// // Copyright ยฉ 2022 Hardcore Engineering Inc. // // Licensed under the Eclipse Public License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. You may // obtain a copy of the License at https://www.eclipse.org/legal/epl-2.0 // // Unless required by applicable law or agreed to in writing, software // distributed under the License is distributed on an "AS IS" BASIS, // WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. // // See the License for the specific language governing permissions and // limitations under the License. // import { Analytics } from '@hcengineering/analytics' import core, { TxFactory, WorkspaceEvent, generateId, systemAccountEmail, toWorkspaceString, versionToString, type BaseWorkspaceInfo, type MeasureContext, type Ref, type Space, type Tx, type TxWorkspaceEvent, type WorkspaceId } from '@hcengineering/core' import { unknownError } from '@hcengineering/platform' import { readRequest, type HelloRequest, type HelloResponse, type Request, type Response } from '@hcengineering/rpc' import type { Pipeline, SessionContext } from '@hcengineering/server-core' import { type Token } from '@hcengineering/server-token' import { LOGGING_ENABLED, type BroadcastCall, type ConnectionSocket, type PipelineFactory, type ServerFactory, type Session, type SessionManager, type Workspace } from './types' interface WorkspaceLoginInfo extends Omit<BaseWorkspaceInfo, 'workspace'> { upgrade?: { toProcess: number total: number elapsed: number eta: number } workspaceId: string } function timeoutPromise (time: number): Promise<void> { return new Promise((resolve) => { setTimeout(resolve, time) }) } /** * @public */ export interface Timeouts { // Timeout preferences pingTimeout: number // Default 1 second reconnectTimeout: number // Default 3 seconds } class TSessionManager implements SessionManager { private readonly statusPromises = new Map<string, Promise<void>>() readonly workspaces = new Map<string, Workspace>() checkInterval: any sessions = new Map<string, { session: Session, socket: ConnectionSocket }>() reconnectIds = new Set<string>() maintenanceTimer: any timeMinutes = 0 modelVersion = process.env.MODEL_VERSION ?? '' constructor ( readonly ctx: MeasureContext, readonly sessionFactory: (token: Token, pipeline: Pipeline, broadcast: BroadcastCall) => Session, readonly timeouts: Timeouts ) { this.checkInterval = setInterval(() => { this.handleInterval() }, timeouts.pingTimeout) } scheduleMaintenance (timeMinutes: number): void { this.timeMinutes = timeMinutes this.sendMaintenanceWarning() const nextTime = (): number => (this.timeMinutes > 1 ? 60 * 1000 : this.timeMinutes * 60 * 1000) const showMaintenance = (): void => { if (this.timeMinutes > 1) { this.timeMinutes -= 1 clearTimeout(this.maintenanceTimer) this.maintenanceTimer = setTimeout(showMaintenance, nextTime()) } else { this.timeMinutes = 0 } this.sendMaintenanceWarning() } clearTimeout(this.maintenanceTimer) this.maintenanceTimer = setTimeout(showMaintenance, nextTime()) } private sendMaintenanceWarning (): void { if (this.timeMinutes === 0) { return } const event: TxWorkspaceEvent = this.createMaintenanceWarning() for (const ws of this.workspaces.values()) { this.broadcastAll(ws, [event]) } } private createMaintenanceWarning (): TxWorkspaceEvent { return { _id: generateId(), _class: core.class.TxWorkspaceEvent, event: WorkspaceEvent.MaintenanceNotification, modifiedBy: core.account.System, modifiedOn: Date.now(), objectSpace: core.space.DerivedTx, space: core.space.DerivedTx, createdBy: core.account.System, params: { timeMinutes: this.timeMinutes } } } ticks = 0 handleInterval (): void { for (const [wsId, workspace] of this.workspaces.entries()) { for (const s of workspace.sessions) { if (this.ticks % (5 * 60) === 0) { s[1].session.mins5.find = s[1].session.current.find s[1].session.mins5.tx = s[1].session.current.tx s[1].session.current = { find: 0, tx: 0 } } const now = Date.now() const diff = now - s[1].session.lastRequest let timeout = 60000 if (s[1].session.getUser() === systemAccountEmail) { timeout = timeout * 10 } if (diff > timeout && this.ticks % 10 === 0) { void this.ctx.error('session hang, closing...', { wsId, user: s[1].session.getUser() }) // Force close workspace if only one client and it hang. void this.close(s[1].socket, workspace.workspaceId) continue } if (diff > 20000 && diff < 60000 && this.ticks % 10 === 0) { void s[1].socket.send( workspace.context, { result: 'ping' }, s[1].session.binaryResponseMode, s[1].session.useCompression ) } for (const r of s[1].session.requests.values()) { if (now - r.start > 30000) { void this.ctx.info('request hang found, 30sec', { wsId, user: s[1].session.getUser(), ...r.params }) } } } // Wait some time for new client to appear before closing workspace. if (workspace.sessions.size === 0 && workspace.closing === undefined) { workspace.softShutdown-- if (workspace.softShutdown <= 0) { void this.ctx.info('closing workspace, no users', { workspace: workspace.workspaceId.name, wsId, upgrade: workspace.upgrade, backup: workspace.backup }) workspace.closing = this.performWorkspaceCloseCheck(workspace, workspace.workspaceId, wsId) } } else { workspace.softShutdown = 3 } } this.ticks++ } createSession (token: Token, pipeline: Pipeline): Session { return this.sessionFactory(token, pipeline, this.broadcast.bind(this)) } async getWorkspaceInfo (accounts: string, token: string): Promise<WorkspaceLoginInfo> { const userInfo = await ( await fetch(accounts, { method: 'POST', headers: { Authorization: 'Bearer ' + token, 'Content-Type': 'application/json' }, body: JSON.stringify({ method: 'getWorkspaceInfo', params: [true] }) }) ).json() if (userInfo.error !== undefined) { await this.ctx.error('Error response from account service', { error: JSON.stringify(userInfo) }) throw new Error(JSON.stringify(userInfo.error)) } return { ...userInfo.result, upgrade: userInfo.upgrade } } async addSession ( baseCtx: MeasureContext, ws: ConnectionSocket, token: Token, rawToken: string, pipelineFactory: PipelineFactory, productId: string, sessionId: string | undefined, accountsUrl: string ): Promise< | { session: Session, context: MeasureContext, workspaceId: string } | { upgrade: true, upgradeInfo?: WorkspaceLoginInfo['upgrade'] } | { error: any } > { return await baseCtx.with('๐ฒ add-session', {}, async (ctx) => { const wsString = toWorkspaceString(token.workspace, '@') let workspaceInfo = await ctx.with('check-token', {}, async (ctx) => accountsUrl !== '' ? await this.getWorkspaceInfo(accountsUrl, rawToken) : this.wsFromToken(token) ) if (workspaceInfo?.creating === true && token.email !== systemAccountEmail) { // No access to workspace for token. return { error: new Error(`Workspace during creation phase ${token.email} ${token.workspace.name}`) } } if (workspaceInfo === undefined && token.extra?.admin !== 'true') { // No access to workspace for token. return { error: new Error(`No access to workspace for token ${token.email} ${token.workspace.name}`) } } else if (workspaceInfo === undefined) { workspaceInfo = this.wsFromToken(token) } if ( this.modelVersion !== '' && workspaceInfo.version !== undefined && this.modelVersion !== versionToString(workspaceInfo.version) && token.extra?.model !== 'upgrade' && token.extra?.mode !== 'backup' ) { await ctx.info('model version mismatch', { version: this.modelVersion, workspaceVersion: versionToString(workspaceInfo.version) }) // Version mismatch, return upgrading. return { upgrade: true, upgradeInfo: workspaceInfo.upgrade } } let workspace = this.workspaces.get(wsString) if (workspace?.closing !== undefined) { await workspace?.closing } workspace = this.workspaces.get(wsString) if (sessionId !== undefined && workspace?.sessions?.has(sessionId) === true) { const helloResponse: HelloResponse = { id: -1, result: 'hello', binary: false, reconnect: false, alreadyConnected: true } await ws.send(ctx, helloResponse, false, false) return { error: new Error('Session already exists') } } const workspaceName = workspaceInfo.workspaceName ?? workspaceInfo.workspaceUrl ?? workspaceInfo.workspaceId if (workspace === undefined) { await ctx.info('open workspace', { email: token.email, workspace: workspaceInfo.workspaceId, wsUrl: workspaceInfo.workspaceUrl, ...token.extra }) workspace = this.createWorkspace( baseCtx, pipelineFactory, token, workspaceInfo.workspaceUrl ?? workspaceInfo.workspaceId, workspaceName ) } let pipeline: Pipeline if (token.extra?.model === 'upgrade') { if (workspace.upgrade) { await ctx.info('reconnect workspace in upgrade', { email: token.email, workspace: workspaceInfo.workspaceId, wsUrl: workspaceInfo.workspaceUrl }) pipeline = await ctx.with('๐ค wait', { workspaceName }, async () => await (workspace as Workspace).pipeline) } else { await ctx.info('reconnect workspace in upgrade switch', { email: token.email, workspace: workspaceInfo.workspaceId, wsUrl: workspaceInfo.workspaceUrl }) // We need to wait in case previous upgeade connection is already closing. pipeline = await this.switchToUpgradeSession( token, sessionId, ctx, wsString, workspace, pipelineFactory, ws, workspaceInfo.workspaceUrl ?? workspaceInfo.workspaceId, workspaceName ) } } else { if (workspace.upgrade) { await ctx.info('connect during upgrade', { email: token.email, workspace: workspace.workspaceId.name, sessionUsers: Array.from(workspace.sessions.values()).map((it) => it.session.getUser()), sessionData: Array.from(workspace.sessions.values()).map((it) => it.socket.data()) }) return { upgrade: true } } pipeline = await ctx.with('๐ค wait', { workspaceName }, async () => await (workspace as Workspace).pipeline) } const session = this.createSession(token, pipeline) session.sessionId = sessionId !== undefined && (sessionId ?? '').trim().length > 0 ? sessionId : generateId() session.sessionInstanceId = generateId() this.sessions.set(ws.id, { session, socket: ws }) // We need to delete previous session with Id if found. workspace.sessions.set(session.sessionId, { session, socket: ws }) // We do not need to wait for set-status, just return session to client void ctx.with('set-status', {}, (ctx) => this.trySetStatus(ctx, session, true)) if (this.timeMinutes > 0) { void ws.send( ctx, { result: this.createMaintenanceWarning() }, session.binaryResponseMode, session.useCompression ) } return { session, context: workspace.context, workspaceId: wsString } }) } private wsFromToken (token: Token): WorkspaceLoginInfo { return { workspaceId: token.workspace.name, workspaceUrl: token.workspace.name, workspaceName: token.workspace.name, createdBy: '', createdOn: Date.now(), lastVisit: Date.now(), productId: '', createProgress: 100, creating: false, disabled: false } } private async switchToUpgradeSession ( token: Token, sessionId: string | undefined, ctx: MeasureContext, wsString: string, workspace: Workspace, pipelineFactory: PipelineFactory, ws: ConnectionSocket, workspaceUrl: string, workspaceName: string ): Promise<Pipeline> { if (LOGGING_ENABLED) { await ctx.info('reloading workspace', { workspaceName, token: JSON.stringify(token) }) } // Mark as upgrade, to prevent any new clients to connect during close workspace.upgrade = true workspace.backup = token.extra?.mode === 'backup' // If upgrade client is used. // Drop all existing clients workspace.closing = this.closeAll(wsString, workspace, 0, 'upgrade') await workspace.closing // Wipe workspace and update values. workspace.workspaceName = workspaceName if (!workspace.upgrade) { // This is previous workspace, intended to be closed. workspace.id = generateId() workspace.sessions = new Map() } // Re-create pipeline. workspace.pipeline = pipelineFactory( ctx, { ...token.workspace, workspaceUrl, workspaceName }, true, (tx, targets) => { this.broadcastAll(workspace, tx, targets) } ) return await workspace.pipeline } broadcastAll (workspace: Workspace, tx: Tx[], targets?: string[]): void { if (workspace.upgrade) { return } const ctx = this.ctx.newChild('๐ฌ broadcast-all', {}) const sessions = [...workspace.sessions.values()] function send (): void { for (const session of sessions.splice(0, 1)) { if (targets !== undefined && !targets.includes(session.session.getUser())) continue for (const _tx of tx) { try { void session.socket.send( ctx, { result: _tx }, session.session.binaryResponseMode, session.session.useCompression ) } catch (err: any) { Analytics.handleError(err) void ctx.error('error during send', { error: err }) } } } if (sessions.length > 0) { setImmediate(send) } else { ctx.end() } } send() } private createWorkspace ( ctx: MeasureContext, pipelineFactory: PipelineFactory, token: Token, workspaceUrl: string, workspaceName: string ): Workspace { const upgrade = token.extra?.model === 'upgrade' const backup = token.extra?.mode === 'backup' const context = ctx.newChild('๐งฒ session', {}) const pipelineCtx = context.newChild('๐งฒ pipeline-factory', {}) const workspace: Workspace = { context, id: generateId(), pipeline: pipelineFactory( pipelineCtx, { ...token.workspace, workspaceUrl, workspaceName }, upgrade, (tx, targets) => { this.broadcastAll(workspace, tx, targets) } ), sessions: new Map(), softShutdown: 3, upgrade, backup, workspaceId: token.workspace, workspaceName } this.workspaces.set(toWorkspaceString(token.workspace), workspace) return workspace } private async trySetStatus (ctx: MeasureContext, session: Session, online: boolean): Promise<void> { const current = this.statusPromises.get(session.getUser()) if (current !== undefined) { await current } const promise = this.setStatus(ctx, session, online) this.statusPromises.set(session.getUser(), promise) await promise this.statusPromises.delete(session.getUser()) } private async setStatus (ctx: MeasureContext, session: Session, online: boolean): Promise<void> { try { const user = ( await session.pipeline().modelDb.findAll( core.class.Account, { email: session.getUser() }, { limit: 1 } ) )[0] if (user === undefined) return const status = (await session.findAll(ctx, core.class.UserStatus, { user: user._id }, { limit: 1 }))[0] const txFactory = new TxFactory(user._id, true) if (status === undefined) { const tx = txFactory.createTxCreateDoc(core.class.UserStatus, user._id as string as Ref<Space>, { online, user: user._id }) await session.tx(ctx, tx) } else if (status.online !== online) { const tx = txFactory.createTxUpdateDoc(status._class, status.space, status._id, { online }) await session.tx(ctx, tx) } } catch {} } async close (ws: ConnectionSocket, workspaceId: WorkspaceId): Promise<void> { const wsid = toWorkspaceString(workspaceId) const workspace = this.workspaces.get(wsid) if (workspace === undefined) { return } const sessionRef = this.sessions.get(ws.id) if (sessionRef !== undefined) { this.sessions.delete(ws.id) workspace.sessions.delete(sessionRef.session.sessionId) this.reconnectIds.add(sessionRef.session.sessionId) setTimeout(() => { this.reconnectIds.delete(sessionRef.session.sessionId) }, this.timeouts.reconnectTimeout) try { sessionRef.socket.close() } catch (err) { // Ignore if closed } const user = sessionRef.session.getUser() const another = Array.from(workspace.sessions.values()).findIndex((p) => p.session.getUser() === user) if (another === -1 && !workspace.upgrade) { await this.trySetStatus(workspace.context, sessionRef.session, false) } } } async forceClose (wsId: string, ignoreSocket?: ConnectionSocket): Promise<void> { const ws = this.workspaces.get(wsId) if (ws !== undefined) { ws.upgrade = true // We need to similare upgrade to refresh all clients. ws.closing = this.closeAll(wsId, ws, 99, 'force-close', ignoreSocket) await ws.closing this.workspaces.delete(wsId) } } async closeAll ( wsId: string, workspace: Workspace, code: number, reason: 'upgrade' | 'shutdown' | 'force-close', ignoreSocket?: ConnectionSocket ): Promise<void> { if (LOGGING_ENABLED) { await this.ctx.info('closing workspace', { workspace: workspace.id, wsName: workspace.workspaceName, code, reason, wsId }) } const sessions = Array.from(workspace.sessions) workspace.sessions = new Map() const closeS = async (s: Session, webSocket: ConnectionSocket): Promise<void> => { s.workspaceClosed = true if (reason === 'upgrade' || reason === 'force-close') { // Override message handler, to wait for upgrading response from clients. await this.sendUpgrade(workspace.context, webSocket, s.binaryResponseMode) } webSocket.close() } if (LOGGING_ENABLED) { await this.ctx.info('Clients disconnected. Closing Workspace...', { wsId, workspace: workspace.id, wsName: workspace.workspaceName }) } await Promise.all( sessions.filter((it) => it[1].socket.id !== ignoreSocket?.id).map((s) => closeS(s[1].session, s[1].socket)) ) const closePipeline = async (): Promise<void> => { try { await this.ctx.with('close-pipeline', {}, async () => { await (await workspace.pipeline).close() }) } catch (err: any) { Analytics.handleError(err) await this.ctx.error('close-pipeline-error', { error: err }) } } await this.ctx.with('closing', {}, async () => { await Promise.race([closePipeline(), timeoutPromise(120000)]) }) if (LOGGING_ENABLED) { await this.ctx.info('Workspace closed...', { workspace: workspace.id, wsId, wsName: workspace.workspaceName }) } } private async sendUpgrade (ctx: MeasureContext, webSocket: ConnectionSocket, binary: boolean): Promise<void> { await webSocket.send( ctx, { result: { _class: core.class.TxModelUpgrade } }, binary, false ) } async closeWorkspaces (ctx: MeasureContext): Promise<void> { if (this.checkInterval !== undefined) { clearInterval(this.checkInterval) } for (const w of this.workspaces) { await this.closeAll(w[0], w[1], 1, 'shutdown') } } private async performWorkspaceCloseCheck ( workspace: Workspace, workspaceId: WorkspaceId, wsid: string ): Promise<void> { const wsUID = workspace.id const logParams = { wsid, workspace: workspace.id, wsName: workspaceId.name } if (workspace.sessions.size === 0) { if (LOGGING_ENABLED) { await this.ctx.info('no sessions for workspace', logParams) } try { if (workspace.sessions.size === 0) { const pl = await workspace.pipeline await Promise.race([pl, timeoutPromise(60000)]) await Promise.race([pl.close(), timeoutPromise(60000)]) if (this.workspaces.get(wsid)?.id === wsUID) { this.workspaces.delete(wsid) } workspace.context.end() if (LOGGING_ENABLED) { await this.ctx.info('Closed workspace', logParams) } } } catch (err: any) { Analytics.handleError(err) this.workspaces.delete(wsid) if (LOGGING_ENABLED) { await this.ctx.error('failed', { ...logParams, error: err }) } } } else { if (LOGGING_ENABLED) { await this.ctx.info('few sessions for workspace, close skipped', { ...logParams, sessions: workspace.sessions.size }) } } } broadcast (from: Session | null, workspaceId: WorkspaceId, resp: Response<any>, target?: string[]): void { const workspace = this.workspaces.get(toWorkspaceString(workspaceId)) if (workspace === undefined) { void this.ctx.error('internal: cannot find sessions', { workspaceId: workspaceId.name, target, userId: from?.getUser() ?? '$unknown' }) return } if (workspace?.upgrade ?? false) { return } if (LOGGING_ENABLED) { void this.ctx.info('server broadcasting to clients...', { workspace: workspaceId.name, count: workspace.sessions.size }) } const sessions = [...workspace.sessions.values()] const ctx = this.ctx.newChild('๐ญ broadcast', {}) function send (): void { for (const sessionRef of sessions.splice(0, 1)) { if (sessionRef.session.sessionId !== from?.sessionId) { if (target === undefined) { void sessionRef.socket.send( ctx, resp, sessionRef.session.binaryResponseMode, sessionRef.session.useCompression ) } else if (target.includes(sessionRef.session.getUser())) { void sessionRef.socket.send( ctx, resp, sessionRef.session.binaryResponseMode, sessionRef.session.useCompression ) } } } if (sessions.length > 0) { setImmediate(send) } else { ctx.end() } } send() } async handleRequest<S extends Session>( requestCtx: MeasureContext, service: S, ws: ConnectionSocket, msg: any, workspace: string ): Promise<void> { const userCtx = requestCtx.newChild('๐ client', { workspace: '๐งฒ ' + workspace }) as SessionContext userCtx.sessionId = service.sessionInstanceId ?? '' // Calculate total number of clients const reqId = generateId() const st = Date.now() try { const backupMode = 'loadChunk' in service await userCtx.with(`๐งญ ${backupMode ? 'handleBackup' : 'handleRequest'}`, {}, async (ctx) => { const request = await ctx.with('๐ฅ read', {}, async () => readRequest(msg, false)) if (request.method === 'forceClose') { const wsRef = this.workspaces.get(workspace) let done = false if (wsRef !== undefined) { if (wsRef.upgrade) { done = true console.log('FORCE CLOSE', workspace) // In case of upgrade, we need to force close workspace not in interval handler await this.forceClose(workspace, ws) } } const forceCloseResponse: Response<any> = { id: request.id, result: done } await ws.send(ctx, forceCloseResponse, service.binaryResponseMode, service.useCompression) return } if (request.id === -1 && request.method === 'hello') { const hello = request as HelloRequest service.binaryResponseMode = hello.binary ?? false service.useCompression = hello.compression ?? false service.useBroadcast = hello.broadcast ?? false if (LOGGING_ENABLED) { await ctx.info('hello happen', { workspace, user: service.getUser(), binary: service.binaryResponseMode, compression: service.useCompression, timeToHello: Date.now() - service.createTime, workspaceUsers: this.workspaces.get(workspace)?.sessions?.size, totalUsers: this.sessions.size }) } const helloResponse: HelloResponse = { id: -1, result: 'hello', binary: service.binaryResponseMode, reconnect: this.reconnectIds.has(service.sessionId) } await ws.send(ctx, helloResponse, false, false) return } if (request.method === 'measure' || request.method === 'measure-done') { await this.handleMeasure<S>(service, request, ctx, ws) return } service.requests.set(reqId, { id: reqId, params: request, start: st }) if (request.id === -1 && request.method === '#upgrade') { ws.close() return } const f = (service as any)[request.method] try { const params = [...request.params] const result = service.measureCtx?.ctx !== undefined ? await f.apply(service, [service.measureCtx?.ctx, ...params]) : await ctx.with('๐งจ process', {}, async (callTx) => f.apply(service, [callTx, ...params])) const resp: Response<any> = { id: request.id, result } await handleSend( ctx, ws, resp, this.sessions.size < 100 ? 10000 : 1001, service.binaryResponseMode, service.useCompression ) } catch (err: any) { Analytics.handleError(err) if (LOGGING_ENABLED) { await this.ctx.error('error handle request', { error: err, request }) } const resp: Response<any> = { id: request.id, error: unknownError(err), result: JSON.parse(JSON.stringify(err?.stack)) } await ws.send(ctx, resp, service.binaryResponseMode, service.useCompression) } }) } finally { userCtx.end() service.requests.delete(reqId) } } private async handleMeasure<S extends Session>( service: S, request: Request<any[]>, ctx: MeasureContext, ws: ConnectionSocket ): Promise<void> { let serverTime = 0 if (request.method === 'measure') { service.measureCtx = { ctx: ctx.newChild('๐ถ ' + request.params[0], {}), time: Date.now() } } else { if (service.measureCtx !== undefined) { serverTime = Date.now() - service.measureCtx.time service.measureCtx.ctx.end(serverTime) } } try { const resp: Response<any> = { id: request.id, result: request.method === 'measure' ? 'started' : serverTime } await handleSend( ctx, ws, resp, this.sessions.size < 100 ? 10000 : 1001, service.binaryResponseMode, service.useCompression ) } catch (err: any) { Analytics.handleError(err) if (LOGGING_ENABLED) { await ctx.error('error handle measure', { error: err, request }) } const resp: Response<any> = { id: request.id, error: unknownError(err), result: JSON.parse(JSON.stringify(err?.stack)) } await ws.send(ctx, resp, service.binaryResponseMode, service.useCompression) } } } async function handleSend ( ctx: MeasureContext, ws: ConnectionSocket, msg: Response<any>, chunkLimit: number, useBinary: boolean, useCompression: boolean ): Promise<void> { // ws.send(msg) if (Array.isArray(msg.result) && chunkLimit > 0 && msg.result.length > chunkLimit) { // Split and send by chunks const data = [...msg.result] let cid = 1 while (data.length > 0) { const chunk = data.splice(0, chunkLimit) if (chunk !== undefined) { await ws.send( ctx, { ...msg, result: chunk, chunk: { index: cid, final: data.length === 0 } }, useBinary, useCompression ) } cid++ } } else { await ws.send(ctx, msg, useBinary, useCompression) } } /** * @public */ export function start ( ctx: MeasureContext, opt: { port: number pipelineFactory: PipelineFactory sessionFactory: (token: Token, pipeline: Pipeline, broadcast: BroadcastCall) => Session productId: string serverFactory: ServerFactory enableCompression?: boolean accountsUrl: string } & Partial<Timeouts> ): () => Promise<void> { const sessions = new TSessionManager(ctx, opt.sessionFactory, { pingTimeout: opt.pingTimeout ?? 10000, reconnectTimeout: 500 }) return opt.serverFactory( sessions, (rctx, service, ws, msg, workspace) => sessions.handleRequest(rctx, service, ws, msg, workspace), ctx, opt.pipelineFactory, opt.port, opt.productId, opt.enableCompression ?? true, opt.accountsUrl ) }