1 import crypto from
'node:crypto'
2 import { performance
} from
'node:perf_hooks'
3 import type { MessageValue
, PromiseResponseWrapper
} from
'../utility-types'
5 DEFAULT_WORKER_CHOICE_STRATEGY_OPTIONS
,
10 import { KillBehaviors
, isKillBehavior
} from
'../worker/worker-options'
11 import { CircularArray
} from
'../circular-array'
12 import { Queue
} from
'../queue'
21 type TasksQueueOptions
,
32 WorkerChoiceStrategies
,
33 type WorkerChoiceStrategy
,
34 type WorkerChoiceStrategyOptions
35 } from
'./selection-strategies/selection-strategies-types'
36 import { WorkerChoiceStrategyContext
} from
'./selection-strategies/worker-choice-strategy-context'
39 * Base class that implements some shared logic for all poolifier pools.
41 * @typeParam Worker - Type of worker which manages this pool.
42 * @typeParam Data - Type of data sent to the worker. This can only be serializable data.
43 * @typeParam Response - Type of execution response. This can only be serializable data.
45 export abstract class AbstractPool
<
46 Worker
extends IWorker
,
49 > implements IPool
<Worker
, Data
, Response
> {
51 public readonly workerNodes
: Array<WorkerNode
<Worker
, Data
>> = []
54 public readonly emitter
?: PoolEmitter
57 * The execution response promise map.
59 * - `key`: The message id of each submitted task.
60 * - `value`: An object that contains the worker, the execution response promise resolve and reject callbacks.
62 * When we receive a message from the worker, we get a map entry with the promise resolve/reject bound to the message id.
64 protected promiseResponseMap
: Map
<
66 PromiseResponseWrapper
<Worker
, Response
>
67 > = new Map
<string, PromiseResponseWrapper
<Worker
, Response
>>()
70 * Worker choice strategy context referencing a worker choice algorithm implementation.
72 protected workerChoiceStrategyContext
: WorkerChoiceStrategyContext
<
79 * Constructs a new poolifier pool.
81 * @param numberOfWorkers - Number of workers that this pool should manage.
82 * @param filePath - Path to the worker file.
83 * @param opts - Options for the pool.
86 protected readonly numberOfWorkers
: number,
87 protected readonly filePath
: string,
88 protected readonly opts
: PoolOptions
<Worker
>
91 throw new Error('Cannot start a pool from a worker!')
93 this.checkNumberOfWorkers(this.numberOfWorkers
)
94 this.checkFilePath(this.filePath
)
95 this.checkPoolOptions(this.opts
)
97 this.chooseWorkerNode
= this.chooseWorkerNode
.bind(this)
98 this.executeTask
= this.executeTask
.bind(this)
99 this.enqueueTask
= this.enqueueTask
.bind(this)
100 this.checkAndEmitEvents
= this.checkAndEmitEvents
.bind(this)
102 if (this.opts
.enableEvents
=== true) {
103 this.emitter
= new PoolEmitter()
105 this.workerChoiceStrategyContext
= new WorkerChoiceStrategyContext
<
111 this.opts
.workerChoiceStrategy
,
112 this.opts
.workerChoiceStrategyOptions
117 for (let i
= 1; i
<= this.numberOfWorkers
; i
++) {
118 this.createAndSetupWorker()
122 private checkFilePath (filePath
: string): void {
125 (typeof filePath
=== 'string' && filePath
.trim().length
=== 0)
127 throw new Error('Please specify a file with a worker implementation')
131 private checkNumberOfWorkers (numberOfWorkers
: number): void {
132 if (numberOfWorkers
== null) {
134 'Cannot instantiate a pool without specifying the number of workers'
136 } else if (!Number.isSafeInteger(numberOfWorkers
)) {
138 'Cannot instantiate a pool with a non safe integer number of workers'
140 } else if (numberOfWorkers
< 0) {
141 throw new RangeError(
142 'Cannot instantiate a pool with a negative number of workers'
144 } else if (this.type === PoolTypes
.fixed
&& numberOfWorkers
=== 0) {
145 throw new Error('Cannot instantiate a fixed pool with no worker')
149 private checkPoolOptions (opts
: PoolOptions
<Worker
>): void {
150 if (isPlainObject(opts
)) {
151 this.opts
.workerChoiceStrategy
=
152 opts
.workerChoiceStrategy
?? WorkerChoiceStrategies
.ROUND_ROBIN
153 this.checkValidWorkerChoiceStrategy(this.opts
.workerChoiceStrategy
)
154 this.opts
.workerChoiceStrategyOptions
=
155 opts
.workerChoiceStrategyOptions
??
156 DEFAULT_WORKER_CHOICE_STRATEGY_OPTIONS
157 this.checkValidWorkerChoiceStrategyOptions(
158 this.opts
.workerChoiceStrategyOptions
160 this.opts
.restartWorkerOnError
= opts
.restartWorkerOnError
?? true
161 this.opts
.enableEvents
= opts
.enableEvents
?? true
162 this.opts
.enableTasksQueue
= opts
.enableTasksQueue
?? false
163 if (this.opts
.enableTasksQueue
) {
164 this.checkValidTasksQueueOptions(
165 opts
.tasksQueueOptions
as TasksQueueOptions
167 this.opts
.tasksQueueOptions
= this.buildTasksQueueOptions(
168 opts
.tasksQueueOptions
as TasksQueueOptions
172 throw new TypeError('Invalid pool options: must be a plain object')
176 private checkValidWorkerChoiceStrategy (
177 workerChoiceStrategy
: WorkerChoiceStrategy
179 if (!Object.values(WorkerChoiceStrategies
).includes(workerChoiceStrategy
)) {
181 `Invalid worker choice strategy '${workerChoiceStrategy}'`
186 private checkValidWorkerChoiceStrategyOptions (
187 workerChoiceStrategyOptions
: WorkerChoiceStrategyOptions
189 if (!isPlainObject(workerChoiceStrategyOptions
)) {
191 'Invalid worker choice strategy options: must be a plain object'
195 workerChoiceStrategyOptions
.weights
!= null &&
196 Object.keys(workerChoiceStrategyOptions
.weights
).length
!== this.maxSize
199 'Invalid worker choice strategy options: must have a weight for each worker node'
204 private checkValidTasksQueueOptions (
205 tasksQueueOptions
: TasksQueueOptions
207 if (tasksQueueOptions
!= null && !isPlainObject(tasksQueueOptions
)) {
208 throw new TypeError('Invalid tasks queue options: must be a plain object')
210 if ((tasksQueueOptions
?.concurrency
as number) <= 0) {
212 `Invalid worker tasks concurrency '${
213 tasksQueueOptions.concurrency as number
220 public get
info (): PoolInfo
{
224 minSize
: this.minSize
,
225 maxSize
: this.maxSize
,
226 workerNodes
: this.workerNodes
.length
,
227 idleWorkerNodes
: this.workerNodes
.reduce(
228 (accumulator
, workerNode
) =>
229 workerNode
.workerUsage
.tasks
.executing
=== 0
234 busyWorkerNodes
: this.workerNodes
.reduce(
235 (accumulator
, workerNode
) =>
236 workerNode
.workerUsage
.tasks
.executing
> 0
241 executedTasks
: this.workerNodes
.reduce(
242 (accumulator
, workerNode
) =>
243 accumulator
+ workerNode
.workerUsage
.tasks
.executed
,
246 executingTasks
: this.workerNodes
.reduce(
247 (accumulator
, workerNode
) =>
248 accumulator
+ workerNode
.workerUsage
.tasks
.executing
,
251 queuedTasks
: this.workerNodes
.reduce(
252 (accumulator
, workerNode
) => accumulator
+ workerNode
.tasksQueue
.size
,
255 maxQueuedTasks
: this.workerNodes
.reduce(
256 (accumulator
, workerNode
) =>
257 accumulator
+ workerNode
.tasksQueue
.maxSize
,
260 failedTasks
: this.workerNodes
.reduce(
261 (accumulator
, workerNode
) =>
262 accumulator
+ workerNode
.workerUsage
.tasks
.failed
,
271 * If it is `'dynamic'`, it provides the `max` property.
273 protected abstract get
type (): PoolType
276 * Gets the worker type.
278 protected abstract get
worker (): WorkerType
283 protected abstract get
minSize (): number
288 protected abstract get
maxSize (): number
291 * Gets the given worker its worker node key.
293 * @param worker - The worker.
294 * @returns The worker node key if the worker is found in the pool worker nodes, `-1` otherwise.
296 private getWorkerNodeKey (worker
: Worker
): number {
297 return this.workerNodes
.findIndex(
298 workerNode
=> workerNode
.worker
=== worker
303 public setWorkerChoiceStrategy (
304 workerChoiceStrategy
: WorkerChoiceStrategy
,
305 workerChoiceStrategyOptions
?: WorkerChoiceStrategyOptions
307 this.checkValidWorkerChoiceStrategy(workerChoiceStrategy
)
308 this.opts
.workerChoiceStrategy
= workerChoiceStrategy
309 this.workerChoiceStrategyContext
.setWorkerChoiceStrategy(
310 this.opts
.workerChoiceStrategy
312 if (workerChoiceStrategyOptions
!= null) {
313 this.setWorkerChoiceStrategyOptions(workerChoiceStrategyOptions
)
315 for (const workerNode
of this.workerNodes
) {
316 this.setWorkerNodeTasksUsage(
318 this.getWorkerUsage(workerNode
.worker
)
320 this.setWorkerStatistics(workerNode
.worker
)
325 public setWorkerChoiceStrategyOptions (
326 workerChoiceStrategyOptions
: WorkerChoiceStrategyOptions
328 this.checkValidWorkerChoiceStrategyOptions(workerChoiceStrategyOptions
)
329 this.opts
.workerChoiceStrategyOptions
= workerChoiceStrategyOptions
330 this.workerChoiceStrategyContext
.setOptions(
331 this.opts
.workerChoiceStrategyOptions
336 public enableTasksQueue (
338 tasksQueueOptions
?: TasksQueueOptions
340 if (this.opts
.enableTasksQueue
=== true && !enable
) {
341 this.flushTasksQueues()
343 this.opts
.enableTasksQueue
= enable
344 this.setTasksQueueOptions(tasksQueueOptions
as TasksQueueOptions
)
348 public setTasksQueueOptions (tasksQueueOptions
: TasksQueueOptions
): void {
349 if (this.opts
.enableTasksQueue
=== true) {
350 this.checkValidTasksQueueOptions(tasksQueueOptions
)
351 this.opts
.tasksQueueOptions
=
352 this.buildTasksQueueOptions(tasksQueueOptions
)
353 } else if (this.opts
.tasksQueueOptions
!= null) {
354 delete this.opts
.tasksQueueOptions
358 private buildTasksQueueOptions (
359 tasksQueueOptions
: TasksQueueOptions
360 ): TasksQueueOptions
{
362 concurrency
: tasksQueueOptions
?.concurrency
?? 1
367 * Whether the pool is full or not.
369 * The pool filling boolean status.
371 protected get
full (): boolean {
372 return this.workerNodes
.length
>= this.maxSize
376 * Whether the pool is busy or not.
378 * The pool busyness boolean status.
380 protected abstract get
busy (): boolean
382 protected internalBusy (): boolean {
384 this.workerNodes
.findIndex(workerNode
=> {
385 return workerNode
.workerUsage
.tasks
.executing
=== 0
391 public async execute (data
?: Data
, name
?: string): Promise
<Response
> {
392 const timestamp
= performance
.now()
393 const workerNodeKey
= this.chooseWorkerNode()
394 const submittedTask
: Task
<Data
> = {
396 // eslint-disable-next-line @typescript-eslint/consistent-type-assertions
397 data
: data
?? ({} as Data
),
399 id
: crypto
.randomUUID()
401 const res
= new Promise
<Response
>((resolve
, reject
) => {
402 this.promiseResponseMap
.set(submittedTask
.id
as string, {
405 worker
: this.workerNodes
[workerNodeKey
].worker
409 this.opts
.enableTasksQueue
=== true &&
411 this.workerNodes
[workerNodeKey
].workerUsage
.tasks
.executing
>=
412 ((this.opts
.tasksQueueOptions
as TasksQueueOptions
)
413 .concurrency
as number))
415 this.enqueueTask(workerNodeKey
, submittedTask
)
417 this.executeTask(workerNodeKey
, submittedTask
)
419 this.workerChoiceStrategyContext
.update(workerNodeKey
)
420 this.checkAndEmitEvents()
421 // eslint-disable-next-line @typescript-eslint/return-await
426 public async destroy (): Promise
<void> {
428 this.workerNodes
.map(async (workerNode
, workerNodeKey
) => {
429 this.flushTasksQueue(workerNodeKey
)
430 // FIXME: wait for tasks to be finished
431 await this.destroyWorker(workerNode
.worker
)
437 * Shutdowns the given worker.
439 * @param worker - A worker within `workerNodes`.
441 protected abstract destroyWorker (worker
: Worker
): void | Promise
<void>
444 * Setup hook to execute code before worker node are created in the abstract constructor.
449 protected setupHook (): void {
450 // Intentionally empty
454 * Should return whether the worker is the main worker or not.
456 protected abstract isMain (): boolean
459 * Hook executed before the worker task execution.
462 * @param workerNodeKey - The worker node key.
463 * @param task - The task to execute.
465 protected beforeTaskExecutionHook (
466 workerNodeKey
: number,
469 const workerUsage
= this.workerNodes
[workerNodeKey
].workerUsage
470 ++workerUsage
.tasks
.executing
471 this.updateWaitTimeWorkerUsage(workerUsage
, task
)
475 * Hook executed after the worker task execution.
478 * @param worker - The worker.
479 * @param message - The received message.
481 protected afterTaskExecutionHook (
483 message
: MessageValue
<Response
>
486 this.workerNodes
[this.getWorkerNodeKey(worker
)].workerUsage
487 this.updateTaskStatisticsWorkerUsage(workerUsage
, message
)
488 this.updateRunTimeWorkerUsage(workerUsage
, message
)
489 this.updateEluWorkerUsage(workerUsage
, message
)
492 private updateTaskStatisticsWorkerUsage (
493 workerUsage
: WorkerUsage
,
494 message
: MessageValue
<Response
>
496 const workerTaskStatistics
= workerUsage
.tasks
497 --workerTaskStatistics
.executing
498 ++workerTaskStatistics
.executed
499 if (message
.taskError
!= null) {
500 ++workerTaskStatistics
.failed
504 private updateRunTimeWorkerUsage (
505 workerUsage
: WorkerUsage
,
506 message
: MessageValue
<Response
>
509 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements().runTime
512 workerUsage
.runTime
.aggregate
+= message
.taskPerformance
?.runTime
?? 0
514 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements().runTime
516 workerUsage
.tasks
.executed
!== 0
518 workerUsage
.runTime
.average
=
519 workerUsage
.runTime
.aggregate
/
520 (workerUsage
.tasks
.executed
- workerUsage
.tasks
.failed
)
523 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements().runTime
525 message
.taskPerformance
?.runTime
!= null
527 workerUsage
.runTime
.history
.push(message
.taskPerformance
.runTime
)
528 workerUsage
.runTime
.median
= median(workerUsage
.runTime
.history
)
533 private updateWaitTimeWorkerUsage (
534 workerUsage
: WorkerUsage
,
537 const timestamp
= performance
.now()
538 const taskWaitTime
= timestamp
- (task
.timestamp
?? timestamp
)
540 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements().waitTime
543 workerUsage
.waitTime
.aggregate
+= taskWaitTime
?? 0
545 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements()
547 workerUsage
.tasks
.executed
!== 0
549 workerUsage
.waitTime
.average
=
550 workerUsage
.waitTime
.aggregate
/
551 (workerUsage
.tasks
.executed
- workerUsage
.tasks
.failed
)
554 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements()
558 workerUsage
.waitTime
.history
.push(taskWaitTime
)
559 workerUsage
.waitTime
.median
= median(workerUsage
.waitTime
.history
)
564 private updateEluWorkerUsage (
565 workerUsage
: WorkerUsage
,
566 message
: MessageValue
<Response
>
569 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements().elu
572 if (workerUsage
.elu
!= null && message
.taskPerformance
?.elu
!= null) {
573 workerUsage
.elu
.idle
.aggregate
+= message
.taskPerformance
.elu
.idle
574 workerUsage
.elu
.active
.aggregate
+= message
.taskPerformance
.elu
.active
575 workerUsage
.elu
.utilization
=
576 (workerUsage
.elu
.utilization
+
577 message
.taskPerformance
.elu
.utilization
) /
579 } else if (message
.taskPerformance
?.elu
!= null) {
580 workerUsage
.elu
.idle
.aggregate
= message
.taskPerformance
.elu
.idle
581 workerUsage
.elu
.active
.aggregate
= message
.taskPerformance
.elu
.active
582 workerUsage
.elu
.utilization
= message
.taskPerformance
.elu
.utilization
585 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements().elu
587 workerUsage
.tasks
.executed
!== 0
589 const executedTasks
=
590 workerUsage
.tasks
.executed
- workerUsage
.tasks
.failed
591 workerUsage
.elu
.idle
.average
=
592 workerUsage
.elu
.idle
.aggregate
/ executedTasks
593 workerUsage
.elu
.active
.average
=
594 workerUsage
.elu
.active
.aggregate
/ executedTasks
597 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements().elu
599 message
.taskPerformance
?.elu
!= null
601 workerUsage
.elu
.idle
.history
.push(message
.taskPerformance
.elu
.idle
)
602 workerUsage
.elu
.active
.history
.push(message
.taskPerformance
.elu
.active
)
603 workerUsage
.elu
.idle
.median
= median(workerUsage
.elu
.idle
.history
)
604 workerUsage
.elu
.active
.median
= median(workerUsage
.elu
.active
.history
)
610 * Chooses a worker node for the next task.
612 * The default worker choice strategy uses a round robin algorithm to distribute the load.
614 * @returns The worker node key
616 protected chooseWorkerNode (): number {
617 let workerNodeKey
: number
618 if (this.type === PoolTypes
.dynamic
&& !this.full
&& this.internalBusy()) {
619 const workerCreated
= this.createAndSetupWorker()
620 this.registerWorkerMessageListener(workerCreated
, message
=> {
621 const currentWorkerNodeKey
= this.getWorkerNodeKey(workerCreated
)
623 isKillBehavior(KillBehaviors
.HARD
, message
.kill
) ||
624 (message
.kill
!= null &&
625 this.workerNodes
[currentWorkerNodeKey
].workerUsage
.tasks
628 // Kill message received from the worker: no new tasks are submitted to that worker for a while ( > maxInactiveTime)
629 this.flushTasksQueue(currentWorkerNodeKey
)
630 // FIXME: wait for tasks to be finished
631 void (this.destroyWorker(workerCreated
) as Promise
<void>)
634 workerNodeKey
= this.getWorkerNodeKey(workerCreated
)
636 workerNodeKey
= this.workerChoiceStrategyContext
.execute()
642 * Sends a message to the given worker.
644 * @param worker - The worker which should receive the message.
645 * @param message - The message.
647 protected abstract sendToWorker (
649 message
: MessageValue
<Data
>
653 * Registers a listener callback on the given worker.
655 * @param worker - The worker which should register a listener.
656 * @param listener - The message listener callback.
658 protected abstract registerWorkerMessageListener
<
659 Message
extends Data
| Response
660 >(worker
: Worker
, listener
: (message
: MessageValue
<Message
>) => void): void
663 * Returns a newly created worker.
665 protected abstract createWorker (): Worker
668 * Function that can be hooked up when a worker has been newly created and moved to the pool worker nodes.
670 * Can be used to update the `maxListeners` or binding the `main-worker`\<-\>`worker` connection if not bind by default.
672 * @param worker - The newly created worker.
674 protected abstract afterWorkerSetup (worker
: Worker
): void
677 * Creates a new worker and sets it up completely in the pool worker nodes.
679 * @returns New, completely set up worker.
681 protected createAndSetupWorker (): Worker
{
682 const worker
= this.createWorker()
684 worker
.on('message', this.opts
.messageHandler
?? EMPTY_FUNCTION
)
685 worker
.on('error', this.opts
.errorHandler
?? EMPTY_FUNCTION
)
686 worker
.on('error', error
=> {
687 if (this.emitter
!= null) {
688 this.emitter
.emit(PoolEvents
.error
, error
)
690 if (this.opts
.restartWorkerOnError
=== true) {
691 this.createAndSetupWorker()
694 worker
.on('online', this.opts
.onlineHandler
?? EMPTY_FUNCTION
)
695 worker
.on('exit', this.opts
.exitHandler
?? EMPTY_FUNCTION
)
696 worker
.once('exit', () => {
697 this.removeWorkerNode(worker
)
700 this.pushWorkerNode(worker
)
702 this.setWorkerStatistics(worker
)
704 this.afterWorkerSetup(worker
)
710 * This function is the listener registered for each worker message.
712 * @returns The listener function to execute when a message is received from a worker.
714 protected workerListener (): (message
: MessageValue
<Response
>) => void {
716 if (message
.id
!= null) {
717 // Task execution response received
718 const promiseResponse
= this.promiseResponseMap
.get(message
.id
)
719 if (promiseResponse
!= null) {
720 if (message
.taskError
!= null) {
721 promiseResponse
.reject(message
.taskError
.message
)
722 if (this.emitter
!= null) {
723 this.emitter
.emit(PoolEvents
.taskError
, message
.taskError
)
726 promiseResponse
.resolve(message
.data
as Response
)
728 this.afterTaskExecutionHook(promiseResponse
.worker
, message
)
729 this.promiseResponseMap
.delete(message
.id
)
730 const workerNodeKey
= this.getWorkerNodeKey(promiseResponse
.worker
)
732 this.opts
.enableTasksQueue
=== true &&
733 this.tasksQueueSize(workerNodeKey
) > 0
737 this.dequeueTask(workerNodeKey
) as Task
<Data
>
745 private checkAndEmitEvents (): void {
746 if (this.emitter
!= null) {
748 this.emitter
?.emit(PoolEvents
.busy
, this.info
)
750 if (this.type === PoolTypes
.dynamic
&& this.full
) {
751 this.emitter
?.emit(PoolEvents
.full
, this.info
)
757 * Sets the given worker node its tasks usage in the pool.
759 * @param workerNode - The worker node.
760 * @param workerUsage - The worker usage.
762 private setWorkerNodeTasksUsage (
763 workerNode
: WorkerNode
<Worker
, Data
>,
764 workerUsage
: WorkerUsage
766 workerNode
.workerUsage
= workerUsage
770 * Pushes the given worker in the pool worker nodes.
772 * @param worker - The worker.
773 * @returns The worker nodes length.
775 private pushWorkerNode (worker
: Worker
): number {
776 return this.workerNodes
.push({
778 workerUsage
: this.getWorkerUsage(worker
),
779 tasksQueue
: new Queue
<Task
<Data
>>()
784 // * Sets the given worker in the pool worker nodes.
786 // * @param workerNodeKey - The worker node key.
787 // * @param worker - The worker.
788 // * @param workerUsage - The worker usage.
789 // * @param tasksQueue - The worker task queue.
791 // private setWorkerNode (
792 // workerNodeKey: number,
794 // workerUsage: WorkerUsage,
795 // tasksQueue: Queue<Task<Data>>
797 // this.workerNodes[workerNodeKey] = {
805 * Removes the given worker from the pool worker nodes.
807 * @param worker - The worker.
809 private removeWorkerNode (worker
: Worker
): void {
810 const workerNodeKey
= this.getWorkerNodeKey(worker
)
811 if (workerNodeKey
!== -1) {
812 this.workerNodes
.splice(workerNodeKey
, 1)
813 this.workerChoiceStrategyContext
.remove(workerNodeKey
)
817 private executeTask (workerNodeKey
: number, task
: Task
<Data
>): void {
818 this.beforeTaskExecutionHook(workerNodeKey
, task
)
819 this.sendToWorker(this.workerNodes
[workerNodeKey
].worker
, task
)
822 private enqueueTask (workerNodeKey
: number, task
: Task
<Data
>): number {
823 return this.workerNodes
[workerNodeKey
].tasksQueue
.enqueue(task
)
826 private dequeueTask (workerNodeKey
: number): Task
<Data
> | undefined {
827 return this.workerNodes
[workerNodeKey
].tasksQueue
.dequeue()
830 private tasksQueueSize (workerNodeKey
: number): number {
831 return this.workerNodes
[workerNodeKey
].tasksQueue
.size
834 private flushTasksQueue (workerNodeKey
: number): void {
835 if (this.tasksQueueSize(workerNodeKey
) > 0) {
836 for (let i
= 0; i
< this.tasksQueueSize(workerNodeKey
); i
++) {
839 this.dequeueTask(workerNodeKey
) as Task
<Data
>
845 private flushTasksQueues (): void {
846 for (const [workerNodeKey
] of this.workerNodes
.entries()) {
847 this.flushTasksQueue(workerNodeKey
)
851 private setWorkerStatistics (worker
: Worker
): void {
852 this.sendToWorker(worker
, {
855 this.workerChoiceStrategyContext
.getTaskStatisticsRequirements()
857 elu
: this.workerChoiceStrategyContext
.getTaskStatisticsRequirements()
863 private getWorkerUsage (worker
: Worker
): WorkerUsage
{
865 tasks
: this.getTaskStatistics(worker
),
870 history
: new CircularArray()
876 history
: new CircularArray()
883 history
: new CircularArray()
889 history
: new CircularArray()
896 private getTaskStatistics (worker
: Worker
): TaskStatistics
{
898 this.workerNodes
[this.getWorkerNodeKey(worker
)]?.tasksQueue
?.size
902 get
queued (): number {
903 return queueSize
?? 0