build(deps): apply updates
[poolifier.git] / src / pools / worker-node.ts
index 57628bf72c74c28d18764e8d6fed067f687e6e71..de65f27012634c493d697a0ae9e3972a7f5234db 100644 (file)
@@ -1,16 +1,26 @@
 import { MessageChannel } from 'node:worker_threads'
 import { CircularArray } from '../circular-array'
-import { Queue } from '../queue'
 import type { Task } from '../utility-types'
-import { DEFAULT_TASK_NAME } from '../utils'
+import {
+  DEFAULT_TASK_NAME,
+  EMPTY_FUNCTION,
+  exponentialDelay,
+  getWorkerId,
+  getWorkerType,
+  sleep
+} from '../utils'
+import { Deque } from '../deque'
 import {
   type IWorker,
   type IWorkerNode,
+  type StrategyData,
   type WorkerInfo,
+  type WorkerNodeEventDetail,
   type WorkerType,
   WorkerTypes,
   type WorkerUsage
 } from './worker'
+import { checkWorkerNodeArguments } from './utils'
 
 /**
  * Worker node.
@@ -19,54 +29,45 @@ import {
  * @typeParam Data - Type of data sent to the worker. This can only be structured-cloneable data.
  */
 export class WorkerNode<Worker extends IWorker, Data = unknown>
-implements IWorkerNode<Worker, Data> {
+  extends EventTarget
+  implements IWorkerNode<Worker, Data> {
   /** @inheritdoc */
   public readonly worker: Worker
   /** @inheritdoc */
   public readonly info: WorkerInfo
   /** @inheritdoc */
+  public usage: WorkerUsage
+  /** @inheritdoc */
+  public strategyData?: StrategyData
+  /** @inheritdoc */
   public messageChannel?: MessageChannel
   /** @inheritdoc */
-  public usage: WorkerUsage
+  public tasksQueueBackPressureSize: number
+  private readonly tasksQueue: Deque<Task<Data>>
+  private onBackPressureStarted: boolean
+  private onEmptyQueueCount: number
   private readonly taskFunctionsUsage: Map<string, WorkerUsage>
-  private readonly tasksQueue: Queue<Task<Data>>
-  private readonly tasksQueueBackPressureSize: number
 
   /**
    * Constructs a new worker node.
    *
    * @param worker - The worker.
-   * @param workerType - The worker type.
-   * @param poolMaxSize - The pool maximum size.
+   * @param tasksQueueBackPressureSize - The tasks queue back pressure size.
    */
-  constructor (worker: Worker, workerType: WorkerType, poolMaxSize: number) {
-    if (worker == null) {
-      throw new TypeError('Cannot construct a worker node without a worker')
-    }
-    if (workerType == null) {
-      throw new TypeError(
-        'Cannot construct a worker node without a worker type'
-      )
-    }
-    if (poolMaxSize == null) {
-      throw new TypeError(
-        'Cannot construct a worker node without a pool maximum size'
-      )
-    }
-    if (isNaN(poolMaxSize)) {
-      throw new TypeError(
-        'Cannot construct a worker node with a NaN pool maximum size'
-      )
-    }
+  constructor (worker: Worker, tasksQueueBackPressureSize: number) {
+    super()
+    checkWorkerNodeArguments<Worker>(worker, tasksQueueBackPressureSize)
     this.worker = worker
-    this.info = this.initWorkerInfo(worker, workerType)
-    if (workerType === WorkerTypes.thread) {
+    this.info = this.initWorkerInfo(worker)
+    this.usage = this.initWorkerUsage()
+    if (this.info.type === WorkerTypes.thread) {
       this.messageChannel = new MessageChannel()
     }
-    this.usage = this.initWorkerUsage()
+    this.tasksQueueBackPressureSize = tasksQueueBackPressureSize
+    this.tasksQueue = new Deque<Task<Data>>()
+    this.onBackPressureStarted = false
+    this.onEmptyQueueCount = 0
     this.taskFunctionsUsage = new Map<string, WorkerUsage>()
-    this.tasksQueue = new Queue<Task<Data>>()
-    this.tasksQueueBackPressureSize = Math.pow(poolMaxSize, 2)
   }
 
   /** @inheritdoc */
@@ -74,23 +75,52 @@ implements IWorkerNode<Worker, Data> {
     return this.tasksQueue.size
   }
 
-  /**
-   * Tasks queue maximum size.
-   *
-   * @returns The tasks queue maximum size.
-   */
-  private tasksQueueMaxSize (): number {
-    return this.tasksQueue.maxSize
+  /** @inheritdoc */
+  public enqueueTask (task: Task<Data>): number {
+    const tasksQueueSize = this.tasksQueue.push(task)
+    if (this.hasBackPressure() && !this.onBackPressureStarted) {
+      this.onBackPressureStarted = true
+      this.dispatchEvent(
+        new CustomEvent<WorkerNodeEventDetail>('backpressure', {
+          detail: { workerId: this.info.id as number }
+        })
+      )
+      this.onBackPressureStarted = false
+    }
+    return tasksQueueSize
   }
 
   /** @inheritdoc */
-  public enqueueTask (task: Task<Data>): number {
-    return this.tasksQueue.enqueue(task)
+  public unshiftTask (task: Task<Data>): number {
+    const tasksQueueSize = this.tasksQueue.unshift(task)
+    if (this.hasBackPressure() && !this.onBackPressureStarted) {
+      this.onBackPressureStarted = true
+      this.dispatchEvent(
+        new CustomEvent<WorkerNodeEventDetail>('backpressure', {
+          detail: { workerId: this.info.id as number }
+        })
+      )
+      this.onBackPressureStarted = false
+    }
+    return tasksQueueSize
   }
 
   /** @inheritdoc */
   public dequeueTask (): Task<Data> | undefined {
-    return this.tasksQueue.dequeue()
+    const task = this.tasksQueue.shift()
+    if (this.tasksQueue.size === 0 && this.onEmptyQueueCount === 0) {
+      this.startOnEmptyQueue().catch(EMPTY_FUNCTION)
+    }
+    return task
+  }
+
+  /** @inheritdoc */
+  public popTask (): Task<Data> | undefined {
+    const task = this.tasksQueue.pop()
+    if (this.tasksQueue.size === 0 && this.onEmptyQueueCount === 0) {
+      this.startOnEmptyQueue().catch(EMPTY_FUNCTION)
+    }
+    return task
   }
 
   /** @inheritdoc */
@@ -112,31 +142,31 @@ implements IWorkerNode<Worker, Data> {
   /** @inheritdoc */
   public closeChannel (): void {
     if (this.messageChannel != null) {
-      this.messageChannel?.port1.unref()
-      this.messageChannel?.port2.unref()
-      this.messageChannel?.port1.close()
-      this.messageChannel?.port2.close()
+      this.messageChannel.port1.unref()
+      this.messageChannel.port2.unref()
+      this.messageChannel.port1.close()
+      this.messageChannel.port2.close()
       delete this.messageChannel
     }
   }
 
   /** @inheritdoc */
   public getTaskFunctionWorkerUsage (name: string): WorkerUsage | undefined {
-    if (!Array.isArray(this.info.taskFunctions)) {
+    if (!Array.isArray(this.info.taskFunctionNames)) {
       throw new Error(
         `Cannot get task function worker usage for task function name '${name}' when task function names list is not yet defined`
       )
     }
     if (
-      Array.isArray(this.info.taskFunctions) &&
-      this.info.taskFunctions.length < 3
+      Array.isArray(this.info.taskFunctionNames) &&
+      this.info.taskFunctionNames.length < 3
     ) {
       throw new Error(
         `Cannot get task function worker usage for task function name '${name}' when task function names list has less than 3 elements`
       )
     }
     if (name === DEFAULT_TASK_NAME) {
-      name = this.info.taskFunctions[1]
+      name = this.info.taskFunctionNames[1]
     }
     if (!this.taskFunctionsUsage.has(name)) {
       this.taskFunctionsUsage.set(name, this.initTaskFunctionWorkerUsage(name))
@@ -144,10 +174,33 @@ implements IWorkerNode<Worker, Data> {
     return this.taskFunctionsUsage.get(name)
   }
 
-  private initWorkerInfo (worker: Worker, workerType: WorkerType): WorkerInfo {
+  /** @inheritdoc */
+  public deleteTaskFunctionWorkerUsage (name: string): boolean {
+    return this.taskFunctionsUsage.delete(name)
+  }
+
+  private async startOnEmptyQueue (): Promise<void> {
+    if (
+      this.onEmptyQueueCount > 0 &&
+      (this.usage.tasks.executing > 0 || this.tasksQueue.size > 0)
+    ) {
+      this.onEmptyQueueCount = 0
+      return
+    }
+    ++this.onEmptyQueueCount
+    this.dispatchEvent(
+      new CustomEvent<WorkerNodeEventDetail>('emptyqueue', {
+        detail: { workerId: this.info.id as number }
+      })
+    )
+    await sleep(exponentialDelay(this.onEmptyQueueCount))
+    await this.startOnEmptyQueue()
+  }
+
+  private initWorkerInfo (worker: Worker): WorkerInfo {
     return {
-      id: this.getWorkerId(worker, workerType),
-      type: workerType,
+      id: getWorkerId(worker),
+      type: getWorkerType(worker) as WorkerType,
       dynamic: false,
       ready: false
     }
@@ -155,10 +208,10 @@ implements IWorkerNode<Worker, Data> {
 
   private initWorkerUsage (): WorkerUsage {
     const getTasksQueueSize = (): number => {
-      return this.tasksQueueSize()
+      return this.tasksQueue.size
     }
     const getTasksQueueMaxSize = (): number => {
-      return this.tasksQueueMaxSize()
+      return this.tasksQueue.maxSize
     }
     return {
       tasks: {
@@ -170,76 +223,64 @@ implements IWorkerNode<Worker, Data> {
         get maxQueued (): number {
           return getTasksQueueMaxSize()
         },
+        stolen: 0,
         failed: 0
       },
       runTime: {
-        history: new CircularArray()
+        history: new CircularArray<number>()
       },
       waitTime: {
-        history: new CircularArray()
+        history: new CircularArray<number>()
       },
       elu: {
         idle: {
-          history: new CircularArray()
+          history: new CircularArray<number>()
         },
         active: {
-          history: new CircularArray()
+          history: new CircularArray<number>()
         }
       }
     }
   }
 
   private initTaskFunctionWorkerUsage (name: string): WorkerUsage {
-    const getTaskQueueSize = (): number => {
-      let taskQueueSize = 0
+    const getTaskFunctionQueueSize = (): number => {
+      let taskFunctionQueueSize = 0
       for (const task of this.tasksQueue) {
-        if (task.name === name) {
-          ++taskQueueSize
+        if (
+          (task.name === DEFAULT_TASK_NAME &&
+            name === (this.info.taskFunctionNames as string[])[1]) ||
+          (task.name !== DEFAULT_TASK_NAME && name === task.name)
+        ) {
+          ++taskFunctionQueueSize
         }
       }
-      return taskQueueSize
+      return taskFunctionQueueSize
     }
     return {
       tasks: {
         executed: 0,
         executing: 0,
         get queued (): number {
-          return getTaskQueueSize()
+          return getTaskFunctionQueueSize()
         },
+        stolen: 0,
         failed: 0
       },
       runTime: {
-        history: new CircularArray()
+        history: new CircularArray<number>()
       },
       waitTime: {
-        history: new CircularArray()
+        history: new CircularArray<number>()
       },
       elu: {
         idle: {
-          history: new CircularArray()
+          history: new CircularArray<number>()
         },
         active: {
-          history: new CircularArray()
+          history: new CircularArray<number>()
         }
       }
     }
   }
-
-  /**
-   * Gets the worker id.
-   *
-   * @param worker - The worker.
-   * @param workerType - The worker type.
-   * @returns The worker id.
-   */
-  private getWorkerId (
-    worker: Worker,
-    workerType: WorkerType
-  ): number | undefined {
-    if (workerType === WorkerTypes.thread) {
-      return worker.threadId
-    } else if (workerType === WorkerTypes.cluster) {
-      return worker.id
-    }
-  }
 }