mirror of
https://github.com/hwanny1128/HGZero.git
synced 2025-12-06 21:56:24 +00:00
주요 변경사항:
- Event Hub 리스너를 Python AI Service에 통합하여 STT 텍스트 실시간 수신
- LocalDateTime 배열 형식을 Unix timestamp로 변환하는 로직 추가
- SSE 응답에 CORS 헤더 명시적 추가 (localhost:8888 허용)
- SSE Keep-alive를 위한 ping 이벤트 추가 (5초 주기)
- Redis 데이터 정리 스크립트 추가
- 분석 임계값을 MVP 수준으로 조정 (3개 세그먼트 = 약 15-30초)
- 프론트엔드 SSE 연동 가이드 문서 작성
- 프론트엔드에 ping 이벤트 핸들러 추가 및 에러 핸들링 개선
기술적 개선사항:
- EventSourceResponse에 Access-Control-Allow-Origin 헤더 추가
- timestamp 변환 로직으로 Java-Python 호환성 해결
- Redis 저장 오류 로깅 강화
- SSE generator에 주기적 heartbeat 전송으로 연결 유지
문서:
- develop/dev/ai-frontend-integration-guide.md: 프론트엔드 개발자를 위한 상세 연동 가이드
🤖 Generated with Claude Code
Co-Authored-By: Claude <noreply@anthropic.com>
134 lines
5.0 KiB
Python
134 lines
5.0 KiB
Python
"""Azure Event Hub 서비스 - STT 텍스트 수신"""
|
|
import asyncio
|
|
import logging
|
|
import json
|
|
from azure.eventhub.aio import EventHubConsumerClient
|
|
|
|
from app.config import get_settings
|
|
from app.services.redis_service import RedisService
|
|
|
|
logger = logging.getLogger(__name__)
|
|
settings = get_settings()
|
|
|
|
|
|
class EventHubService:
|
|
"""Event Hub 리스너 - STT 텍스트 실시간 수신"""
|
|
|
|
def __init__(self):
|
|
self.client = None
|
|
self.redis_service = RedisService()
|
|
|
|
async def start(self):
|
|
"""Event Hub 리스닝 시작"""
|
|
if not settings.eventhub_connection_string:
|
|
logger.warning("Event Hub 연결 문자열이 설정되지 않음 - Event Hub 리스너 비활성화")
|
|
return
|
|
|
|
logger.info("Event Hub 리스너 시작")
|
|
|
|
try:
|
|
# Redis 연결
|
|
await self.redis_service.connect()
|
|
|
|
# Event Hub 클라이언트 생성
|
|
self.client = EventHubConsumerClient.from_connection_string(
|
|
conn_str=settings.eventhub_connection_string,
|
|
consumer_group=settings.eventhub_consumer_group,
|
|
eventhub_name=settings.eventhub_name,
|
|
)
|
|
|
|
# 이벤트 수신 시작
|
|
async with self.client:
|
|
await self.client.receive(
|
|
on_event=self.on_event,
|
|
on_error=self.on_error,
|
|
starting_position="-1", # 최신 이벤트부터
|
|
)
|
|
|
|
except Exception as e:
|
|
logger.error(f"Event Hub 리스너 오류: {e}")
|
|
finally:
|
|
await self.redis_service.disconnect()
|
|
|
|
async def on_event(self, partition_context, event):
|
|
"""
|
|
이벤트 수신 핸들러
|
|
|
|
이벤트 형식 (STT Service에서 발행):
|
|
{
|
|
"eventType": "TranscriptSegmentReady",
|
|
"meetingId": "meeting-123",
|
|
"text": "변환된 텍스트",
|
|
"timestamp": 1234567890000
|
|
}
|
|
"""
|
|
try:
|
|
# 이벤트 원본 데이터 로깅
|
|
raw_body = event.body_as_str()
|
|
logger.info(f"수신한 이벤트 원본 (처음 300자): {raw_body[:300]}")
|
|
|
|
# 이벤트 데이터 파싱
|
|
event_data = json.loads(raw_body)
|
|
|
|
event_type = event_data.get("eventType")
|
|
meeting_id = event_data.get("meetingId")
|
|
text = event_data.get("text")
|
|
timestamp_raw = event_data.get("timestamp")
|
|
|
|
# timestamp 변환: LocalDateTime 배열 → Unix timestamp (ms)
|
|
# Java LocalDateTime은 [year, month, day, hour, minute, second, nano] 형식
|
|
if isinstance(timestamp_raw, list) and len(timestamp_raw) >= 3:
|
|
from datetime import datetime
|
|
year, month, day = timestamp_raw[0:3]
|
|
hour = timestamp_raw[3] if len(timestamp_raw) > 3 else 0
|
|
minute = timestamp_raw[4] if len(timestamp_raw) > 4 else 0
|
|
second = timestamp_raw[5] if len(timestamp_raw) > 5 else 0
|
|
dt = datetime(year, month, day, hour, minute, second)
|
|
timestamp = int(dt.timestamp() * 1000) # milliseconds
|
|
else:
|
|
timestamp = int(timestamp_raw) if timestamp_raw else int(datetime.now().timestamp() * 1000)
|
|
|
|
# SegmentCreated 이벤트 처리
|
|
if event_type == "SegmentCreated" and meeting_id and text:
|
|
logger.info(
|
|
f"STT 텍스트 수신 - meetingId: {meeting_id}, "
|
|
f"텍스트 길이: {len(text)}, timestamp: {timestamp}"
|
|
)
|
|
|
|
try:
|
|
# Redis에 텍스트 축적 (슬라이딩 윈도우)
|
|
await self.redis_service.add_transcript_segment(
|
|
meeting_id=meeting_id,
|
|
text=text,
|
|
timestamp=timestamp
|
|
)
|
|
logger.info(f"✅ Redis 저장 완료 - meetingId: {meeting_id}, timestamp: {timestamp}")
|
|
except Exception as redis_error:
|
|
logger.error(f"❌ Redis 저장 실패 - meetingId: {meeting_id}, 오류: {redis_error}", exc_info=True)
|
|
|
|
# MVP 개발: checkpoint 업데이트 제거 (InMemory 모드)
|
|
# await partition_context.update_checkpoint(event)
|
|
|
|
except Exception as e:
|
|
logger.error(f"이벤트 처리 오류: {e}", exc_info=True)
|
|
|
|
async def on_error(self, partition_context, error):
|
|
"""에러 핸들러"""
|
|
logger.error(
|
|
f"Event Hub 에러 - Partition: {partition_context.partition_id}, "
|
|
f"Error: {error}"
|
|
)
|
|
|
|
async def stop(self):
|
|
"""Event Hub 리스너 종료"""
|
|
if self.client:
|
|
await self.client.close()
|
|
logger.info("Event Hub 리스너 종료")
|
|
|
|
|
|
# 백그라운드 태스크로 실행할 함수
|
|
async def start_eventhub_listener():
|
|
"""Event Hub 리스너 백그라운드 실행"""
|
|
service = EventHubService()
|
|
await service.start()
|