From 2df15a0d89df1923f70a68f9ebb94f77dcf2a5bb Mon Sep 17 00:00:00 2001 From: manast Date: Mon, 2 Sep 2024 09:07:13 +0000 Subject: [PATCH] deploy: c9373ddf8aa238e111e979e315323da7a79c19ad --- classes/v5.AsyncFifoQueue.html | 4 +- classes/v5.Backoffs.html | 4 +- classes/v5.ChildPool.html | 4 +- classes/v5.ChildProcessor.html | 4 +- classes/v5.DelayedError.html | 4 +- classes/v5.FlowProducer.html | 16 +-- classes/v5.Job.html | 120 +++++++++---------- classes/v5.Queue.html | 118 +++++++++--------- classes/v5.QueueBase.html | 18 +-- classes/v5.QueueEvents.html | 20 ++-- classes/v5.QueueGetters.html | 72 +++++------ classes/v5.QueueKeys.html | 4 +- classes/v5.RateLimitError.html | 4 +- classes/v5.RedisConnection.html | 6 +- classes/v5.Repeat.html | 18 +-- classes/v5.Scripts.html | 16 +-- classes/v5.UnrecoverableError.html | 4 +- classes/v5.WaitingChildrenError.html | 4 +- classes/v5.Worker.html | 36 +++--- enums/v5.ChildCommand.html | 4 +- enums/v5.ClientType.html | 4 +- enums/v5.ErrorCode.html | 4 +- enums/v5.MetricsTime.html | 4 +- enums/v5.ParentCommand.html | 4 +- functions/v5.array2obj.html | 2 +- functions/v5.asyncSend.html | 2 +- functions/v5.childSend.html | 2 +- functions/v5.decreaseMaxListeners.html | 2 +- functions/v5.delay.html | 2 +- functions/v5.errorToJSON.html | 2 +- functions/v5.getNextMillis.html | 2 +- functions/v5.getParentKey.html | 2 +- functions/v5.increaseMaxListeners.html | 2 +- functions/v5.invertObject.html | 2 +- functions/v5.isEmpty.html | 2 +- functions/v5.isNotConnectionError.html | 2 +- functions/v5.isRedisCluster.html | 2 +- functions/v5.isRedisInstance.html | 2 +- functions/v5.isRedisVersionLowerThan.html | 2 +- functions/v5.lengthInUtf8Bytes.html | 2 +- functions/v5.parseObjectValues.html | 2 +- functions/v5.raw2NextJobData.html | 2 +- functions/v5.removeAllQueueData.html | 2 +- functions/v5.toString.html | 2 +- functions/v5.tryCatch.html | 2 +- interfaces/v5.AddChildrenOpts.html | 4 +- interfaces/v5.AddNodeOpts.html | 6 +- interfaces/v5.AdvancedOptions.html | 8 +- interfaces/v5.AdvancedRepeatOptions.html | 6 +- interfaces/v5.BackoffOptions.html | 6 +- interfaces/v5.BaseJobOptions.html | 34 +++--- interfaces/v5.BaseOptions.html | 4 +- interfaces/v5.BuiltInStrategies.html | 2 +- interfaces/v5.ChildMessage.html | 4 +- interfaces/v5.DebounceOptions.html | 6 +- interfaces/v5.DefaultJobOptions.html | 24 ++-- interfaces/v5.DependenciesOpts.html | 4 +- interfaces/v5.FlowJobBase.html | 4 +- interfaces/v5.FlowOpts.html | 4 +- interfaces/v5.FlowProducerListener.html | 6 +- interfaces/v5.GetNextJobOptions.html | 4 +- interfaces/v5.IConnection.html | 4 +- interfaces/v5.IoredisListener.html | 4 +- interfaces/v5.JobJson.html | 4 +- interfaces/v5.JobJsonRaw.html | 4 +- interfaces/v5.JobNode.html | 4 +- interfaces/v5.KeepJobs.html | 6 +- interfaces/v5.Metrics.html | 4 +- interfaces/v5.MetricsOptions.html | 4 +- interfaces/v5.MinimalJob.html | 46 +++---- interfaces/v5.MoveToDelayedOpts.html | 4 +- interfaces/v5.MoveToWaitingChildrenOpts.html | 4 +- interfaces/v5.NodeOpts.html | 12 +- interfaces/v5.ObliterateOpts.html | 6 +- interfaces/v5.Parent.html | 4 +- interfaces/v5.ParentKeys.html | 4 +- interfaces/v5.ParentMessage.html | 4 +- interfaces/v5.QueueBaseOptions.html | 10 +- interfaces/v5.QueueEventsListener.html | 40 +++---- interfaces/v5.QueueEventsOptions.html | 16 +-- interfaces/v5.QueueListener.html | 18 +-- interfaces/v5.QueueOptions.html | 12 +- interfaces/v5.RateLimiterOptions.html | 6 +- interfaces/v5.RawCommand.html | 4 +- interfaces/v5.RepeatBaseOptions.html | 10 +- interfaces/v5.RepeatOptions.html | 14 +-- interfaces/v5.SandboxedJob.html | 4 +- interfaces/v5.WorkerListener.html | 28 ++--- interfaces/v5.WorkerOptions.html | 44 +++---- types/v5.BackoffStrategy.html | 2 +- types/v5.BulkJobOptions.html | 2 +- types/v5.ClusterOptions.html | 2 +- types/v5.ConnectionOptions.html | 2 +- types/v5.EntryId.html | 2 +- types/v5.EntryRaw.html | 2 +- types/v5.FinishedPropValAttribute.html | 2 +- types/v5.FinishedStatus.html | 2 +- types/v5.FlowChildJob.html | 2 +- types/v5.FlowJob.html | 2 +- types/v5.FlowQueuesOpts.html | 2 +- types/v5.JobData.html | 2 +- types/v5.JobJsonSandbox.html | 2 +- types/v5.JobState.html | 2 +- types/v5.JobType.html | 2 +- types/v5.JobsOptions.html | 2 +- types/v5.KeysMap.html | 2 +- types/v5.MinimalQueue.html | 2 +- types/v5.ParentOpts.html | 2 +- types/v5.Processor.html | 2 +- types/v5.RedisClient.html | 2 +- types/v5.RedisJobOptions.html | 2 +- types/v5.RedisOptions.html | 2 +- types/v5.RepeatStrategy.html | 2 +- types/v5.RepeatableJob.html | 2 +- types/v5.RepeatableOptions.html | 2 +- types/v5.SandboxedJobProcessor.html | 2 +- types/v5.StreamName.html | 2 +- types/v5.StreamReadRaw.html | 2 +- variables/v5.DELAY_TIME_1.html | 2 +- variables/v5.DELAY_TIME_5.html | 2 +- variables/v5.PRIORITY_LIMIT.html | 2 +- variables/v5.QUEUE_EVENT_SUFFIX.html | 2 +- variables/v5.RATE_LIMIT_ERROR.html | 2 +- variables/v5.clientCommandMessageReg.html | 2 +- variables/v5.errorObject.html | 2 +- 125 files changed, 530 insertions(+), 530 deletions(-) diff --git a/classes/v5.AsyncFifoQueue.html b/classes/v5.AsyncFifoQueue.html index 610a7d8eac..70a00a1cc5 100644 --- a/classes/v5.AsyncFifoQueue.html +++ b/classes/v5.AsyncFifoQueue.html @@ -1,11 +1,11 @@ AsyncFifoQueue | bullmq - v5.12.12

Class AsyncFifoQueue<T>

AsyncFifoQueue

A minimal FIFO queue for asynchronous operations. Allows adding asynchronous operations and consume them in the order they are resolved.

-

Type Parameters

  • T

Constructors

Type Parameters

  • T

Constructors

Methods

Generated using TypeDoc

\ No newline at end of file +

Constructors

Methods

Generated using TypeDoc

\ No newline at end of file diff --git a/classes/v5.Backoffs.html b/classes/v5.Backoffs.html index ba51e663c6..1337d32d93 100644 --- a/classes/v5.Backoffs.html +++ b/classes/v5.Backoffs.html @@ -1,5 +1,5 @@ -Backoffs | bullmq - v5.12.12

Class Backoffs

Constructors

constructor +Backoffs | bullmq - v5.12.12

Class Backoffs

Constructors

Properties

Methods

Constructors

Properties

builtinStrategies: BuiltInStrategies = ...

Methods

Generated using TypeDoc

\ No newline at end of file +

Constructors

Properties

builtinStrategies: BuiltInStrategies = ...

Methods

Generated using TypeDoc

\ No newline at end of file diff --git a/classes/v5.ChildPool.html b/classes/v5.ChildPool.html index 97b70a420e..8fc493a17e 100644 --- a/classes/v5.ChildPool.html +++ b/classes/v5.ChildPool.html @@ -1,4 +1,4 @@ -ChildPool | bullmq - v5.12.12

Class ChildPool

Constructors

constructor +ChildPool | bullmq - v5.12.12

Class ChildPool

Constructors

Properties

Methods

clean @@ -8,4 +8,4 @@ release remove retain -

Constructors

Properties

free: {
    [key: string]: Child[];
} = {}

Type declaration

  • [key: string]: Child[]
retained: {
    [key: number]: Child;
} = {}

Type declaration

  • [key: number]: Child

Methods

  • Parameters

    • child: Child
    • signal: "SIGKILL" | "SIGTERM" = 'SIGKILL'

    Returns Promise<void>

  • Parameters

    • processFile: string

    Returns Promise<Child>

Generated using TypeDoc

\ No newline at end of file +

Constructors

Properties

free: {
    [key: string]: Child[];
} = {}

Type declaration

  • [key: string]: Child[]
retained: {
    [key: number]: Child;
} = {}

Type declaration

  • [key: number]: Child

Methods

  • Parameters

    • child: Child
    • signal: "SIGKILL" | "SIGTERM" = 'SIGKILL'

    Returns Promise<void>

  • Parameters

    • processFile: string

    Returns Promise<Child>

Generated using TypeDoc

\ No newline at end of file diff --git a/classes/v5.ChildProcessor.html b/classes/v5.ChildProcessor.html index df930b18ed..e2c0163741 100644 --- a/classes/v5.ChildProcessor.html +++ b/classes/v5.ChildProcessor.html @@ -1,7 +1,7 @@ ChildProcessor | bullmq - v5.12.12

Class ChildProcessor

ChildProcessor

This class acts as the interface between a child process and it parent process so that jobs can be processed in different processes.

-

Constructors

Constructors

Properties

currentJobPromise: Promise<unknown>
processor: any
status?: ChildStatus

Methods

Generated using TypeDoc

\ No newline at end of file +

Constructors

Properties

currentJobPromise: Promise<unknown>
processor: any
status?: ChildStatus

Methods

Generated using TypeDoc

\ No newline at end of file diff --git a/classes/v5.DelayedError.html b/classes/v5.DelayedError.html index e153cd88b7..348987518f 100644 --- a/classes/v5.DelayedError.html +++ b/classes/v5.DelayedError.html @@ -1,5 +1,5 @@ DelayedError | bullmq - v5.12.12

Class DelayedError

DelayedError

Error to be thrown when job is moved to delayed state from job in active state.

-

Hierarchy

  • Error
    • DelayedError

Constructors

Constructors

Generated using TypeDoc

\ No newline at end of file +

Hierarchy

Constructors

Constructors

Generated using TypeDoc

\ No newline at end of file diff --git a/classes/v5.FlowProducer.html b/classes/v5.FlowProducer.html index 75b6a85067..781a77c843 100644 --- a/classes/v5.FlowProducer.html +++ b/classes/v5.FlowProducer.html @@ -4,7 +4,7 @@ Whenever the children of a given parent are completed, the parent will be processed, being able to access the children's result data. All Jobs can be in different queues, either children or parents,

-

Hierarchy

Constructors

Hierarchy

  • EventEmitter
    • FlowProducer

Constructors

Properties

closing keys opts @@ -21,14 +21,14 @@ on once waitUntilReady -

Constructors

Properties

closing: Promise<void>
keys: KeysMap
opts: QueueBaseOptions = ...
queueKeys: QueueKeys
toKey: ((name, type) => string)

Type declaration

    • (name, type): string
    • Parameters

      • name: string
      • type: string

      Returns string

Accessors

Methods

  • Adds a flow.

    +

Constructors

Properties

closing: Promise<void>
keys: KeysMap
opts: QueueBaseOptions = ...
queueKeys: QueueKeys
toKey: ((name, type) => string)

Type declaration

    • (name, type): string
    • Parameters

      • name: string
      • type: string

      Returns string

Accessors

Methods

  • Adds a flow.

    This call would be atomic, either it fails and no jobs will be added to the queues, or it succeeds and all jobs will be added.

    Parameters

    • flow: FlowJob

      an object with a tree-like structure where children jobs will be processed before their parents.

    • Optional opts: FlowOpts

      options that will be applied to the flow object.

      -

    Returns Promise<JobNode>

  • Adds multiple flows.

    +

Returns Promise<JobNode>

  • Adds multiple flows.

    A flow is a tree-like structure of jobs that depend on each other. Whenever the children of a given parent are completed, the parent will be processed, being able to access the children's result data.

    @@ -37,8 +37,8 @@ be added to the queues, or it succeeds and all jobs will be added.

    Parameters

    • flows: FlowJob[]

      an array of objects with a tree-like structure where children jobs will be processed before their parents.

      -

    Returns Promise<JobNode[]>

  • Closes the connection and returns a promise that resolves when the connection is closed.

    -

    Returns Promise<void>

  • Get a flow.

    +

Returns Promise<JobNode[]>

  • Closes the connection and returns a promise that resolves when the connection is closed.

    +

    Returns Promise<void>

Generated using TypeDoc

\ No newline at end of file +

Returns Promise<JobNode>

Generated using TypeDoc

\ No newline at end of file diff --git a/classes/v5.Job.html b/classes/v5.Job.html index 83e1d2e1f8..c3036be8e8 100644 --- a/classes/v5.Job.html +++ b/classes/v5.Job.html @@ -3,7 +3,7 @@ you add a job to the queue with methods such as Queue.addJob( ... )

A Job instance is also passed to the Worker's process function.

Job

-

Type Parameters

Implements

Constructors

Type Parameters

  • DataType = any
  • ReturnType = any
  • NameType extends string = string

Implements

Constructors

Properties

attemptsMade attemptsStarted data @@ -67,137 +67,137 @@

Constructors

Properties

attemptsMade: number = 0

Number of attempts after the job has failed.

+
  • Optional id: string
  • Returns Job<DataType, ReturnType, NameType>

    Properties

    attemptsMade: number = 0

    Number of attempts after the job has failed.

    Default Value

    0
     
    -
    attemptsStarted: number = 0

    Number of attempts when job is moved to active.

    +
    attemptsStarted: number = 0

    Number of attempts when job is moved to active.

    Default Value

    0
     
    -
    data: DataType

    The payload for this job.

    -
    debounceId?: string

    Debounce identifier.

    -
    delay: number

    An amount of milliseconds to wait until this job can be processed.

    +
    data: DataType

    The payload for this job.

    +
    debounceId?: string

    Debounce identifier.

    +
    delay: number

    An amount of milliseconds to wait until this job can be processed.

    Default Value

    0
     
    -
    failedReason: string

    Reason for failing.

    -
    finishedOn?: number

    Timestamp for when the job finished (completed or failed).

    -
    id?: string
    name: NameType

    The name of the Job

    -
    opts: JobsOptions = {}

    The options object for this job.

    -
    parent?: ParentKeys

    Object that contains parentId (id) and parent queueKey.

    -
    parentKey?: string

    Fully qualified key (including the queue prefix) pointing to the parent of this job.

    -
    processedBy?: string

    The worker name that is processing or processed this job.

    -
    processedOn?: number

    Timestamp for when the job was processed.

    -
    progress: number | object = 0

    The progress a job has performed so far.

    +
    failedReason: string

    Reason for failing.

    +
    finishedOn?: number

    Timestamp for when the job finished (completed or failed).

    +
    id?: string
    name: NameType

    The name of the Job

    +
    opts: JobsOptions = {}

    The options object for this job.

    +
    parent?: ParentKeys

    Object that contains parentId (id) and parent queueKey.

    +
    parentKey?: string

    Fully qualified key (including the queue prefix) pointing to the parent of this job.

    +
    processedBy?: string

    The worker name that is processing or processed this job.

    +
    processedOn?: number

    Timestamp for when the job was processed.

    +
    progress: number | object = 0

    The progress a job has performed so far.

    Default Value

    0
     
    -
    queueQualifiedName: string

    It includes the prefix, the namespace separator :, and queue name.

    +
    queueQualifiedName: string

    It includes the prefix, the namespace separator :, and queue name.

    repeatJobKey?: string

    Base repeat job key.

    -
    returnvalue: ReturnType = null

    The value returned by the processor when processing this job.

    +
    repeatJobKey?: string

    Base repeat job key.

    +
    returnvalue: ReturnType = null

    The value returned by the processor when processing this job.

    Default Value

    null
     
    -
    stacktrace: string[] = null

    Stacktrace for the error (for failed jobs).

    +
    stacktrace: string[] = null

    Stacktrace for the error (for failed jobs).

    Default Value

    null
     
    -
    timestamp: number

    Timestamp when the job was created (unless overridden with job options).

    -
    token?: string

    The token used for locking this job.

    -

    Accessors

    • get prefix(): string
    • Returns string

      the prefix that is used.

      -
    • get queueName(): string
    • Returns string

      the queue name this job belongs to.

      -

    Methods

    timestamp: number

    Timestamp when the job was created (unless overridden with job options).

    +
    token?: string

    The token used for locking this job.

    +

    Accessors

    • get prefix(): string
    • Returns string

      the prefix that is used.

      +
    • get queueName(): string
    • Returns string

      the queue name this job belongs to.

      +

    Methods

    • Change delay of a delayed job.

      Parameters

      • delay: number

        milliseconds to be added to current time.

      Returns Promise<void>

      void

      -
    • Change job priority.

      Parameters

      • opts: {
            lifo?: boolean;
            priority?: number;
        }
        • Optional lifo?: boolean
        • Optional priority?: number

      Returns Promise<void>

      void

      -
    • Clears job's logs

      Parameters

      • Optional keepLogs: number

        the amount of log entries to preserve

        -

      Returns Promise<void>

    • Marks a job to not be retried if it fails (even if attempts has been configured)

      -

      Returns void

    • Extend the lock for this job.

      +

    Returns Promise<void>

    • Marks a job to not be retried if it fails (even if attempts has been configured)

      +

      Returns void

    • Extend the lock for this job.

      Parameters

      • token: string

        unique token for the lock

      • duration: number

        lock duration in milliseconds

        -

      Returns Promise<number>

    • Get this jobs children result values if any.

      +

    Returns Promise<number>

    • Get this jobs children result values if any.

      Type Parameters

      • CT = any

      Returns Promise<{
          [jobKey: string]: CT;
      }>

      Object mapping children job keys with their values.

      -
    • Get children job keys if this job is a parent and has children.

      +
    • Get children job keys if this job is a parent and has children.

      Parameters

      Returns Promise<{
          nextProcessedCursor?: number;
          nextUnprocessedCursor?: number;
          processed?: Record<string, any>;
          unprocessed?: string[];
      }>

      dependencies separated by processed and unprocessed.

      Remarks

      Count options before Redis v7.2 works as expected with any quantity of entries on processed/unprocessed dependencies, since v7.2 you must consider that count won't have any effect until processed/unprocessed dependencies have a length greater than 127

      See

      https://redis.io/docs/management/optimization/memory-optimization/#redis--72

      -
    • Get children job counts if this job is a parent and has children.

      +
    • Get children job counts if this job is a parent and has children.

      Parameters

      • opts: {
            processed?: boolean;
            unprocessed?: boolean;
        } = {}
        • Optional processed?: boolean
        • Optional unprocessed?: boolean

      Returns Promise<{
          processed?: number;
          unprocessed?: number;
      }>

      dependencies count separated by processed and unprocessed.

      -
    • Get this jobs children failure values if any.

      +
    • Get this jobs children failure values if any.

      Returns Promise<{
          [jobKey: string]: string;
      }>

      Object mapping children job keys with their failure values.

      -
    • Get current state.

      Returns Promise<"unknown" | JobState>

      Returns one of these values: 'completed', 'failed', 'delayed', 'active', 'waiting', 'waiting-children', 'unknown'.

      -
    • Returns Promise<boolean>

      true of the job is active.

      -
    • Returns Promise<boolean>

      true if the job has completed.

      -
    • Returns Promise<boolean>

      true if the job is delayed.

      -
    • Returns Promise<boolean>

      true if the job has failed.

      -
    • Returns Promise<boolean>

      true if the job is waiting.

      -
    • Returns Promise<boolean>

      true if the job is waiting for children.

      -
    • Returns Promise<boolean>

      true of the job is active.

      +
    • Returns Promise<boolean>

      true if the job has completed.

      +
    • Returns Promise<boolean>

      true if the job is delayed.

      +
    • Returns Promise<boolean>

      true if the job has failed.

      +
    • Returns Promise<boolean>

      true if the job is waiting.

      +
    • Returns Promise<boolean>

      true if the job is waiting for children.

      +
    • Logs one row of log data.

      Parameters

      • logRow: string

        string with log data to be logged.

      Returns Promise<number>

      The total number of log entries for this job so far.

      -
    • Moves a job to the completed queue. +

    • Moves a job to the completed queue. Returned job to be used with Queue.prototype.nextJobFromJobData.

      Parameters

      • returnValue: ReturnType

        The jobs success message.

      • token: string

        Worker token used to acquire completed job.

      • fetchNext: boolean = true

        True when wanting to fetch the next job.

      Returns Promise<void | any[]>

      Returns the jobData of the next job in the waiting queue or void.

      -
    • Moves the job to the delay set.

      +
    • Moves the job to the delay set.

      Parameters

      • timestamp: number

        timestamp where the job should be moved back to "wait"

      • Optional token: string

        token to check job is locked by current worker

        -

      Returns Promise<void>

    • Moves a job to the failed queue.

      +

    Returns Promise<void>

    • Moves a job to the failed queue.

      Type Parameters

      • E extends Error

      Parameters

      • err: E

        the jobs error message.

      • token: string

        token to check job is locked by current worker

      • fetchNext: boolean = false

        true when wanting to fetch the next job

      Returns Promise<void | any[]>

      Returns the jobData of the next job in the waiting queue or void.

      -
    • Moves the job to the waiting-children set.

      +
    • Moves the job to the waiting-children set.

      Parameters

      • token: string

        Token to check job is locked by current worker

      • opts: MoveToWaitingChildrenOpts = {}

        The options bag for moving a job to waiting-children.

      Returns Promise<boolean>

      true if the job was moved

      -
    • Promotes a delayed job so that it starts to be processed as soon as possible.

      -

      Returns Promise<void>

    • Completely remove the job from the queue. +

    • Promotes a delayed job so that it starts to be processed as soon as possible.

      +

      Returns Promise<void>

    • Completely remove the job from the queue. Note, this call will throw an exception if the job is being processed when the call is performed.

      Parameters

      • opts: {
            removeChildren: boolean;
        } = {}

        Options to remove a job

        -
        • removeChildren: boolean

      Returns Promise<void>

    • Removes child dependency from parent when child is not yet finished

      +
      • removeChildren: boolean

    Returns Promise<void>

    • Removes child dependency from parent when child is not yet finished

      Returns Promise<boolean>

      True if the relationship existed and if it was removed.

      -
    • Attempts to retry the job. Only a job that has failed or completed can be retried.

      +
    • Attempts to retry the job. Only a job that has failed or completed can be retried.

      Parameters

      Returns Promise<void>

      If resolved and return code is 1, then the queue emits a waiting event otherwise the operation was not a success and throw the corresponding error. If the promise rejects, it indicates that the script failed to execute

      -
    • Returns Omit<Job<DataType, ReturnType, NameType>, "remove" | "prefix" | "toJSON" | "scripts" | "changeDelay" | "changePriority" | "extendLock" | "getState" | "moveToDelayed" | "moveToWaitingChildren" | "promote" | "removeChildDependency" | "updateData" | "updateProgress" | "discard" | "addJob" | "queue" | "asJSON" | "asJSONSandbox" | "log" | "clearLogs" | "moveToCompleted" | "moveToFailed" | "isCompleted" | "isFailed" | "isDelayed" | "isWaitingChildren" | "isActive" | "isWaiting" | "queueName" | "getChildrenValues" | "getFailedChildrenValues" | "getDependencies" | "getDependenciesCount" | "waitUntilFinished" | "retry">

    • Returns Omit<Job<DataType, ReturnType, NameType>, "remove" | "prefix" | "toJSON" | "scripts" | "changeDelay" | "changePriority" | "extendLock" | "getState" | "moveToDelayed" | "moveToWaitingChildren" | "promote" | "removeChildDependency" | "updateData" | "updateProgress" | "discard" | "addJob" | "queue" | "asJSON" | "asJSONSandbox" | "log" | "clearLogs" | "moveToCompleted" | "moveToFailed" | "isCompleted" | "isFailed" | "isDelayed" | "isWaitingChildren" | "isActive" | "isWaiting" | "queueName" | "getChildrenValues" | "getFailedChildrenValues" | "getDependencies" | "getDependenciesCount" | "waitUntilFinished" | "retry">

    • Updates a job's progress

      +

    Returns Promise<void>

    • Updates a job's progress

      Parameters

      • progress: number | object

        number or object to be saved as progress.

        -

      Returns Promise<void>

    • Returns a promise the resolves when the job has completed (containing the return value of the job), +

    Returns Promise<void>

    • Returns a promise the resolves when the job has completed (containing the return value of the job), or rejects when the job has failed (containing the failedReason).

      Parameters

      • queueEvents: QueueEvents

        Instance of QueueEvents.

      • Optional ttl: number

        Time in milliseconds to wait for job to finish before timing out.

        -

      Returns Promise<ReturnType>

    • addJobLog

      +

    Returns Promise<ReturnType>

    • addJobLog

      Parameters

      • queue: MinimalQueue

        Queue instance

      • jobId: string

        Job id

      • logRow: string

        Log row

      • Optional keepLogs: number

        optional maximum number of logs to keep

      Returns Promise<number>

      The total number of log entries for this job so far.

      -
    • Creates a new job and adds it to the queue.

      +
    • Creates a new job and adds it to the queue.

      Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      • queue: MinimalQueue

        the queue where to add the job.

      • name: N

        the name of the job.

      • data: T

        the payload of the job.

      • Optional opts: JobsOptions

        the options bag for this job.

        -

      Returns Promise<Job<T, R, N>>

    • Creates a bulk of jobs and adds them atomically to the given queue.

      +

    Returns Promise<Job<T, R, N>>

    • Creates a bulk of jobs and adds them atomically to the given queue.

      Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      • queue: MinimalQueue

        the queue were to add the jobs.

      • jobs: {
            data: T;
            name: N;
            opts?: BulkJobOptions;
        }[]

        an array of jobs to be added to the queue.

        -

      Returns Promise<Job<T, R, N>[]>

    • Fetches a Job from the queue given the passed job id.

      +

    Returns Promise<Job<T, R, N>[]>

    • Fetches a Job from the queue given the passed job id.

      Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      • queue: MinimalQueue

        the queue where the job belongs to.

      • jobId: string

        the job id.

        -

      Returns Promise<Job<T, R, N>>

    • Instantiates a Job from a JobJsonRaw object (coming from a deserialized JSON object)

      +

    Returns Promise<Job<T, R, N>>

    • Instantiates a Job from a JobJsonRaw object (coming from a deserialized JSON object)

      Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      • queue: MinimalQueue

        the queue where the job belongs to.

      • json: JobJsonRaw

        the plain object containing the job.

      • Optional jobId: string

        an optional job id (overrides the id coming from the JSON object)

        -

      Returns Job<T, R, N>

    Generated using TypeDoc

    \ No newline at end of file +

    Returns Job<T, R, N>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.Queue.html b/classes/v5.Queue.html index d7513b5733..e362fdc44b 100644 --- a/classes/v5.Queue.html +++ b/classes/v5.Queue.html @@ -1,7 +1,7 @@ Queue | bullmq - v5.12.12

    Class Queue<DataType, ResultType, NameType>

    Queue

    This class provides methods to add jobs to a queue and some other high-level administration such as pausing or deleting queues.

    -

    Type Parameters

    • DataType = any
    • ResultType = any
    • NameType extends string = string

    Hierarchy (view full)

    Constructors

    Type Parameters

    • DataType = any
    • ResultType = any
    • NameType extends string = string

    Hierarchy (view full)

    Constructors

    Properties

    Constructors

    Properties

    closing: Promise<void>
    jobsOpts: BaseJobOptions
    keys: KeysMap
    name: string

    The name of the queue.

    -

    Options for the queue.

    -
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    token: string = ...

    Accessors

    • get metaValues(): Record<string, string | number>
    • Returns Record<string, string | number>

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      -

      Returns string

    Methods

    Constructors

    Properties

    closing: Promise<void>
    jobsOpts: BaseJobOptions
    keys: KeysMap
    name: string

    The name of the queue.

    +

    Options for the queue.

    +
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    token: string = ...

    Accessors

    • get metaValues(): Record<string, string | number>
    • Returns Record<string, string | number>

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      +

      Returns string

    Methods

    Returns Promise<Job<DataType, ResultType, NameType>>

    • Logs one row of job's log data.

      +

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<void>

    Returns boolean

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<{
        items: {
            err?: string;
            id: string;
            v?: any;
        }[];
        jobs: JobJsonRaw[];
        total: number;
    }>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<{
        count: number;
        logs: string[];
    }>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<Metrics>

    -

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<RepeatableJob[]>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<void>

    Returns Promise<number>

    Returns Promise<number>

    Generated using TypeDoc

    \ No newline at end of file +

    Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.QueueBase.html b/classes/v5.QueueBase.html index a97e7b4fa2..70e3fc3908 100644 --- a/classes/v5.QueueBase.html +++ b/classes/v5.QueueBase.html @@ -1,7 +1,7 @@ QueueBase | bullmq - v5.12.12

    Class QueueBase

    QueueBase

    Description

    Base class for all classes that need to interact with queues. This class is normally not used directly, but extended by the other classes.

    -

    Hierarchy (view full)

    Implements

    Constructors

    Hierarchy (view full)

    Implements

    Constructors

    Properties

    closing keys name @@ -18,12 +18,12 @@
  • opts: QueueBaseOptions = ...

    Options for the queue.

  • Connection: typeof RedisConnection = RedisConnection

    An optional "Connection" class used to instantiate a Connection. This is useful for testing with mockups and/or extending the Connection class and passing an alternate implementation.

    -
  • Returns QueueBase

    Properties

    closing: Promise<void>
    keys: KeysMap
    name: string

    The name of the queue.

    -
    opts: QueueBaseOptions = ...

    Options for the queue.

    -
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      -

      Returns string

    Methods

    • Closes the connection and returns a promise that resolves when the connection is closed.

      -

      Returns Promise<void>

    • Emits an event. Normally used by subclasses to emit events.

      +

    Returns QueueBase

    Properties

    closing: Promise<void>
    keys: KeysMap
    name: string

    The name of the queue.

    +
    opts: QueueBaseOptions = ...

    Options for the queue.

    +
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      +

      Returns string

    Methods

    • Closes the connection and returns a promise that resolves when the connection is closed.

      +

      Returns Promise<void>

    • Emits an event. Normally used by subclasses to emit events.

      Parameters

      • event: string | symbol

        The emitted event.

        -
      • Rest ...args: any[]

      Returns boolean

    Generated using TypeDoc

    \ No newline at end of file +
  • Rest ...args: any[]
  • Returns boolean

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.QueueEvents.html b/classes/v5.QueueEvents.html index ce165996a3..5cad83e14c 100644 --- a/classes/v5.QueueEvents.html +++ b/classes/v5.QueueEvents.html @@ -1,7 +1,7 @@ QueueEvents | bullmq - v5.12.12

    Class QueueEvents

    The QueueEvents class is used for listening to the global events emitted by a given queue.

    This class requires a dedicated redis connection.

    -

    Hierarchy (view full)

    Constructors

    Hierarchy (view full)

    Constructors

    Properties

    closing keys name @@ -18,14 +18,14 @@ once run waitUntilReady -

    Constructors

    Properties

    closing: Promise<void>
    keys: KeysMap
    name: string

    The name of the queue.

    -
    opts: QueueBaseOptions = ...

    Options for the queue.

    -
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      -

      Returns string

    Methods

    • Emits an event. Normally used by subclasses to emit events.

      +

    Constructors

    Properties

    closing: Promise<void>
    keys: KeysMap
    name: string

    The name of the queue.

    +
    opts: QueueBaseOptions = ...

    Options for the queue.

    +
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      +

      Returns string

    Methods

    • Manually starts running the event consumming loop. This shall be used if you do not +

    • Rest ...args: Parameters<QueueEventsListener[U]>

    Returns boolean

    • Manually starts running the event consumming loop. This shall be used if you do not use the default "autorun" option on the constructor.

      -

      Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file +

    Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.QueueGetters.html b/classes/v5.QueueGetters.html index 93fa74a87d..595f07fb33 100644 --- a/classes/v5.QueueGetters.html +++ b/classes/v5.QueueGetters.html @@ -1,6 +1,6 @@ QueueGetters | bullmq - v5.12.12

    Class QueueGetters<DataType, ResultType, NameType>

    QueueGetters

    Description

    Provides different getters for different aspects of a queue.

    -

    Type Parameters

    • DataType
    • ResultType
    • NameType extends string

    Hierarchy (view full)

    Constructors

    Type Parameters

    • DataType
    • ResultType
    • NameType extends string

    Hierarchy (view full)

    Constructors

    Properties

    closing keys name @@ -46,30 +46,30 @@
  • opts: QueueBaseOptions = ...

    Options for the queue.

  • Connection: typeof RedisConnection = RedisConnection

    An optional "Connection" class used to instantiate a Connection. This is useful for testing with mockups and/or extending the Connection class and passing an alternate implementation.

    -
  • Returns QueueGetters<DataType, ResultType, NameType>

    Properties

    closing: Promise<void>
    keys: KeysMap
    name: string

    The name of the queue.

    -
    opts: QueueBaseOptions = ...

    Options for the queue.

    -
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      -

      Returns string

    Methods

    • Closes the connection and returns a promise that resolves when the connection is closed.

      -

      Returns Promise<void>

    • Returns the number of jobs waiting to be processed. This includes jobs that are +

    Returns QueueGetters<DataType, ResultType, NameType>

    Properties

    closing: Promise<void>
    keys: KeysMap
    name: string

    The name of the queue.

    +
    opts: QueueBaseOptions = ...

    Options for the queue.

    +
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      +

      Returns string

    Methods

    • Closes the connection and returns a promise that resolves when the connection is closed.

      +

      Returns Promise<void>

    • Returns the number of jobs waiting to be processed. This includes jobs that are "waiting" or "delayed" or "prioritized" or "waiting-children".

      -

      Returns Promise<number>

    • Emits an event. Normally used by subclasses to emit events.

      +

      Returns Promise<number>

    • Emits an event. Normally used by subclasses to emit events.

      Parameters

      • event: string | symbol

        The emitted event.

        -
      • Rest ...args: any[]

      Returns boolean

    Returns boolean

    • Returns the number of jobs in active status.

      -

      Returns Promise<number>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<{
        items: {
            err?: string;
            id: string;
            v?: any;
        }[];
        jobs: JobJsonRaw[];
        total: number;
    }>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<{
        count: number;
        logs: string[];
    }>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<Metrics>

    -

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Returns Promise<Job<DataType, ResultType, NameType>[]>

    Generated using TypeDoc

    \ No newline at end of file +

    Returns Promise<number>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.QueueKeys.html b/classes/v5.QueueKeys.html index 1cf36c93e1..1a3500b126 100644 --- a/classes/v5.QueueKeys.html +++ b/classes/v5.QueueKeys.html @@ -1,6 +1,6 @@ -QueueKeys | bullmq - v5.12.12

    Class QueueKeys

    Constructors

    constructor +QueueKeys | bullmq - v5.12.12

    Class QueueKeys

    Constructors

    Properties

    Methods

    Constructors

    Properties

    prefix: string = 'bull'

    Methods

    Generated using TypeDoc

    \ No newline at end of file +

    Constructors

    Properties

    prefix: string = 'bull'

    Methods

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.RateLimitError.html b/classes/v5.RateLimitError.html index 4e13c39ad0..cdb9d51d0c 100644 --- a/classes/v5.RateLimitError.html +++ b/classes/v5.RateLimitError.html @@ -1,4 +1,4 @@ RateLimitError | bullmq - v5.12.12

    Class RateLimitError

    RateLimitError

    Error to be thrown when queue reaches a rate limit.

    -

    Hierarchy

    • Error
      • RateLimitError

    Constructors

    Constructors

    Generated using TypeDoc

    \ No newline at end of file +

    Hierarchy

    Constructors

    Constructors

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.RedisConnection.html b/classes/v5.RedisConnection.html index 6d20ed4ba5..34e8eaab47 100644 --- a/classes/v5.RedisConnection.html +++ b/classes/v5.RedisConnection.html @@ -1,4 +1,4 @@ -RedisConnection | bullmq - v5.12.12

    Class RedisConnection

    Hierarchy

    • EventEmitter
      • RedisConnection

    Constructors

    constructor +RedisConnection | bullmq - v5.12.12

    Class RedisConnection

    Hierarchy

    • EventEmitter
      • RedisConnection

    Constructors

    Properties

    Constructors

    Properties

    capabilities: RedisCapabilities = ...
    closing: boolean
    status: "closed" | "closing" | "ready" | "initializing" = 'initializing'
    minimumVersion: string = '5.0.0'
    recommendedMinimumVersion: string = '6.2.0'

    Accessors

    Methods

    Generated using TypeDoc

    \ No newline at end of file +

    Constructors

    Properties

    capabilities: RedisCapabilities = ...
    closing: boolean
    status: "closed" | "closing" | "ready" | "initializing" = 'initializing'
    minimumVersion: string = '5.0.0'
    recommendedMinimumVersion: string = '6.2.0'

    Accessors

    Methods

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.Repeat.html b/classes/v5.Repeat.html index 91a3243471..7141b85cca 100644 --- a/classes/v5.Repeat.html +++ b/classes/v5.Repeat.html @@ -1,7 +1,7 @@ Repeat | bullmq - v5.12.12

    Class Repeat

    QueueBase

    Description

    Base class for all classes that need to interact with queues. This class is normally not used directly, but extended by the other classes.

    -

    Hierarchy (view full)

    Constructors

    Hierarchy (view full)

    Constructors

    Properties

    closing: Promise<void>
    keys: KeysMap
    name: string

    The name of the queue.

    -
    opts: QueueBaseOptions = ...

    Options for the queue.

    -
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      -

      Returns string

    Methods

    • Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      Returns Promise<Job<T, R, N>>

    • Closes the connection and returns a promise that resolves when the connection is closed.

      -

      Returns Promise<void>

    • Emits an event. Normally used by subclasses to emit events.

      +

    Constructors

    Properties

    closing: Promise<void>
    keys: KeysMap
    name: string

    The name of the queue.

    +
    opts: QueueBaseOptions = ...

    Options for the queue.

    +
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      +

      Returns string

    Methods

    • Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      Returns Promise<Job<T, R, N>>

    • Closes the connection and returns a promise that resolves when the connection is closed.

      +

      Returns Promise<void>

    • Emits an event. Normally used by subclasses to emit events.

      Parameters

      • event: string | symbol

        The emitted event.

        -
      • Rest ...args: any[]

      Returns boolean

    • Type Parameters

      • T = any
      • N extends string = string

      Parameters

      • name: N
      • nextMillis: number
      • repeatJobKey: string
      • data: T

      Returns string

    • Parameters

      Returns Promise<number>

    • Parameters

      • repeatJobKey: string

      Returns Promise<number>

    Generated using TypeDoc

    \ No newline at end of file +
  • Rest ...args: any[]
  • Returns boolean

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.Scripts.html b/classes/v5.Scripts.html index 813742a8f1..c4124da03f 100644 --- a/classes/v5.Scripts.html +++ b/classes/v5.Scripts.html @@ -1,4 +1,4 @@ -Scripts | bullmq - v5.12.12

    Class Scripts

    Constructors

    constructor +Scripts | bullmq - v5.12.12

    Class Scripts

    Constructors

    Properties

    Methods

    Constructors

    Properties

    moveToFinishedKeys: string[]

    Methods

    • Parameters

      • jobId: string
      • logRow: string
      • Optional keepLogs: number

      Returns Promise<number>

    • Parameters

      • customKey: string
      • nextMillis: number
      • opts: RepeatableOptions
      • legacyCustomKey: string
      • skipCheckExists: boolean

      Returns Promise<string>

    • Parameters

      • jobId: string
      • delay: number

      Returns Promise<void>

    • Parameters

      • jobId: string
      • priority: number = 0
      • lifo: boolean = false

      Returns Promise<void>

    • Remove jobs in a specific state.

      +

    Constructors

    Properties

    moveToFinishedKeys: string[]

    Methods

    • Parameters

      • jobId: string
      • logRow: string
      • Optional keepLogs: number

      Returns Promise<number>

    • Parameters

      • customKey: string
      • nextMillis: number
      • opts: RepeatableOptions
      • legacyCustomKey: string
      • skipCheckExists: boolean

      Returns Promise<string>

    • Parameters

      • jobId: string
      • delay: number

      Returns Promise<void>

    • Parameters

      • jobId: string
      • priority: number = 0
      • lifo: boolean = false

      Returns Promise<void>

    • Remove jobs in a specific state.

      Parameters

      • set: string
      • timestamp: number
      • limit: number = 0

      Returns Promise<string[]>

      Id jobs from the deleted records.

      -
    • Parameters

      • jobId: string
      • token: string
      • duration: number
      • Optional client: ChainableCommander | RedisClient

      Returns Promise<number>

    • Parameters

      • __namedParameters: {
            code: number;
            command: string;
            jobId?: string;
            parentKey?: string;
            state?: string;
        }
        • code: number
        • command: string
        • Optional jobId?: string
        • Optional parentKey?: string
        • Optional state?: string

      Returns Error

    • Parameters

      • priorities: number[]

      Returns Promise<number[]>

    • Parameters

      • types: JobType[]
      • start: number = 0
      • end: number = 1
      • asc: boolean = false

      Returns Promise<[string][]>

    • Parameters

      • Optional maxJobs: number

      Returns Promise<number>

    • Parameters

      • Optional maxJobs: number

      Returns (string | number)[]

    • Parameters

      • repeatConcatOptions: string
      • repeatJobKey: string

      Returns string

    • Parameters

      • jobId: string
      • returnValue: boolean = false

      Returns Promise<number | [number, string]>

    • Parameters

      • listKey: string
      • jobId: string

      Returns Promise<boolean>

    • Moves a job back from Active to Wait. +

    • Parameters

      • jobId: string
      • token: string
      • duration: number
      • Optional client: ChainableCommander | RedisClient

      Returns Promise<number>

    • Parameters

      • __namedParameters: {
            code: number;
            command: string;
            jobId?: string;
            parentKey?: string;
            state?: string;
        }
        • code: number
        • command: string
        • Optional jobId?: string
        • Optional parentKey?: string
        • Optional state?: string

      Returns Error

    • Parameters

      • priorities: number[]

      Returns Promise<number[]>

    • Parameters

      • types: JobType[]
      • start: number = 0
      • end: number = 1
      • asc: boolean = false

      Returns Promise<[string][]>

    • Parameters

      • Optional maxJobs: number

      Returns Promise<number>

    • Parameters

      • Optional maxJobs: number

      Returns (string | number)[]

    • Parameters

      • repeatConcatOptions: string
      • repeatJobKey: string

      Returns string

    • Parameters

      • jobId: string
      • returnValue: boolean = false

      Returns Promise<number | [number, string]>

    • Parameters

      • listKey: string
      • jobId: string

      Returns Promise<boolean>

    • Moves a job back from Active to Wait. This script is used when a job has been manually rate limited and needs to be moved back to wait from active status.

      Parameters

      • jobId: string

        Job id

        -
      • token: string

      Returns Promise<any>

    • Looks for unlocked jobs in the active queue.

      +
    • token: string

    Returns Promise<any>

    • Looks for unlocked jobs in the active queue.

      The job was being worked on, but the worker process died and it failed to renew the lock. We call these jobs 'stalled'. This is the most common case. We resolve these by moving them back to wait to be re-processed. To prevent jobs from cycling endlessly between active and wait, (e.g. if the job handler keeps crashing), we limit the number stalled job recoveries to settings.maxStalledCount.

      -

      Returns Promise<[string[], string[]]>

    • Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      • job: MinimalJob<T, R, N>
      • returnvalue: R
      • removeOnComplete: number | boolean | KeepJobs
      • token: string
      • fetchNext: boolean = false

      Returns (string | number | boolean | Buffer)[]

    • Parameters

      • jobId: string
      • timestamp: number
      • delay: number
      • token: string = '0'
      • opts: MoveToDelayedOpts = {}

      Returns Promise<void>

    • Parameters

      Returns (string | number)[]

    • Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      • job: MinimalJob<T, R, N>
      • failedReason: string
      • removeOnFailed: number | boolean | KeepJobs
      • token: string
      • fetchNext: boolean = false

      Returns (string | number | boolean | Buffer)[]

    • Parameters

      • jobId: string
      • args: (string | number | boolean | Buffer)[]

      Returns Promise<any[]>

    • Move parent job to waiting-children state.

      +

      Returns Promise<[string[], string[]]>

    • Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      • job: MinimalJob<T, R, N>
      • returnvalue: R
      • removeOnComplete: number | boolean | KeepJobs
      • token: string
      • fetchNext: boolean = false

      Returns (string | number | boolean | Buffer)[]

    • Parameters

      • jobId: string
      • timestamp: number
      • delay: number
      • token: string = '0'
      • opts: MoveToDelayedOpts = {}

      Returns Promise<void>

    • Parameters

      Returns (string | number)[]

    • Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      • job: MinimalJob<T, R, N>
      • failedReason: string
      • removeOnFailed: number | boolean | KeepJobs
      • token: string
      • fetchNext: boolean = false

      Returns (string | number | boolean | Buffer)[]

    • Parameters

      • jobId: string
      • args: (string | number | boolean | Buffer)[]

      Returns Promise<any[]>

    • Move parent job to waiting-children state.

      Parameters

      Returns Promise<boolean>

      true if job is successfully moved, false if there are pending dependencies.

      Throws

      JobNotExist This exception is thrown if jobId is missing.

      @@ -64,8 +64,8 @@

      Throws

      JobLockNotExist This exception is thrown if job lock is missing.

      Throws

      JobNotInState This exception is thrown if job is not in active state.

      -
    • Parameters

      • opts: {
            count: number;
            force: boolean;
        }
        • count: number
        • force: boolean

      Returns Promise<number>

    • Paginate a set or hash keys.

      -

      Parameters

      • key: string
      • opts: {
            end: number;
            fetchJobs?: boolean;
            start: number;
        }
        • end: number
        • Optional fetchJobs?: boolean
        • start: number

      Returns Promise<{
          cursor: string;
          items: {
              err?: string;
              id: string;
              v?: any;
          }[];
          jobs?: JobJsonRaw[];
          total: number;
      }>

    • Parameters

      • count: number = 1000

      Returns Promise<number>

    • Parameters

      • jobId: string
      • removeChildren: boolean

      Returns Promise<number>

    • Parameters

      • jobId: string
      • parentKey: string

      Returns Promise<boolean>

    • Parameters

      • legacyRepeatJobId: string
      • repeatConcatOptions: string
      • repeatJobKey: string

      Returns Promise<number>

    • Parameters

      • opts: {
            count: number;
            force: boolean;
        }
        • count: number
        • force: boolean

      Returns Promise<number>

    • Paginate a set or hash keys.

      +

      Parameters

      • key: string
      • opts: {
            end: number;
            fetchJobs?: boolean;
            start: number;
        }
        • end: number
        • Optional fetchJobs?: boolean
        • start: number

      Returns Promise<{
          cursor: string;
          items: {
              err?: string;
              id: string;
              v?: any;
          }[];
          jobs?: JobJsonRaw[];
          total: number;
      }>

    • Parameters

      • count: number = 1000

      Returns Promise<number>

    • Parameters

      • jobId: string
      • removeChildren: boolean

      Returns Promise<number>

    • Parameters

      • jobId: string
      • parentKey: string

      Returns Promise<boolean>

    • Parameters

      • legacyRepeatJobId: string
      • repeatConcatOptions: string
      • repeatJobKey: string

      Returns Promise<number>

    • Attempts to reprocess a job

      Type Parameters

      • T = any
      • R = any
      • N extends string = string

      Parameters

      • job: MinimalJob<T, R, N>
      • state: "failed" | "completed"

        The expected job state. If the job is not found on the provided state, then it's not reprocessed. Supported states: 'failed', 'completed'

      Returns Promise<void>

      Returns a promise that evaluates to a return code: @@ -73,4 +73,4 @@

      Throws

      JobNotInState 0 means the job does not exist -1 means the job is currently locked and can't be retried. -2 means the job was not found in the expected set

      -
    • Parameters

      • jobId: string
      • lifo: boolean
      • token: string

      Returns (string | number)[]

    • Parameters

      • state: FinishedStatus = 'failed'
      • count: number = 1000
      • timestamp: number = ...

      Returns Promise<number>

    • Parameters

      • jobId: string
      • stacktrace: string
      • failedReason: string

      Returns string[]

    • Parameters

      • jobId: string
      • progress: number | object

      Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.UnrecoverableError.html b/classes/v5.UnrecoverableError.html index f9e79e7625..3946fb71ea 100644 --- a/classes/v5.UnrecoverableError.html +++ b/classes/v5.UnrecoverableError.html @@ -1,5 +1,5 @@ UnrecoverableError | bullmq - v5.12.12

    Class UnrecoverableError

    UnrecoverableError

    Error to move a job to failed even if the attemptsMade are lower than the expected limit.

    -

    Hierarchy

    • Error
      • UnrecoverableError

    Constructors

    Constructors

    Generated using TypeDoc

    \ No newline at end of file +

    Hierarchy

    Constructors

    Constructors

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.WaitingChildrenError.html b/classes/v5.WaitingChildrenError.html index fc3ad37039..637a3a7738 100644 --- a/classes/v5.WaitingChildrenError.html +++ b/classes/v5.WaitingChildrenError.html @@ -1,5 +1,5 @@ WaitingChildrenError | bullmq - v5.12.12

    Class WaitingChildrenError

    WaitingChildrenError

    Error to be thrown when job is moved to waiting-children state from job in active state.

    -

    Hierarchy

    • Error
      • WaitingChildrenError

    Constructors

    Constructors

    Generated using TypeDoc

    \ No newline at end of file +

    Hierarchy

    Constructors

    Constructors

    Generated using TypeDoc

    \ No newline at end of file diff --git a/classes/v5.Worker.html b/classes/v5.Worker.html index 17f91d9729..5501df3f73 100644 --- a/classes/v5.Worker.html +++ b/classes/v5.Worker.html @@ -1,7 +1,7 @@ Worker | bullmq - v5.12.12

    Class Worker<DataType, ResultType, NameType>

    This class represents a worker that is able to process jobs from the queue. As soon as the class is instantiated and a connection to Redis is established it will start processing jobs.

    -

    Type Parameters

    • DataType = any
    • ResultType = any
    • NameType extends string = string

    Hierarchy (view full)

    Constructors

    Type Parameters

    • DataType = any
    • ResultType = any
    • NameType extends string = string

    Hierarchy (view full)

    Constructors

    Properties

    Constructors

    Properties

    closing: Promise<void>
    id: string
    keys: KeysMap
    name: string

    The name of the queue.

    -

    Options for the queue.

    -
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • set concurrency(concurrency): void
    • Parameters

      • concurrency: number

      Returns void

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      -

      Returns string

    Methods

    • Closes the worker and related redis connections.

      +

    Constructors

    Properties

    closing: Promise<void>
    id: string
    keys: KeysMap
    name: string

    The name of the queue.

    +

    Options for the queue.

    +
    qualifiedName: string
    toKey: ((type) => string)

    Type declaration

      • (type): string
      • Parameters

        • type: string

        Returns string

    Accessors

    • set concurrency(concurrency): void
    • Parameters

      • concurrency: number

      Returns void

    • get redisVersion(): string
    • Returns the version of the Redis instance the client is connected to,

      +

      Returns string

    Methods

    • Closes the worker and related redis connections.

      This method waits for current jobs to finalize before returning.

      Parameters

      • force: boolean = false

        Use force boolean parameter if you do not want to wait for current jobs to be processed.

      Returns Promise<void>

      Promise that resolves when the worker has been closed.

      -
    • This function is exposed only for testing purposes.

      -

      Parameters

      • Optional milliseconds: number
      • Optional abortController: AbortController

      Returns Promise<void>

    • This function is exposed only for testing purposes.

      +

      Parameters

      • Optional milliseconds: number
      • Optional abortController: AbortController

      Returns Promise<void>

    Returns boolean

    • Checks if worker is paused.

      Returns boolean

      true if worker is paused, false otherwise.

      -
    • Checks if worker is currently running.

      Returns boolean

      true if worker is running, false otherwise.

      -
    • Pauses the processing of this queue only for this worker.

      -

      Parameters

      • Optional doNotWaitActive: boolean

      Returns Promise<void>

    • Overrides the rate limit to be active for the next jobs.

      +
    • Pauses the processing of this queue only for this worker.

      +

      Parameters

      • Optional doNotWaitActive: boolean

      Returns Promise<void>

    • Overrides the rate limit to be active for the next jobs.

      Parameters

      • expireTimeMs: number

        expire time in ms of this rate limit.

        -

      Returns Promise<void>

    • Resumes processing of this worker (if paused).

      -

      Returns void

    • Manually starts the stalled checker. +

    Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file +

    Returns Promise<RedisClient>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/enums/v5.ChildCommand.html b/enums/v5.ChildCommand.html index 263569993c..37ee8ea68a 100644 --- a/enums/v5.ChildCommand.html +++ b/enums/v5.ChildCommand.html @@ -1,4 +1,4 @@ -ChildCommand | bullmq - v5.12.12

    Enumeration ChildCommand

    Enumeration Members

    Init +ChildCommand | bullmq - v5.12.12

    Enumeration ChildCommand

    Enumeration Members

    Enumeration Members

    Init: 0
    Start: 1
    Stop: 2

    Generated using TypeDoc

    \ No newline at end of file +

    Enumeration Members

    Init: 0
    Start: 1
    Stop: 2

    Generated using TypeDoc

    \ No newline at end of file diff --git a/enums/v5.ClientType.html b/enums/v5.ClientType.html index 0f9b598d4f..a4d083370f 100644 --- a/enums/v5.ClientType.html +++ b/enums/v5.ClientType.html @@ -1,3 +1,3 @@ -ClientType | bullmq - v5.12.12

    Enumeration ClientType

    Enumeration Members

    blocking +ClientType | bullmq - v5.12.12

    Enumeration ClientType

    Enumeration Members

    Enumeration Members

    blocking: "blocking"
    normal: "normal"

    Generated using TypeDoc

    \ No newline at end of file +

    Enumeration Members

    blocking: "blocking"
    normal: "normal"

    Generated using TypeDoc

    \ No newline at end of file diff --git a/enums/v5.ErrorCode.html b/enums/v5.ErrorCode.html index f60b2a9e88..bef8d006b8 100644 --- a/enums/v5.ErrorCode.html +++ b/enums/v5.ErrorCode.html @@ -1,8 +1,8 @@ -ErrorCode | bullmq - v5.12.12

    Enumeration ErrorCode

    Enumeration Members

    JobLockMismatch +ErrorCode | bullmq - v5.12.12

    Enumeration ErrorCode

    Enumeration Members

    JobLockMismatch: -6
    JobLockNotExist: -2
    JobNotExist: -1
    JobNotInState: -3
    JobPendingDependencies: -4
    ParentJobCannotBeReplaced: -7
    ParentJobNotExist: -5

    Generated using TypeDoc

    \ No newline at end of file +

    Enumeration Members

    JobLockMismatch: -6
    JobLockNotExist: -2
    JobNotExist: -1
    JobNotInState: -3
    JobPendingDependencies: -4
    ParentJobCannotBeReplaced: -7
    ParentJobNotExist: -5

    Generated using TypeDoc

    \ No newline at end of file diff --git a/enums/v5.MetricsTime.html b/enums/v5.MetricsTime.html index 8fb36cd4e8..3d759feea2 100644 --- a/enums/v5.MetricsTime.html +++ b/enums/v5.MetricsTime.html @@ -1,4 +1,4 @@ -MetricsTime | bullmq - v5.12.12

    Enumeration MetricsTime

    Enumeration Members

    FIFTEEN_MINUTES +MetricsTime | bullmq - v5.12.12

    Enumeration MetricsTime

    Enumeration Members

    FIFTEEN_MINUTES: 15
    FIVE_MINUTES: 5
    ONE_HOUR: 60
    ONE_MINUTE: 1
    ONE_MONTH: 80640
    ONE_WEEK: 10080
    THIRTY_MINUTES: 30
    TWO_WEEKS: 20160

    Generated using TypeDoc

    \ No newline at end of file +

    Enumeration Members

    FIFTEEN_MINUTES: 15
    FIVE_MINUTES: 5
    ONE_HOUR: 60
    ONE_MINUTE: 1
    ONE_MONTH: 80640
    ONE_WEEK: 10080
    THIRTY_MINUTES: 30
    TWO_WEEKS: 20160

    Generated using TypeDoc

    \ No newline at end of file diff --git a/enums/v5.ParentCommand.html b/enums/v5.ParentCommand.html index 99f1938202..5133e32cf6 100644 --- a/enums/v5.ParentCommand.html +++ b/enums/v5.ParentCommand.html @@ -1,4 +1,4 @@ -ParentCommand | bullmq - v5.12.12

    Enumeration ParentCommand

    Enumeration Members

    Completed +ParentCommand | bullmq - v5.12.12

    Enumeration ParentCommand

    Enumeration Members

    Enumeration Members

    Completed: 0
    Error: 1
    Failed: 2
    InitCompleted: 4
    InitFailed: 3
    Log: 5
    MoveToDelayed: 6
    Progress: 7
    Update: 8

    Generated using TypeDoc

    \ No newline at end of file +

    Enumeration Members

    Completed: 0
    Error: 1
    Failed: 2
    InitCompleted: 4
    InitFailed: 3
    Log: 5
    MoveToDelayed: 6
    Progress: 7
    Update: 8

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.array2obj.html b/functions/v5.array2obj.html index 7906aa09b1..5a42fbb9cd 100644 --- a/functions/v5.array2obj.html +++ b/functions/v5.array2obj.html @@ -1 +1 @@ -array2obj | bullmq - v5.12.12

    Function array2obj

    • Parameters

      • arr: string[]

      Returns Record<string, string>

    Generated using TypeDoc

    \ No newline at end of file +array2obj | bullmq - v5.12.12

    Function array2obj

    • Parameters

      • arr: string[]

      Returns Record<string, string>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.asyncSend.html b/functions/v5.asyncSend.html index 6af2dd3a06..b3d4ee2527 100644 --- a/functions/v5.asyncSend.html +++ b/functions/v5.asyncSend.html @@ -1 +1 @@ -asyncSend | bullmq - v5.12.12

    Function asyncSend

    • Type Parameters

      • T extends procSendLike

      Parameters

      • proc: T
      • msg: any

      Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file +asyncSend | bullmq - v5.12.12

    Function asyncSend

    • Type Parameters

      • T extends procSendLike

      Parameters

      • proc: T
      • msg: any

      Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.childSend.html b/functions/v5.childSend.html index 83970fe110..9d28a0781a 100644 --- a/functions/v5.childSend.html +++ b/functions/v5.childSend.html @@ -1 +1 @@ -childSend | bullmq - v5.12.12

    Function childSend

    Generated using TypeDoc

    \ No newline at end of file +childSend | bullmq - v5.12.12

    Function childSend

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.decreaseMaxListeners.html b/functions/v5.decreaseMaxListeners.html index 85f30b61e6..8a7ad5f9ea 100644 --- a/functions/v5.decreaseMaxListeners.html +++ b/functions/v5.decreaseMaxListeners.html @@ -1 +1 @@ -decreaseMaxListeners | bullmq - v5.12.12

    Function decreaseMaxListeners

    • Parameters

      • emitter: EventEmitter
      • count: number

      Returns void

    Generated using TypeDoc

    \ No newline at end of file +decreaseMaxListeners | bullmq - v5.12.12

    Function decreaseMaxListeners

    • Parameters

      • emitter: EventEmitter
      • count: number

      Returns void

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.delay.html b/functions/v5.delay.html index 365ae6228f..6ff598b9ec 100644 --- a/functions/v5.delay.html +++ b/functions/v5.delay.html @@ -1 +1 @@ -delay | bullmq - v5.12.12

    Function delay

    • Parameters

      • ms: number
      • Optional abortController: AbortController

      Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file +delay | bullmq - v5.12.12

    Function delay

    • Parameters

      • ms: number
      • Optional abortController: AbortController

      Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.errorToJSON.html b/functions/v5.errorToJSON.html index 5de7903345..02f0316306 100644 --- a/functions/v5.errorToJSON.html +++ b/functions/v5.errorToJSON.html @@ -1 +1 @@ -errorToJSON | bullmq - v5.12.12

    Function errorToJSON

    • Parameters

      • value: any

      Returns Record<string, any>

    Generated using TypeDoc

    \ No newline at end of file +errorToJSON | bullmq - v5.12.12

    Function errorToJSON

    • Parameters

      • value: any

      Returns Record<string, any>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.getNextMillis.html b/functions/v5.getNextMillis.html index 4542d02b0f..bb5aebefa3 100644 --- a/functions/v5.getNextMillis.html +++ b/functions/v5.getNextMillis.html @@ -1 +1 @@ -getNextMillis | bullmq - v5.12.12

    Function getNextMillis

    Generated using TypeDoc

    \ No newline at end of file +getNextMillis | bullmq - v5.12.12

    Function getNextMillis

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.getParentKey.html b/functions/v5.getParentKey.html index 73c6d526d3..7f9a86c7ce 100644 --- a/functions/v5.getParentKey.html +++ b/functions/v5.getParentKey.html @@ -1 +1 @@ -getParentKey | bullmq - v5.12.12

    Function getParentKey

    • Parameters

      • opts: {
            id: string;
            queue: string;
        }
        • id: string
        • queue: string

      Returns string | undefined

    Generated using TypeDoc

    \ No newline at end of file +getParentKey | bullmq - v5.12.12

    Function getParentKey

    • Parameters

      • opts: {
            id: string;
            queue: string;
        }
        • id: string
        • queue: string

      Returns string | undefined

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.increaseMaxListeners.html b/functions/v5.increaseMaxListeners.html index 1b9ce787ba..0155ea7dde 100644 --- a/functions/v5.increaseMaxListeners.html +++ b/functions/v5.increaseMaxListeners.html @@ -1 +1 @@ -increaseMaxListeners | bullmq - v5.12.12

    Function increaseMaxListeners

    • Parameters

      • emitter: EventEmitter
      • count: number

      Returns void

    Generated using TypeDoc

    \ No newline at end of file +increaseMaxListeners | bullmq - v5.12.12

    Function increaseMaxListeners

    • Parameters

      • emitter: EventEmitter
      • count: number

      Returns void

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.invertObject.html b/functions/v5.invertObject.html index e7b13cdd08..d5f39adff7 100644 --- a/functions/v5.invertObject.html +++ b/functions/v5.invertObject.html @@ -1 +1 @@ -invertObject | bullmq - v5.12.12

    Function invertObject

    • Parameters

      • obj: Record<string, string>

      Returns Record<string, string>

    Generated using TypeDoc

    \ No newline at end of file +invertObject | bullmq - v5.12.12

    Function invertObject

    • Parameters

      • obj: Record<string, string>

      Returns Record<string, string>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.isEmpty.html b/functions/v5.isEmpty.html index 509f98add6..6095221505 100644 --- a/functions/v5.isEmpty.html +++ b/functions/v5.isEmpty.html @@ -1 +1 @@ -isEmpty | bullmq - v5.12.12

    Function isEmpty

    • Parameters

      • obj: object

      Returns boolean

    Generated using TypeDoc

    \ No newline at end of file +isEmpty | bullmq - v5.12.12

    Function isEmpty

    • Parameters

      • obj: object

      Returns boolean

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.isNotConnectionError.html b/functions/v5.isNotConnectionError.html index 385b72b424..33c4baaaf2 100644 --- a/functions/v5.isNotConnectionError.html +++ b/functions/v5.isNotConnectionError.html @@ -1 +1 @@ -isNotConnectionError | bullmq - v5.12.12

    Function isNotConnectionError

    • Parameters

      • error: Error

      Returns boolean

    Generated using TypeDoc

    \ No newline at end of file +isNotConnectionError | bullmq - v5.12.12

    Function isNotConnectionError

    • Parameters

      • error: Error

      Returns boolean

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.isRedisCluster.html b/functions/v5.isRedisCluster.html index 4467ca2d1e..d72d3e18d8 100644 --- a/functions/v5.isRedisCluster.html +++ b/functions/v5.isRedisCluster.html @@ -1 +1 @@ -isRedisCluster | bullmq - v5.12.12

    Function isRedisCluster

    • Parameters

      • obj: unknown

      Returns obj is Cluster

    Generated using TypeDoc

    \ No newline at end of file +isRedisCluster | bullmq - v5.12.12

    Function isRedisCluster

    • Parameters

      • obj: unknown

      Returns obj is Cluster

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.isRedisInstance.html b/functions/v5.isRedisInstance.html index 769de4604c..247964851c 100644 --- a/functions/v5.isRedisInstance.html +++ b/functions/v5.isRedisInstance.html @@ -1 +1 @@ -isRedisInstance | bullmq - v5.12.12

    Function isRedisInstance

    • Parameters

      • obj: any

      Returns obj is Cluster | Redis

    Generated using TypeDoc

    \ No newline at end of file +isRedisInstance | bullmq - v5.12.12

    Function isRedisInstance

    • Parameters

      • obj: any

      Returns obj is Cluster | Redis

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.isRedisVersionLowerThan.html b/functions/v5.isRedisVersionLowerThan.html index 54af72e659..cd69b51802 100644 --- a/functions/v5.isRedisVersionLowerThan.html +++ b/functions/v5.isRedisVersionLowerThan.html @@ -1 +1 @@ -isRedisVersionLowerThan | bullmq - v5.12.12

    Function isRedisVersionLowerThan

    • Parameters

      • currentVersion: string
      • minimumVersion: string

      Returns boolean

    Generated using TypeDoc

    \ No newline at end of file +isRedisVersionLowerThan | bullmq - v5.12.12

    Function isRedisVersionLowerThan

    • Parameters

      • currentVersion: string
      • minimumVersion: string

      Returns boolean

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.lengthInUtf8Bytes.html b/functions/v5.lengthInUtf8Bytes.html index 3a2f7a1d6f..8864e8fa39 100644 --- a/functions/v5.lengthInUtf8Bytes.html +++ b/functions/v5.lengthInUtf8Bytes.html @@ -1,3 +1,3 @@ lengthInUtf8Bytes | bullmq - v5.12.12

    Function lengthInUtf8Bytes

    Generated using TypeDoc

    \ No newline at end of file +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.parseObjectValues.html b/functions/v5.parseObjectValues.html index c92e30c4b0..3fef10c7b4 100644 --- a/functions/v5.parseObjectValues.html +++ b/functions/v5.parseObjectValues.html @@ -1 +1 @@ -parseObjectValues | bullmq - v5.12.12

    Function parseObjectValues

    • Parameters

      • obj: {
            [key: string]: string;
        }
        • [key: string]: string

      Returns Record<string, any>

    Generated using TypeDoc

    \ No newline at end of file +parseObjectValues | bullmq - v5.12.12

    Function parseObjectValues

    • Parameters

      • obj: {
            [key: string]: string;
        }
        • [key: string]: string

      Returns Record<string, any>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.raw2NextJobData.html b/functions/v5.raw2NextJobData.html index d781e27d26..f9911d9b33 100644 --- a/functions/v5.raw2NextJobData.html +++ b/functions/v5.raw2NextJobData.html @@ -1 +1 @@ -raw2NextJobData | bullmq - v5.12.12

    Function raw2NextJobData

    Generated using TypeDoc

    \ No newline at end of file +raw2NextJobData | bullmq - v5.12.12

    Function raw2NextJobData

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.removeAllQueueData.html b/functions/v5.removeAllQueueData.html index 52d50efac6..af43842ba3 100644 --- a/functions/v5.removeAllQueueData.html +++ b/functions/v5.removeAllQueueData.html @@ -1 +1 @@ -removeAllQueueData | bullmq - v5.12.12

    Function removeAllQueueData

    • Parameters

      • client: RedisClient
      • queueName: string
      • prefix: string = ...

      Returns Promise<void | boolean>

    Generated using TypeDoc

    \ No newline at end of file +removeAllQueueData | bullmq - v5.12.12

    Function removeAllQueueData

    • Parameters

      • client: RedisClient
      • queueName: string
      • prefix: string = ...

      Returns Promise<void | boolean>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.toString.html b/functions/v5.toString.html index 954f3b21b4..dd65fa0f0c 100644 --- a/functions/v5.toString.html +++ b/functions/v5.toString.html @@ -1 +1 @@ -toString | bullmq - v5.12.12

    Function toString

    • Parameters

      • value: any

      Returns string

    Generated using TypeDoc

    \ No newline at end of file +toString | bullmq - v5.12.12

    Function toString

    • Parameters

      • value: any

      Returns string

    Generated using TypeDoc

    \ No newline at end of file diff --git a/functions/v5.tryCatch.html b/functions/v5.tryCatch.html index 045c0ffe37..d5dfdc9eb3 100644 --- a/functions/v5.tryCatch.html +++ b/functions/v5.tryCatch.html @@ -1 +1 @@ -tryCatch | bullmq - v5.12.12

    Function tryCatch

    • Parameters

      • fn: ((...args) => any)
          • (...args): any
          • Parameters

            • Rest ...args: any

            Returns any

      • ctx: any
      • args: any[]

      Returns any

    Generated using TypeDoc

    \ No newline at end of file +tryCatch | bullmq - v5.12.12

    Function tryCatch

    • Parameters

      • fn: ((...args) => any)
          • (...args): any
          • Parameters

            • Rest ...args: any

            Returns any

      • ctx: any
      • args: any[]

      Returns any

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.AddChildrenOpts.html b/interfaces/v5.AddChildrenOpts.html index 9f4d05d268..230fe37a61 100644 --- a/interfaces/v5.AddChildrenOpts.html +++ b/interfaces/v5.AddChildrenOpts.html @@ -1,5 +1,5 @@ -AddChildrenOpts | bullmq - v5.12.12

    Interface AddChildrenOpts

    interface AddChildrenOpts {
        multi: ChainableCommander;
        nodes: FlowJob[];
        parent: {
            parentDependenciesKey: string;
            parentOpts: {
                id: string;
                queue: string;
            };
        };
        queuesOpts?: FlowQueuesOpts;
    }

    Properties

    multi +AddChildrenOpts | bullmq - v5.12.12

    Interface AddChildrenOpts

    interface AddChildrenOpts {
        multi: ChainableCommander;
        nodes: FlowJob[];
        parent: {
            parentDependenciesKey: string;
            parentOpts: {
                id: string;
                queue: string;
            };
        };
        queuesOpts?: FlowQueuesOpts;
    }

    Properties

    multi: ChainableCommander
    nodes: FlowJob[]
    parent: {
        parentDependenciesKey: string;
        parentOpts: {
            id: string;
            queue: string;
        };
    }

    Type declaration

    • parentDependenciesKey: string
    • parentOpts: {
          id: string;
          queue: string;
      }
      • id: string
      • queue: string
    queuesOpts?: FlowQueuesOpts

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    multi: ChainableCommander
    nodes: FlowJob[]
    parent: {
        parentDependenciesKey: string;
        parentOpts: {
            id: string;
            queue: string;
        };
    }

    Type declaration

    • parentDependenciesKey: string
    • parentOpts: {
          id: string;
          queue: string;
      }
      • id: string
      • queue: string
    queuesOpts?: FlowQueuesOpts

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.AddNodeOpts.html b/interfaces/v5.AddNodeOpts.html index 56e7689ed3..03263df5e0 100644 --- a/interfaces/v5.AddNodeOpts.html +++ b/interfaces/v5.AddNodeOpts.html @@ -1,6 +1,6 @@ -AddNodeOpts | bullmq - v5.12.12

    Interface AddNodeOpts

    interface AddNodeOpts {
        multi: ChainableCommander;
        node: FlowJob;
        parent?: {
            parentDependenciesKey: string;
            parentOpts: {
                id: string;
                queue: string;
            };
        };
        queuesOpts?: FlowQueuesOpts;
    }

    Properties

    multi +AddNodeOpts | bullmq - v5.12.12

    Interface AddNodeOpts

    interface AddNodeOpts {
        multi: ChainableCommander;
        node: FlowJob;
        parent?: {
            parentDependenciesKey: string;
            parentOpts: {
                id: string;
                queue: string;
            };
        };
        queuesOpts?: FlowQueuesOpts;
    }

    Properties

    multi: ChainableCommander
    node: FlowJob
    parent?: {
        parentDependenciesKey: string;
        parentOpts: {
            id: string;
            queue: string;
        };
    }

    Type declaration

    • parentDependenciesKey: string
    • parentOpts: {
          id: string;
          queue: string;
      }
      • id: string
      • queue: string
    queuesOpts?: FlowQueuesOpts

    Queues options that will be applied in each node depending on queue name presence.

    -

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    multi: ChainableCommander
    node: FlowJob
    parent?: {
        parentDependenciesKey: string;
        parentOpts: {
            id: string;
            queue: string;
        };
    }

    Type declaration

    • parentDependenciesKey: string
    • parentOpts: {
          id: string;
          queue: string;
      }
      • id: string
      • queue: string
    queuesOpts?: FlowQueuesOpts

    Queues options that will be applied in each node depending on queue name presence.

    +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.AdvancedOptions.html b/interfaces/v5.AdvancedOptions.html index bf87c2a701..3c992a4fda 100644 --- a/interfaces/v5.AdvancedOptions.html +++ b/interfaces/v5.AdvancedOptions.html @@ -1,8 +1,8 @@ -AdvancedOptions | bullmq - v5.12.12

    Interface AdvancedOptions

    interface AdvancedOptions {
        backoffStrategy?: BackoffStrategy;
        repeatKeyHashAlgorithm?: string;
        repeatStrategy?: RepeatStrategy;
    }

    Hierarchy (view full)

    Properties

    backoffStrategy? +AdvancedOptions | bullmq - v5.12.12

    Interface AdvancedOptions

    interface AdvancedOptions {
        backoffStrategy?: BackoffStrategy;
        repeatKeyHashAlgorithm?: string;
        repeatStrategy?: RepeatStrategy;
    }

    Hierarchy (view full)

    Properties

    backoffStrategy?: BackoffStrategy

    A custom backoff strategy.

    -
    repeatKeyHashAlgorithm?: string

    A hash algorithm to be used when trying to create the job redis key. +

    repeatKeyHashAlgorithm?: string

    A hash algorithm to be used when trying to create the job redis key. Default - md5

    -
    repeatStrategy?: RepeatStrategy

    A custom cron strategy.

    -

    Generated using TypeDoc

    \ No newline at end of file +
    repeatStrategy?: RepeatStrategy

    A custom cron strategy.

    +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.AdvancedRepeatOptions.html b/interfaces/v5.AdvancedRepeatOptions.html index f096b228aa..bf6c56424f 100644 --- a/interfaces/v5.AdvancedRepeatOptions.html +++ b/interfaces/v5.AdvancedRepeatOptions.html @@ -1,6 +1,6 @@ -AdvancedRepeatOptions | bullmq - v5.12.12

    Interface AdvancedRepeatOptions

    interface AdvancedRepeatOptions {
        repeatKeyHashAlgorithm?: string;
        repeatStrategy?: RepeatStrategy;
    }

    Hierarchy (view full)

    Properties

    repeatKeyHashAlgorithm? +AdvancedRepeatOptions | bullmq - v5.12.12

    Interface AdvancedRepeatOptions

    interface AdvancedRepeatOptions {
        repeatKeyHashAlgorithm?: string;
        repeatStrategy?: RepeatStrategy;
    }

    Hierarchy (view full)

    Properties

    repeatKeyHashAlgorithm?: string

    A hash algorithm to be used when trying to create the job redis key. Default - md5

    -
    repeatStrategy?: RepeatStrategy

    A custom cron strategy.

    -

    Generated using TypeDoc

    \ No newline at end of file +
    repeatStrategy?: RepeatStrategy

    A custom cron strategy.

    +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.BackoffOptions.html b/interfaces/v5.BackoffOptions.html index eccfbee4c0..6ca0bd6442 100644 --- a/interfaces/v5.BackoffOptions.html +++ b/interfaces/v5.BackoffOptions.html @@ -1,7 +1,7 @@ BackoffOptions | bullmq - v5.12.12

    Interface BackoffOptions

    Settings for backing off failed jobs.

    interface BackoffOptions {
        delay?: number;
        type: "fixed" | "exponential" | string & {};
    }

    Properties

    interface BackoffOptions {
        delay?: number;
        type: "fixed" | "exponential" | string & {};
    }

    Properties

    Properties

    delay?: number

    Delay in milliseconds.

    -
    type: "fixed" | "exponential" | string & {}

    Name of the backoff strategy.

    -

    Generated using TypeDoc

    \ No newline at end of file +
    type: "fixed" | "exponential" | string & {}

    Name of the backoff strategy.

    +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.BaseJobOptions.html b/interfaces/v5.BaseJobOptions.html index 956cacb4b0..b53a79014f 100644 --- a/interfaces/v5.BaseJobOptions.html +++ b/interfaces/v5.BaseJobOptions.html @@ -1,4 +1,4 @@ -BaseJobOptions | bullmq - v5.12.12

    Interface BaseJobOptions

    interface BaseJobOptions {
        attempts?: number;
        backoff?: number | BackoffOptions;
        delay?: number;
        jobId?: string;
        keepLogs?: number;
        lifo?: boolean;
        parent?: {
            id: string;
            queue: string;
        };
        prevMillis?: number;
        priority?: number;
        removeOnComplete?: number | boolean | KeepJobs;
        removeOnFail?: number | boolean | KeepJobs;
        repeat?: RepeatOptions;
        repeatJobKey?: string;
        sizeLimit?: number;
        stackTraceLimit?: number;
        timestamp?: number;
    }

    Hierarchy (view full)

    Properties

    attempts? +BaseJobOptions | bullmq - v5.12.12

    Interface BaseJobOptions

    interface BaseJobOptions {
        attempts?: number;
        backoff?: number | BackoffOptions;
        delay?: number;
        jobId?: string;
        keepLogs?: number;
        lifo?: boolean;
        parent?: {
            id: string;
            queue: string;
        };
        prevMillis?: number;
        priority?: number;
        removeOnComplete?: number | boolean | KeepJobs;
        removeOnFail?: number | boolean | KeepJobs;
        repeat?: RepeatOptions;
        repeatJobKey?: string;
        sizeLimit?: number;
        stackTraceLimit?: number;
        timestamp?: number;
    }

    Hierarchy (view full)

    Properties

    attempts? backoff? delay? jobId? @@ -17,41 +17,41 @@

    Properties

    attempts?: number

    The total number of attempts to try the job until it completes.

    Default Value

    0
     
    -
    backoff?: number | BackoffOptions

    Backoff setting for automatic retries if the job fails

    -
    delay?: number

    An amount of milliseconds to wait until this job can be processed. +

    backoff?: number | BackoffOptions

    Backoff setting for automatic retries if the job fails

    +
    delay?: number

    An amount of milliseconds to wait until this job can be processed. Note that for accurate delays, worker and producers should have their clocks synchronized.

    Default Value

    0
     
    -
    jobId?: string

    Override the job ID - by default, the job ID is a unique +

    jobId?: string

    Override the job ID - by default, the job ID is a unique integer, but you can use this setting to override it. If you use this option, it is up to you to ensure the jobId is unique. If you attempt to add a job with an id that already exists, it will not be added.

    -
    keepLogs?: number

    Maximum amount of log entries that will be preserved

    -
    lifo?: boolean

    If true, adds the job to the right of the queue instead of the left (default false)

    +
    keepLogs?: number

    Maximum amount of log entries that will be preserved

    +
    lifo?: boolean

    If true, adds the job to the right of the queue instead of the left (default false)

    parent?: {
        id: string;
        queue: string;
    }

    Type declaration

    parent?: {
        id: string;
        queue: string;
    }

    Type declaration

    prevMillis?: number

    Internal property used by repeatable jobs.

    -
    priority?: number

    Ranges from 1 (highest priority) to 2 097 152 (lowest priority). Note that +

    prevMillis?: number

    Internal property used by repeatable jobs.

    +
    priority?: number

    Ranges from 1 (highest priority) to 2 097 152 (lowest priority). Note that using priorities has a slight impact on performance, so do not use it if not required.

    -
    removeOnComplete?: number | boolean | KeepJobs

    If true, removes the job when it successfully completes +

    removeOnComplete?: number | boolean | KeepJobs

    If true, removes the job when it successfully completes When given a number, it specifies the maximum amount of jobs to keep, or you can provide an object specifying max age and/or count to keep. It overrides whatever setting is used in the worker. Default behavior is to keep the job in the completed set.

    -
    removeOnFail?: number | boolean | KeepJobs

    If true, removes the job when it fails after all attempts. +

    removeOnFail?: number | boolean | KeepJobs

    If true, removes the job when it fails after all attempts. When given a number, it specifies the maximum amount of jobs to keep, or you can provide an object specifying max age and/or count to keep. It overrides whatever setting is used in the worker. Default behavior is to keep the job in the failed set.

    -
    repeat?: RepeatOptions

    Repeat this job, for example based on a cron schedule.

    -
    repeatJobKey?: string

    Internal property used by repeatable jobs to save base repeat job key.

    -
    sizeLimit?: number

    Limits the size in bytes of the job's data payload (as a JSON serialized string).

    -
    stackTraceLimit?: number

    Limits the amount of stack trace lines that will be recorded in the stacktrace.

    -
    timestamp?: number

    Timestamp when the job was created.

    +
    repeat?: RepeatOptions

    Repeat this job, for example based on a cron schedule.

    +
    repeatJobKey?: string

    Internal property used by repeatable jobs to save base repeat job key.

    +
    sizeLimit?: number

    Limits the size in bytes of the job's data payload (as a JSON serialized string).

    +
    stackTraceLimit?: number

    Limits the amount of stack trace lines that will be recorded in the stacktrace.

    +
    timestamp?: number

    Timestamp when the job was created.

    Default Value

    Date.now()
     
    -

    Generated using TypeDoc

    \ No newline at end of file +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.BaseOptions.html b/interfaces/v5.BaseOptions.html index 1d15134ca0..7e199b3751 100644 --- a/interfaces/v5.BaseOptions.html +++ b/interfaces/v5.BaseOptions.html @@ -1,2 +1,2 @@ -BaseOptions | bullmq - v5.12.12

    Interface BaseOptions

    interface BaseOptions {
        skipVersionCheck?: boolean;
    }

    Properties

    Properties

    skipVersionCheck?: boolean

    Generated using TypeDoc

    \ No newline at end of file +BaseOptions | bullmq - v5.12.12

    Interface BaseOptions

    interface BaseOptions {
        skipVersionCheck?: boolean;
    }

    Properties

    Properties

    skipVersionCheck?: boolean

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.BuiltInStrategies.html b/interfaces/v5.BuiltInStrategies.html index 49898e609a..07e21aa75f 100644 --- a/interfaces/v5.BuiltInStrategies.html +++ b/interfaces/v5.BuiltInStrategies.html @@ -1 +1 @@ -BuiltInStrategies | bullmq - v5.12.12

    Interface BuiltInStrategies

    interface BuiltInStrategies {
        [index: string]: ((delay) => BackoffStrategy);
    }

    Indexable

    [index: string]: ((delay) => BackoffStrategy)

    Generated using TypeDoc

    \ No newline at end of file +BuiltInStrategies | bullmq - v5.12.12

    Interface BuiltInStrategies

    interface BuiltInStrategies {
        [index: string]: ((delay) => BackoffStrategy);
    }

    Indexable

    [index: string]: ((delay) => BackoffStrategy)

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.ChildMessage.html b/interfaces/v5.ChildMessage.html index 209f02cf62..aecc5b4a38 100644 --- a/interfaces/v5.ChildMessage.html +++ b/interfaces/v5.ChildMessage.html @@ -1,4 +1,4 @@ -ChildMessage | bullmq - v5.12.12

    Interface ChildMessage

    interface ChildMessage {
        cmd: ParentCommand;
        err?: Record<string, any>;
        value?: any;
    }

    Properties

    cmd +ChildMessage | bullmq - v5.12.12

    Interface ChildMessage

    interface ChildMessage {
        cmd: ParentCommand;
        err?: Record<string, any>;
        value?: any;
    }

    Properties

    Properties

    err?: Record<string, any>
    value?: any

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    err?: Record<string, any>
    value?: any

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.DebounceOptions.html b/interfaces/v5.DebounceOptions.html index 54b0abf7f4..8755019f09 100644 --- a/interfaces/v5.DebounceOptions.html +++ b/interfaces/v5.DebounceOptions.html @@ -1,6 +1,6 @@ DebounceOptions | bullmq - v5.12.12

    Interface DebounceOptions

    Debounce options

    -
    interface DebounceOptions {
        id: string;
        ttl?: number;
    }

    Properties

    id +
    interface DebounceOptions {
        id: string;
        ttl?: number;
    }

    Properties

    Properties

    id: string

    Identifier

    -
    ttl?: number

    ttl in milliseconds

    -

    Generated using TypeDoc

    \ No newline at end of file +
    ttl?: number

    ttl in milliseconds

    +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.DefaultJobOptions.html b/interfaces/v5.DefaultJobOptions.html index 1ffcc0c830..c597f8c661 100644 --- a/interfaces/v5.DefaultJobOptions.html +++ b/interfaces/v5.DefaultJobOptions.html @@ -1,4 +1,4 @@ -DefaultJobOptions | bullmq - v5.12.12

    Interface DefaultJobOptions

    interface DefaultJobOptions {
        attempts?: number;
        backoff?: number | BackoffOptions;
        delay?: number;
        keepLogs?: number;
        lifo?: boolean;
        priority?: number;
        removeOnComplete?: number | boolean | KeepJobs;
        removeOnFail?: number | boolean | KeepJobs;
        sizeLimit?: number;
        stackTraceLimit?: number;
        timestamp?: number;
    }

    Hierarchy (view full)

    Properties

    attempts? +DefaultJobOptions | bullmq - v5.12.12

    Interface DefaultJobOptions

    interface DefaultJobOptions {
        attempts?: number;
        backoff?: number | BackoffOptions;
        delay?: number;
        keepLogs?: number;
        lifo?: boolean;
        priority?: number;
        removeOnComplete?: number | boolean | KeepJobs;
        removeOnFail?: number | boolean | KeepJobs;
        sizeLimit?: number;
        stackTraceLimit?: number;
        timestamp?: number;
    }

    Hierarchy (view full)

    Properties

    attempts? backoff? delay? keepLogs? @@ -12,31 +12,31 @@

    Properties

    attempts?: number

    The total number of attempts to try the job until it completes.

    Default Value

    0
     
    -
    backoff?: number | BackoffOptions

    Backoff setting for automatic retries if the job fails

    -
    delay?: number

    An amount of milliseconds to wait until this job can be processed. +

    backoff?: number | BackoffOptions

    Backoff setting for automatic retries if the job fails

    +
    delay?: number

    An amount of milliseconds to wait until this job can be processed. Note that for accurate delays, worker and producers should have their clocks synchronized.

    Default Value

    0
     
    -
    keepLogs?: number

    Maximum amount of log entries that will be preserved

    -
    lifo?: boolean

    If true, adds the job to the right of the queue instead of the left (default false)

    +
    keepLogs?: number

    Maximum amount of log entries that will be preserved

    +
    lifo?: boolean

    If true, adds the job to the right of the queue instead of the left (default false)

    priority?: number

    Ranges from 1 (highest priority) to 2 097 152 (lowest priority). Note that +

    priority?: number

    Ranges from 1 (highest priority) to 2 097 152 (lowest priority). Note that using priorities has a slight impact on performance, so do not use it if not required.

    -
    removeOnComplete?: number | boolean | KeepJobs

    If true, removes the job when it successfully completes +

    removeOnComplete?: number | boolean | KeepJobs

    If true, removes the job when it successfully completes When given a number, it specifies the maximum amount of jobs to keep, or you can provide an object specifying max age and/or count to keep. It overrides whatever setting is used in the worker. Default behavior is to keep the job in the completed set.

    -
    removeOnFail?: number | boolean | KeepJobs

    If true, removes the job when it fails after all attempts. +

    removeOnFail?: number | boolean | KeepJobs

    If true, removes the job when it fails after all attempts. When given a number, it specifies the maximum amount of jobs to keep, or you can provide an object specifying max age and/or count to keep. It overrides whatever setting is used in the worker. Default behavior is to keep the job in the failed set.

    -
    sizeLimit?: number

    Limits the size in bytes of the job's data payload (as a JSON serialized string).

    -
    stackTraceLimit?: number

    Limits the amount of stack trace lines that will be recorded in the stacktrace.

    -
    timestamp?: number

    Timestamp when the job was created.

    +
    sizeLimit?: number

    Limits the size in bytes of the job's data payload (as a JSON serialized string).

    +
    stackTraceLimit?: number

    Limits the amount of stack trace lines that will be recorded in the stacktrace.

    +
    timestamp?: number

    Timestamp when the job was created.

    Default Value

    Date.now()
     
    -

    Generated using TypeDoc

    \ No newline at end of file +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.DependenciesOpts.html b/interfaces/v5.DependenciesOpts.html index c733d877d9..f2f55d62ff 100644 --- a/interfaces/v5.DependenciesOpts.html +++ b/interfaces/v5.DependenciesOpts.html @@ -1,3 +1,3 @@ -DependenciesOpts | bullmq - v5.12.12

    Interface DependenciesOpts

    interface DependenciesOpts {
        processed?: {
            count?: number;
            cursor?: number;
        };
        unprocessed?: {
            count?: number;
            cursor?: number;
        };
    }

    Properties

    processed? +DependenciesOpts | bullmq - v5.12.12

    Interface DependenciesOpts

    interface DependenciesOpts {
        processed?: {
            count?: number;
            cursor?: number;
        };
        unprocessed?: {
            count?: number;
            cursor?: number;
        };
    }

    Properties

    processed?: {
        count?: number;
        cursor?: number;
    }

    Type declaration

    • Optional count?: number
    • Optional cursor?: number
    unprocessed?: {
        count?: number;
        cursor?: number;
    }

    Type declaration

    • Optional count?: number
    • Optional cursor?: number

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    processed?: {
        count?: number;
        cursor?: number;
    }

    Type declaration

    • Optional count?: number
    • Optional cursor?: number
    unprocessed?: {
        count?: number;
        cursor?: number;
    }

    Type declaration

    • Optional count?: number
    • Optional cursor?: number

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.FlowJobBase.html b/interfaces/v5.FlowJobBase.html index 97e17e5300..30a0dee124 100644 --- a/interfaces/v5.FlowJobBase.html +++ b/interfaces/v5.FlowJobBase.html @@ -1,7 +1,7 @@ -FlowJobBase | bullmq - v5.12.12

    Interface FlowJobBase<T>

    interface FlowJobBase<T> {
        children?: FlowChildJob[];
        data?: any;
        name: string;
        opts?: Omit<T, "repeat">;
        prefix?: string;
        queueName: string;
    }

    Type Parameters

    • T

    Properties

    children? +FlowJobBase | bullmq - v5.12.12

    Interface FlowJobBase<T>

    interface FlowJobBase<T> {
        children?: FlowChildJob[];
        data?: any;
        name: string;
        opts?: Omit<T, "repeat">;
        prefix?: string;
        queueName: string;
    }

    Type Parameters

    • T

    Properties

    children?: FlowChildJob[]
    data?: any
    name: string
    opts?: Omit<T, "repeat">
    prefix?: string
    queueName: string

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    children?: FlowChildJob[]
    data?: any
    name: string
    opts?: Omit<T, "repeat">
    prefix?: string
    queueName: string

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.FlowOpts.html b/interfaces/v5.FlowOpts.html index 8446c482ee..e40ee39a1b 100644 --- a/interfaces/v5.FlowOpts.html +++ b/interfaces/v5.FlowOpts.html @@ -1,3 +1,3 @@ -FlowOpts | bullmq - v5.12.12

    Interface FlowOpts

    interface FlowOpts {
        queuesOptions: FlowQueuesOpts;
    }

    Properties

    queuesOptions +FlowOpts | bullmq - v5.12.12

    Interface FlowOpts

    interface FlowOpts {
        queuesOptions: FlowQueuesOpts;
    }

    Properties

    Properties

    queuesOptions: FlowQueuesOpts

    Map of options for Queue classes.

    -

    Generated using TypeDoc

    \ No newline at end of file +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.FlowProducerListener.html b/interfaces/v5.FlowProducerListener.html index f252bb169f..6d467469b8 100644 --- a/interfaces/v5.FlowProducerListener.html +++ b/interfaces/v5.FlowProducerListener.html @@ -1,11 +1,11 @@ -FlowProducerListener | bullmq - v5.12.12

    Interface FlowProducerListener

    interface FlowProducerListener {
        error: ((failedReason) => void);
        ioredis:close: (() => void);
    }

    Hierarchy (view full)

    Properties

    error +FlowProducerListener | bullmq - v5.12.12

    Interface FlowProducerListener

    interface FlowProducerListener {
        error: ((failedReason) => void);
        ioredis:close: (() => void);
    }

    Hierarchy (view full)

    Properties

    Properties

    error: ((failedReason) => void)

    Listen to 'error' event.

    This event is triggered when an error is throw.

    Type declaration

      • (failedReason): void
      • Listen to 'error' event.

        This event is triggered when an error is throw.

        -

        Parameters

        • failedReason: Error

        Returns void

    ioredis:close: (() => void)

    Listen to 'ioredis:close' event.

    +

    Parameters

    • failedReason: Error

    Returns void

    ioredis:close: (() => void)

    Listen to 'ioredis:close' event.

    This event is triggered when ioredis is closed.

    Type declaration

      • (): void
      • Listen to 'ioredis:close' event.

        This event is triggered when ioredis is closed.

        -

        Returns void

    Generated using TypeDoc

    \ No newline at end of file +

    Returns void

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.GetNextJobOptions.html b/interfaces/v5.GetNextJobOptions.html index 9d59baed57..92cdac6025 100644 --- a/interfaces/v5.GetNextJobOptions.html +++ b/interfaces/v5.GetNextJobOptions.html @@ -1,2 +1,2 @@ -GetNextJobOptions | bullmq - v5.12.12

    Interface GetNextJobOptions

    interface GetNextJobOptions {
        block?: boolean;
    }

    Properties

    Properties

    block?: boolean

    Generated using TypeDoc

    \ No newline at end of file +GetNextJobOptions | bullmq - v5.12.12

    Interface GetNextJobOptions

    interface GetNextJobOptions {
        block?: boolean;
    }

    Properties

    Properties

    block?: boolean

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.IConnection.html b/interfaces/v5.IConnection.html index 93be4a5377..c834a53123 100644 --- a/interfaces/v5.IConnection.html +++ b/interfaces/v5.IConnection.html @@ -1,3 +1,3 @@ -IConnection | bullmq - v5.12.12

    Interface IConnection

    interface IConnection {
        client: Promise<RedisClient>;
        waitUntilReady(): Promise<boolean>;
    }

    Hierarchy

    • EventEmitter
      • IConnection

    Properties

    client +IConnection | bullmq - v5.12.12

    Interface IConnection

    interface IConnection {
        client: Promise<RedisClient>;
        waitUntilReady(): Promise<boolean>;
    }

    Hierarchy

    • EventEmitter
      • IConnection

    Properties

    Methods

    Properties

    client: Promise<RedisClient>

    Methods

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    client: Promise<RedisClient>

    Methods

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.IoredisListener.html b/interfaces/v5.IoredisListener.html index e36fa24170..027469f9a3 100644 --- a/interfaces/v5.IoredisListener.html +++ b/interfaces/v5.IoredisListener.html @@ -1,6 +1,6 @@ -IoredisListener | bullmq - v5.12.12

    Interface IoredisListener

    interface IoredisListener {
        ioredis:close: (() => void);
    }

    Hierarchy (view full)

    Properties

    ioredis:close +IoredisListener | bullmq - v5.12.12

    Interface IoredisListener

    interface IoredisListener {
        ioredis:close: (() => void);
    }

    Hierarchy (view full)

    Properties

    Properties

    ioredis:close: (() => void)

    Listen to 'ioredis:close' event.

    This event is triggered when ioredis is closed.

    Type declaration

      • (): void
      • Listen to 'ioredis:close' event.

        This event is triggered when ioredis is closed.

        -

        Returns void

    Generated using TypeDoc

    \ No newline at end of file +

    Returns void

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.JobJson.html b/interfaces/v5.JobJson.html index 59f82d74fa..ce7e057fbe 100644 --- a/interfaces/v5.JobJson.html +++ b/interfaces/v5.JobJson.html @@ -1,4 +1,4 @@ -JobJson | bullmq - v5.12.12

    Interface JobJson

    interface JobJson {
        attemptsMade: number;
        attemptsStarted: number;
        data: string;
        debounceId?: string;
        failedReason: string;
        finishedOn?: number;
        id: string;
        name: string;
        opts: RedisJobOptions;
        parent?: ParentKeys;
        parentKey?: string;
        processedBy?: string;
        processedOn?: number;
        progress: number | object;
        repeatJobKey?: string;
        returnvalue: string;
        stacktrace: string;
        timestamp: number;
    }

    Properties

    attemptsMade +JobJson | bullmq - v5.12.12

    Interface JobJson

    interface JobJson {
        attemptsMade: number;
        attemptsStarted: number;
        data: string;
        debounceId?: string;
        failedReason: string;
        finishedOn?: number;
        id: string;
        name: string;
        opts: RedisJobOptions;
        parent?: ParentKeys;
        parentKey?: string;
        processedBy?: string;
        processedOn?: number;
        progress: number | object;
        repeatJobKey?: string;
        returnvalue: string;
        stacktrace: string;
        timestamp: number;
    }

    Properties

    attemptsMade: number
    attemptsStarted: number
    data: string
    debounceId?: string
    failedReason: string
    finishedOn?: number
    id: string
    name: string
    parent?: ParentKeys
    parentKey?: string
    processedBy?: string
    processedOn?: number
    progress: number | object
    repeatJobKey?: string
    returnvalue: string
    stacktrace: string
    timestamp: number

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    attemptsMade: number
    attemptsStarted: number
    data: string
    debounceId?: string
    failedReason: string
    finishedOn?: number
    id: string
    name: string
    parent?: ParentKeys
    parentKey?: string
    processedBy?: string
    processedOn?: number
    progress: number | object
    repeatJobKey?: string
    returnvalue: string
    stacktrace: string
    timestamp: number

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.JobJsonRaw.html b/interfaces/v5.JobJsonRaw.html index b652f32077..43c33e7d23 100644 --- a/interfaces/v5.JobJsonRaw.html +++ b/interfaces/v5.JobJsonRaw.html @@ -1,4 +1,4 @@ -JobJsonRaw | bullmq - v5.12.12

    Interface JobJsonRaw

    interface JobJsonRaw {
        atm?: string;
        ats?: string;
        attemptsMade?: string;
        data: string;
        deid?: string;
        delay: string;
        failedReason: string;
        finishedOn?: string;
        id: string;
        name: string;
        opts: string;
        parent?: string;
        parentKey?: string;
        pb?: string;
        processedOn?: string;
        progress: string;
        returnvalue: string;
        rjk?: string;
        stacktrace: string[];
        timestamp: string;
    }

    Properties

    atm? +JobJsonRaw | bullmq - v5.12.12

    Interface JobJsonRaw

    interface JobJsonRaw {
        atm?: string;
        ats?: string;
        attemptsMade?: string;
        data: string;
        deid?: string;
        delay: string;
        failedReason: string;
        finishedOn?: string;
        id: string;
        name: string;
        opts: string;
        parent?: string;
        parentKey?: string;
        pb?: string;
        processedOn?: string;
        progress: string;
        returnvalue: string;
        rjk?: string;
        stacktrace: string[];
        timestamp: string;
    }

    Properties

    Properties

    atm?: string
    ats?: string
    attemptsMade?: string
    data: string
    deid?: string
    delay: string
    failedReason: string
    finishedOn?: string
    id: string
    name: string
    opts: string
    parent?: string
    parentKey?: string
    pb?: string
    processedOn?: string
    progress: string
    returnvalue: string
    rjk?: string
    stacktrace: string[]
    timestamp: string

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    atm?: string
    ats?: string
    attemptsMade?: string
    data: string
    deid?: string
    delay: string
    failedReason: string
    finishedOn?: string
    id: string
    name: string
    opts: string
    parent?: string
    parentKey?: string
    pb?: string
    processedOn?: string
    progress: string
    returnvalue: string
    rjk?: string
    stacktrace: string[]
    timestamp: string

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.JobNode.html b/interfaces/v5.JobNode.html index eaab4d4366..c134307313 100644 --- a/interfaces/v5.JobNode.html +++ b/interfaces/v5.JobNode.html @@ -1,3 +1,3 @@ -JobNode | bullmq - v5.12.12

    Interface JobNode

    interface JobNode {
        children?: JobNode[];
        job: Job<any, any, string>;
    }

    Properties

    children? +JobNode | bullmq - v5.12.12

    Interface JobNode

    interface JobNode {
        children?: JobNode[];
        job: Job<any, any, string>;
    }

    Properties

    Properties

    children?: JobNode[]
    job: Job<any, any, string>

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    children?: JobNode[]
    job: Job<any, any, string>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.KeepJobs.html b/interfaces/v5.KeepJobs.html index 5699211c08..20aa998d48 100644 --- a/interfaces/v5.KeepJobs.html +++ b/interfaces/v5.KeepJobs.html @@ -2,8 +2,8 @@

    Specify which jobs to keep after finishing. If both age and count are specified, then the jobs kept will be the ones that satisfies both properties.

    -
    interface KeepJobs {
        age?: number;
        count?: number;
    }

    Properties

    interface KeepJobs {
        age?: number;
        count?: number;
    }

    Properties

    Properties

    age?: number

    Maximum age in seconds for job to be kept.

    -
    count?: number

    Maximum count of jobs to be kept.

    -

    Generated using TypeDoc

    \ No newline at end of file +
    count?: number

    Maximum count of jobs to be kept.

    +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.Metrics.html b/interfaces/v5.Metrics.html index 13472d0b72..77fca9c5d6 100644 --- a/interfaces/v5.Metrics.html +++ b/interfaces/v5.Metrics.html @@ -1,4 +1,4 @@ -Metrics | bullmq - v5.12.12

    Interface Metrics

    interface Metrics {
        count: number;
        data: number[];
        meta: {
            count: number;
            prevCount: number;
            prevTS: number;
        };
    }

    Properties

    count +Metrics | bullmq - v5.12.12

    Interface Metrics

    interface Metrics {
        count: number;
        data: number[];
        meta: {
            count: number;
            prevCount: number;
            prevTS: number;
        };
    }

    Properties

    Properties

    count: number
    data: number[]
    meta: {
        count: number;
        prevCount: number;
        prevTS: number;
    }

    Type declaration

    • count: number
    • prevCount: number
    • prevTS: number

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    count: number
    data: number[]
    meta: {
        count: number;
        prevCount: number;
        prevTS: number;
    }

    Type declaration

    • count: number
    • prevCount: number
    • prevTS: number

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.MetricsOptions.html b/interfaces/v5.MetricsOptions.html index c3bfeb595c..0570291948 100644 --- a/interfaces/v5.MetricsOptions.html +++ b/interfaces/v5.MetricsOptions.html @@ -1,5 +1,5 @@ -MetricsOptions | bullmq - v5.12.12

    Interface MetricsOptions

    interface MetricsOptions {
        maxDataPoints?: number;
    }

    Properties

    maxDataPoints? +MetricsOptions | bullmq - v5.12.12

    Interface MetricsOptions

    interface MetricsOptions {
        maxDataPoints?: number;
    }

    Properties

    Properties

    maxDataPoints?: number

    Enable gathering metrics for finished jobs. Output refers to all finished jobs, completed or failed.

    -

    Generated using TypeDoc

    \ No newline at end of file +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.MinimalJob.html b/interfaces/v5.MinimalJob.html index 50c9a87bb4..2719c02e1d 100644 --- a/interfaces/v5.MinimalJob.html +++ b/interfaces/v5.MinimalJob.html @@ -1,5 +1,5 @@ MinimalJob | bullmq - v5.12.12

    Interface MinimalJob<DataType, ReturnType, NameType>

    MinimalJob

    -
    interface MinimalJob<DataType, ReturnType, NameType> {
        attemptsMade: number;
        data: DataType;
        delay: number;
        failedReason: string;
        finishedOn?: number;
        id?: string;
        name: NameType;
        opts: JobsOptions;
        parent?: ParentKeys;
        parentKey?: string;
        processedOn?: number;
        progress: number | object;
        repeatJobKey?: string;
        returnvalue: ReturnType;
        stacktrace: string[];
        timestamp: number;
        get prefix(): string;
        get queueName(): string;
        get queueQualifiedName(): string;
        asJSON(): JobJson;
        asJSONSandbox(): JobJsonSandbox;
        log(logRow): Promise<number>;
        updateData(data): Promise<void>;
        updateProgress(progress): Promise<void>;
    }

    Type Parameters

    • DataType = any
    • ReturnType = any
    • NameType extends string = string

    Implemented by

    Properties

    interface MinimalJob<DataType, ReturnType, NameType> {
        attemptsMade: number;
        data: DataType;
        delay: number;
        failedReason: string;
        finishedOn?: number;
        id?: string;
        name: NameType;
        opts: JobsOptions;
        parent?: ParentKeys;
        parentKey?: string;
        processedOn?: number;
        progress: number | object;
        repeatJobKey?: string;
        returnvalue: ReturnType;
        stacktrace: string[];
        timestamp: number;
        get prefix(): string;
        get queueName(): string;
        get queueQualifiedName(): string;
        asJSON(): JobJson;
        asJSONSandbox(): JobJsonSandbox;
        log(logRow): Promise<number>;
        updateData(data): Promise<void>;
        updateProgress(progress): Promise<void>;
    }

    Type Parameters

    • DataType = any
    • ReturnType = any
    • NameType extends string = string

    Implemented by

    Properties

    attemptsMade data delay failedReason @@ -26,37 +26,37 @@

    Properties

    attemptsMade: number

    Number of attempts after the job has failed.

    Default Value

    0
     
    -
    data: DataType

    The payload for this job.

    -
    delay: number

    An amount of milliseconds to wait until this job can be processed.

    +
    data: DataType

    The payload for this job.

    +
    delay: number

    An amount of milliseconds to wait until this job can be processed.

    Default Value

    0
     
    -
    failedReason: string

    Reason for failing.

    -
    finishedOn?: number

    Timestamp for when the job finished (completed or failed).

    -
    id?: string
    name: NameType

    The name of the Job

    -

    The options object for this job.

    -
    parent?: ParentKeys

    Object that contains parentId (id) and parent queueKey.

    -
    parentKey?: string

    Fully qualified key (including the queue prefix) pointing to the parent of this job.

    -
    processedOn?: number

    Timestamp for when the job was processed.

    -
    progress: number | object

    The progress a job has performed so far.

    +
    failedReason: string

    Reason for failing.

    +
    finishedOn?: number

    Timestamp for when the job finished (completed or failed).

    +
    id?: string
    name: NameType

    The name of the Job

    +

    The options object for this job.

    +
    parent?: ParentKeys

    Object that contains parentId (id) and parent queueKey.

    +
    parentKey?: string

    Fully qualified key (including the queue prefix) pointing to the parent of this job.

    +
    processedOn?: number

    Timestamp for when the job was processed.

    +
    progress: number | object

    The progress a job has performed so far.

    Default Value

    0
     
    -
    repeatJobKey?: string

    Base repeat job key.

    -
    returnvalue: ReturnType

    The value returned by the processor when processing this job.

    +
    repeatJobKey?: string

    Base repeat job key.

    +
    returnvalue: ReturnType

    The value returned by the processor when processing this job.

    Default Value

    null
     
    -
    stacktrace: string[]

    Stacktrace for the error (for failed jobs).

    +
    stacktrace: string[]

    Stacktrace for the error (for failed jobs).

    Default Value

    null
     
    -
    timestamp: number

    Timestamp when the job was created (unless overridden with job options).

    -

    Accessors

    • get queueQualifiedName(): string
    • Returns string

      it includes the prefix, the namespace separator :, and queue name.

      +
    timestamp: number

    Timestamp when the job was created (unless overridden with job options).

    +

    Accessors

    Methods

    Methods

    • Logs one row of log data.

      Parameters

      • logRow: string

        string with log data to be logged.

        -

      Returns Promise<number>

    • Updates a job's data

      +

    Returns Promise<number>

    • Updates a job's data

      Parameters

      • data: DataType

        the data that will replace the current jobs data.

        -

      Returns Promise<void>

    • Updates a job's progress

      +

    Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file +

    Returns Promise<void>

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.MoveToDelayedOpts.html b/interfaces/v5.MoveToDelayedOpts.html index 745ab23c5c..c5d20a5311 100644 --- a/interfaces/v5.MoveToDelayedOpts.html +++ b/interfaces/v5.MoveToDelayedOpts.html @@ -1,2 +1,2 @@ -MoveToDelayedOpts | bullmq - v5.12.12

    Interface MoveToDelayedOpts

    interface MoveToDelayedOpts {
        skipAttempt?: boolean;
    }

    Properties

    Properties

    skipAttempt?: boolean

    Generated using TypeDoc

    \ No newline at end of file +MoveToDelayedOpts | bullmq - v5.12.12

    Interface MoveToDelayedOpts

    interface MoveToDelayedOpts {
        skipAttempt?: boolean;
    }

    Properties

    Properties

    skipAttempt?: boolean

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.MoveToWaitingChildrenOpts.html b/interfaces/v5.MoveToWaitingChildrenOpts.html index 2c181c3bd8..483aee255b 100644 --- a/interfaces/v5.MoveToWaitingChildrenOpts.html +++ b/interfaces/v5.MoveToWaitingChildrenOpts.html @@ -1,2 +1,2 @@ -MoveToWaitingChildrenOpts | bullmq - v5.12.12

    Interface MoveToWaitingChildrenOpts

    interface MoveToWaitingChildrenOpts {
        child?: {
            id: string;
            queue: string;
        };
    }

    Properties

    Properties

    child?: {
        id: string;
        queue: string;
    }

    Type declaration

    • id: string
    • queue: string

    Generated using TypeDoc

    \ No newline at end of file +MoveToWaitingChildrenOpts | bullmq - v5.12.12

    Interface MoveToWaitingChildrenOpts

    interface MoveToWaitingChildrenOpts {
        child?: {
            id: string;
            queue: string;
        };
    }

    Properties

    Properties

    child?: {
        id: string;
        queue: string;
    }

    Type declaration

    • id: string
    • queue: string

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.NodeOpts.html b/interfaces/v5.NodeOpts.html index 3c97a068af..cc61ae647c 100644 --- a/interfaces/v5.NodeOpts.html +++ b/interfaces/v5.NodeOpts.html @@ -1,11 +1,11 @@ -NodeOpts | bullmq - v5.12.12

    Interface NodeOpts

    interface NodeOpts {
        depth?: number;
        id: string;
        maxChildren?: number;
        prefix?: string;
        queueName: string;
    }

    Properties

    depth? +NodeOpts | bullmq - v5.12.12

    Interface NodeOpts

    interface NodeOpts {
        depth?: number;
        id: string;
        maxChildren?: number;
        prefix?: string;
        queueName: string;
    }

    Properties

    depth?: number

    Maximum depth or levels to visit in the tree.

    -
    id: string

    Root job id.

    -
    maxChildren?: number

    Maximum quantity of children per type (processed, unprocessed).

    -
    prefix?: string

    Prefix included in job key.

    -
    queueName: string

    Root job queue name.

    -

    Generated using TypeDoc

    \ No newline at end of file +
    id: string

    Root job id.

    +
    maxChildren?: number

    Maximum quantity of children per type (processed, unprocessed).

    +
    prefix?: string

    Prefix included in job key.

    +
    queueName: string

    Root job queue name.

    +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.ObliterateOpts.html b/interfaces/v5.ObliterateOpts.html index 86545fb1db..9620a3a855 100644 --- a/interfaces/v5.ObliterateOpts.html +++ b/interfaces/v5.ObliterateOpts.html @@ -1,9 +1,9 @@ -ObliterateOpts | bullmq - v5.12.12

    Interface ObliterateOpts

    interface ObliterateOpts {
        count?: number;
        force?: boolean;
    }

    Properties

    count? +ObliterateOpts | bullmq - v5.12.12

    Interface ObliterateOpts

    interface ObliterateOpts {
        count?: number;
        force?: boolean;
    }

    Properties

    Properties

    count?: number

    Use count with the maximum number of deleted keys per iteration

    Default Value

    1000
     
    -
    force?: boolean

    Use force = true to force obliteration even with active jobs in the queue

    +
    force?: boolean

    Use force = true to force obliteration even with active jobs in the queue

    Default Value

    false
     
    -

    Generated using TypeDoc

    \ No newline at end of file +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.Parent.html b/interfaces/v5.Parent.html index 4bfb435b54..ac45bc8991 100644 --- a/interfaces/v5.Parent.html +++ b/interfaces/v5.Parent.html @@ -1,7 +1,7 @@ Parent | bullmq - v5.12.12

    Interface Parent<T>

    Describes the parent for a Job.

    -
    interface Parent<T> {
        data?: T;
        name: string;
        opts?: JobsOptions;
        prefix?: string;
        queue?: string;
    }

    Type Parameters

    • T

    Properties

    interface Parent<T> {
        data?: T;
        name: string;
        opts?: JobsOptions;
        prefix?: string;
        queue?: string;
    }

    Type Parameters

    • T

    Properties

    data?: T
    name: string
    prefix?: string
    queue?: string

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    data?: T
    name: string
    prefix?: string
    queue?: string

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.ParentKeys.html b/interfaces/v5.ParentKeys.html index 5c932031e7..82bb7a53d2 100644 --- a/interfaces/v5.ParentKeys.html +++ b/interfaces/v5.ParentKeys.html @@ -1,3 +1,3 @@ -ParentKeys | bullmq - v5.12.12

    Interface ParentKeys

    interface ParentKeys {
        id: string;
        queueKey: string;
    }

    Properties

    id +ParentKeys | bullmq - v5.12.12

    Interface ParentKeys

    interface ParentKeys {
        id: string;
        queueKey: string;
    }

    Properties

    Properties

    id: string
    queueKey: string

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    id: string
    queueKey: string

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.ParentMessage.html b/interfaces/v5.ParentMessage.html index b144baa4cf..828efdf40a 100644 --- a/interfaces/v5.ParentMessage.html +++ b/interfaces/v5.ParentMessage.html @@ -1,5 +1,5 @@ -ParentMessage | bullmq - v5.12.12

    Interface ParentMessage

    interface ParentMessage {
        cmd: ChildCommand;
        err?: Error;
        job?: JobJson;
        value?: any;
    }

    Properties

    cmd +ParentMessage | bullmq - v5.12.12

    Interface ParentMessage

    interface ParentMessage {
        cmd: ChildCommand;
        err?: Error;
        job?: JobJson;
        value?: any;
    }

    Properties

    Properties

    err?: Error
    job?: JobJson
    value?: any

    Generated using TypeDoc

    \ No newline at end of file +

    Properties

    err?: Error
    job?: JobJson
    value?: any

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.QueueBaseOptions.html b/interfaces/v5.QueueBaseOptions.html index d85b4621d5..508f73f5ad 100644 --- a/interfaces/v5.QueueBaseOptions.html +++ b/interfaces/v5.QueueBaseOptions.html @@ -1,12 +1,12 @@ QueueBaseOptions | bullmq - v5.12.12

    Interface QueueBaseOptions

    Base Queue options

    -
    interface QueueBaseOptions {
        blockingConnection?: boolean;
        connection: ConnectionOptions;
        prefix?: string;
        skipVersionCheck?: boolean;
    }

    Hierarchy (view full)

    Properties

    interface QueueBaseOptions {
        blockingConnection?: boolean;
        connection: ConnectionOptions;
        prefix?: string;
        skipVersionCheck?: boolean;
    }

    Hierarchy (view full)

    Properties

    blockingConnection?: boolean

    Denotes commands should retry indefinitely.

    -
    connection: ConnectionOptions

    Options for connecting to a Redis instance.

    -
    prefix?: string

    Prefix for all queue keys.

    -
    skipVersionCheck?: boolean

    Avoid version validation to be greater or equal than v5.0.0.

    +
    connection: ConnectionOptions

    Options for connecting to a Redis instance.

    +
    prefix?: string

    Prefix for all queue keys.

    +
    skipVersionCheck?: boolean

    Avoid version validation to be greater or equal than v5.0.0.

    Default Value

    false
     
    -

    Generated using TypeDoc

    \ No newline at end of file +

    Generated using TypeDoc

    \ No newline at end of file diff --git a/interfaces/v5.QueueEventsListener.html b/interfaces/v5.QueueEventsListener.html index 42d6bae74b..36d8e8f389 100644 --- a/interfaces/v5.QueueEventsListener.html +++ b/interfaces/v5.QueueEventsListener.html @@ -1,4 +1,4 @@ -QueueEventsListener | bullmq - v5.12.12

    Interface QueueEventsListener

    interface QueueEventsListener {
        active: ((args, id) => void);
        added: ((args, id) => void);
        cleaned: ((args, id) => void);
        completed: ((args, id) => void);
        debounced: ((args, id) => void);
        delayed: ((args, id) => void);
        drained: ((id) => void);
        duplicated: ((args, id) => void);
        error: ((args) => void);
        failed: ((args, id) => void);
        ioredis:close: (() => void);
        paused: ((args, id) => void);
        progress: ((args, id) => void);
        removed: ((args, id) => void);
        resumed: ((args, id) => void);
        retries-exhausted: ((args, id) => void);
        stalled: ((args, id) => void);
        waiting: ((args, id) => void);
        waiting-children: ((args, id) => void);
    }

    Hierarchy (view full)

    Properties

    active +QueueEventsListener | bullmq - v5.12.12

    Interface QueueEventsListener

    interface QueueEventsListener {
        active: ((args, id) => void);
        added: ((args, id) => void);
        cleaned: ((args, id) => void);
        completed: ((args, id) => void);
        debounced: ((args, id) => void);
        delayed: ((args, id) => void);
        drained: ((id) => void);
        duplicated: ((args, id) => void);
        error: ((args) => void);
        failed: ((args, id) => void);
        ioredis:close: (() => void);
        paused: ((args, id) => void);
        progress: ((args, id) => void);
        removed: ((args, id) => void);
        resumed: ((args, id) => void);
        retries-exhausted: ((args, id) => void);
        stalled: ((args, id) => void);
        waiting: ((args, id) => void);
        waiting-children: ((args, id) => void);
    }

    Hierarchy (view full)

    Properties

    active added cleaned completed @@ -21,27 +21,27 @@

    This event is triggered when a job enters the 'active' state.

    Type declaration

      • (args, id): void
      • Listen to 'active' event.

        This event is triggered when a job enters the 'active' state.

        -

        Parameters

        • args: {
              jobId: string;
              prev?: string;
          }
          • jobId: string
          • Optional prev?: string
        • id: string

        Returns void

    added: ((args, id) => void)

    Listen to 'added' event.

    +

    Parameters

    • args: {
          jobId: string;
          prev?: string;
      }
      • jobId: string
      • Optional prev?: string
    • id: string

    Returns void

    added: ((args, id) => void)

    Listen to 'added' event.

    This event is triggered when a job is created.

    Type declaration

      • (args, id): void
      • Listen to 'added' event.

        This event is triggered when a job is created.

        -

        Parameters

        • args: {
              jobId: string;
              name: string;
          }
          • jobId: string
          • name: string
        • id: string

        Returns void

    cleaned: ((args, id) => void)

    Listen to 'cleaned' event.

    +

    Parameters

    • args: {
          jobId: string;
          name: string;
      }
      • jobId: string
      • name: string
    • id: string

    Returns void

    cleaned: ((args, id) => void)

    Listen to 'cleaned' event.

    This event is triggered when a cleaned method is triggered.

    Type declaration

      • (args, id): void
      • Listen to 'cleaned' event.

        This event is triggered when a cleaned method is triggered.

        -

        Parameters

        • args: {
              count: string;
          }
          • count: string
        • id: string

        Returns void

    completed: ((args, id) => void)

    Listen to 'completed' event.

    +

    Parameters

    • args: {
          count: string;
      }
      • count: string
    • id: string

    Returns void

    completed: ((args, id) => void)

    Listen to 'completed' event.

    This event is triggered when a job has successfully completed.

    Type declaration

      • (args, id): void
      • Listen to 'completed' event.

        This event is triggered when a job has successfully completed.

        -

        Parameters

        • args: {
              jobId: string;
              prev?: string;
              returnvalue: string;
          }
          • jobId: string
          • Optional prev?: string
          • returnvalue: string
        • id: string

        Returns void

    debounced: ((args, id) => void)

    Listen to 'debounced' event.

    +

    Parameters

    • args: {
          jobId: string;
          prev?: string;
          returnvalue: string;
      }
      • jobId: string
      • Optional prev?: string
      • returnvalue: string
    • id: string

    Returns void

    debounced: ((args, id) => void)

    Listen to 'debounced' event.

    This event is triggered when a job is debounced because debounceId still existed.

    Type declaration

      • (args, id): void
      • Listen to 'debounced' event.

        This event is triggered when a job is debounced because debounceId still existed.

        -

        Parameters

        • args: {
              debounceId: string;
              jobId: string;
          }
          • debounceId: string
          • jobId: string
        • id: string

        Returns void

    delayed: ((args, id) => void)

    Listen to 'delayed' event.

    +

    Parameters

    • args: {
          debounceId: string;
          jobId: string;
      }
      • debounceId: string
      • jobId: string
    • id: string

    Returns void

    delayed: ((args, id) => void)

    Listen to 'delayed' event.

    This event is triggered when a job is delayed.

    Type declaration

      • (args, id): void
      • Listen to 'delayed' event.

        This event is triggered when a job is delayed.

        -

        Parameters

        • args: {
              delay: number;
              jobId: string;
          }
          • delay: number
          • jobId: string
        • id: string

        Returns void

    drained: ((id) => void)

    Listen to 'drained' event.

    +

    Parameters

    • args: {
          delay: number;
          jobId: string;
      }
      • delay: number
      • jobId: string
    • id: string

    Returns void

    drained: ((id) => void)

    Listen to 'drained' event.

    This event is triggered when the queue has drained the waiting list. Note that there could still be delayed jobs waiting their timers to expire and this event will still be triggered as long as the waiting list has emptied.

    @@ -49,27 +49,27 @@

    This event is triggered when the queue has drained the waiting list. Note that there could still be delayed jobs waiting their timers to expire and this event will still be triggered as long as the waiting list has emptied.

    -

    Parameters

    • id: string

    Returns void

    duplicated: ((args, id) => void)

    Listen to 'duplicated' event.

    +

    Parameters

    • id: string

    Returns void

    duplicated: ((args, id) => void)

    Listen to 'duplicated' event.

    This event is triggered when a job is not created because it already exist.

    Type declaration

      • (args, id): void
      • Listen to 'duplicated' event.

        This event is triggered when a job is not created because it already exist.

        -

        Parameters

        • args: {
              jobId: string;
          }
          • jobId: string
        • id: string

        Returns void

    error: ((args) => void)

    Listen to 'error' event.

    +

    Parameters

    • args: {
          jobId: string;
      }
      • jobId: string
    • id: string

    Returns void

    error: ((args) => void)

    Listen to 'error' event.

    This event is triggered when an exception is thrown.

    Type declaration

      • (args): void
      • Listen to 'error' event.

        This event is triggered when an exception is thrown.

        -

        Parameters

        • args: Error

        Returns void

    failed: ((args, id) => void)

    Listen to 'failed' event.

    +

    Parameters

    • args: Error

    Returns void

    failed: ((args, id) => void)

    Listen to 'failed' event.

    This event is triggered when a job has thrown an exception.

    Type declaration

      • (args, id): void
      • Listen to 'failed' event.

        This event is triggered when a job has thrown an exception.

        -

        Parameters

        • args: {
              failedReason: string;
              jobId: string;
              prev?: string;
          }
          • failedReason: string
          • jobId: string
          • Optional prev?: string
        • id: string

        Returns void

    ioredis:close: (() => void)

    Listen to 'ioredis:close' event.

    +

    Parameters

    • args: {
          failedReason: string;
          jobId: string;
          prev?: string;
      }
      • failedReason: string
      • jobId: string
      • Optional prev?: string
    • id: string

    Returns void

    ioredis:close: (() => void)

    Listen to 'ioredis:close' event.

    This event is triggered when ioredis is closed.

    Type declaration

      • (): void
      • Listen to 'ioredis:close' event.

        This event is triggered when ioredis is closed.

        -

        Returns void

    paused: ((args, id) => void)

    Listen to 'paused' event.

    +

    Returns void

    paused: ((args, id) => void)

    Listen to 'paused' event.

    This event is triggered when a queue is paused.

    Type declaration

      • (args, id): void
      • Listen to 'paused' event.

        This event is triggered when a queue is paused.

        -

        Parameters

        • args: {}
          • id: string

          Returns void

      progress: ((args, id) => void)

      Listen to 'progress' event.

      +

      Parameters

      • args: {}
        • id: string

        Returns void

        progress: ((args, id) => void)

        Listen to 'progress' event.

        This event is triggered when a job updates it progress, i.e. the Job##updateProgress() method is called. This is useful to notify progress or any other data from within a processor to the rest of the @@ -79,21 +79,21 @@ Job##updateProgress() method is called. This is useful to notify progress or any other data from within a processor to the rest of the world.

        -

        Parameters

        • args: {
              data: number | object;
              jobId: string;
          }
          • data: number | object
          • jobId: string
        • id: string

        Returns void

        removed: ((args, id) => void)

        Listen to 'removed' event.

        +

        Parameters

        • args: {
              data: number | object;
              jobId: string;
          }
          • data: number | object
          • jobId: string
        • id: string

        Returns void

        removed: ((args, id) => void)

        Listen to 'removed' event.

        This event is triggered when a job has been manually removed from the queue.

        Type declaration

          • (args, id): void
          • Listen to 'removed' event.

            This event is triggered when a job has been manually removed from the queue.

            -

            Parameters

            • args: {
                  jobId: string;
                  prev: string;
              }
              • jobId: string
              • prev: string
            • id: string

            Returns void

        resumed: ((args, id) => void)

        Listen to 'resumed' event.

        +

        Parameters

        • args: {
              jobId: string;
              prev: string;
          }
          • jobId: string
          • prev: string
        • id: string

        Returns void

        resumed: ((args, id) => void)

        Listen to 'resumed' event.

        This event is triggered when a queue is resumed.

        Type declaration

          • (args, id): void
          • Listen to 'resumed' event.

            This event is triggered when a queue is resumed.

            -

            Parameters

            • args: {}
              • id: string

              Returns void

          retries-exhausted: ((args, id) => void)

          Listen to 'retries-exhausted' event.

          +

          Parameters

          • args: {}
            • id: string

            Returns void

            retries-exhausted: ((args, id) => void)

            Listen to 'retries-exhausted' event.

            This event is triggered when a job has retried the maximum attempts.

            Type declaration

              • (args, id): void
              • Listen to 'retries-exhausted' event.

                This event is triggered when a job has retried the maximum attempts.

                -

                Parameters

                • args: {
                      attemptsMade: string;
                      jobId: string;
                  }
                  • attemptsMade: string
                  • jobId: string
                • id: string

                Returns void

            stalled: ((args, id) => void)

            Listen to 'stalled' event.

            +

            Parameters

            • args: {
                  attemptsMade: string;
                  jobId: string;
              }
              • attemptsMade: string
              • jobId: string
            • id: string

            Returns void

            stalled: ((args, id) => void)

            Listen to 'stalled' event.

            This event is triggered when a job has been moved from 'active' back to 'waiting'/'failed' due to the processor not being able to renew the lock on the said job.

            @@ -101,12 +101,12 @@

            This event is triggered when a job has been moved from 'active' back to 'waiting'/'failed' due to the processor not being able to renew the lock on the said job.

            -

            Parameters

            • args: {
                  jobId: string;
              }
              • jobId: string
            • id: string

            Returns void

            waiting: ((args, id) => void)

            Listen to 'waiting' event.

            +

            Parameters

            • args: {
                  jobId: string;
              }
              • jobId: string
            • id: string

            Returns void

            waiting: ((args, id) => void)

            Listen to 'waiting' event.

            This event is triggered when a job enters the 'waiting' state.

            Type declaration

              • (args, id): void
              • Listen to 'waiting' event.

                This event is triggered when a job enters the 'waiting' state.

                -

                Parameters

                • args: {
                      jobId: string;
                      prev?: string;
                  }
                  • jobId: string
                  • Optional prev?: string
                • id: string

                Returns void

            waiting-children: ((args, id) => void)

            Listen to 'waiting-children' event.

            +

            Parameters

            • args: {
                  jobId: string;
                  prev?: string;
              }
              • jobId: string
              • Optional prev?: string
            • id: string

            Returns void

            waiting-children: ((args, id) => void)

            Listen to 'waiting-children' event.

            This event is triggered when a job enters the 'waiting-children' state.

            Type declaration

              • (args, id): void
              • Listen to 'waiting-children' event.

                This event is triggered when a job enters the 'waiting-children' state.

                -

                Parameters

                • args: {
                      jobId: string;
                  }
                  • jobId: string
                • id: string

                Returns void

            Generated using TypeDoc

            \ No newline at end of file +

            Parameters

            Returns void

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.QueueEventsOptions.html b/interfaces/v5.QueueEventsOptions.html index 7b075a377d..06db3dab69 100644 --- a/interfaces/v5.QueueEventsOptions.html +++ b/interfaces/v5.QueueEventsOptions.html @@ -1,5 +1,5 @@ QueueEventsOptions | bullmq - v5.12.12

            Interface QueueEventsOptions

            Options for QueueEvents

            -
            interface QueueEventsOptions {
                autorun?: boolean;
                blockingConnection?: boolean;
                blockingTimeout?: number;
                connection: ConnectionOptions;
                lastEventId?: string;
                prefix?: string;
                skipVersionCheck?: boolean;
            }

            Hierarchy (view full)

            Properties

            interface QueueEventsOptions {
                autorun?: boolean;
                blockingConnection?: boolean;
                blockingTimeout?: number;
                connection: ConnectionOptions;
                lastEventId?: string;
                prefix?: string;
                skipVersionCheck?: boolean;
            }

            Hierarchy (view full)

            Properties

            autorun?: boolean

            Condition to start listening to events at instance creation.

            -
            blockingConnection?: boolean

            Denotes commands should retry indefinitely.

            -
            blockingTimeout?: number

            Timeout for the blocking XREAD call to the events stream.

            -
            connection: ConnectionOptions

            Options for connecting to a Redis instance.

            -
            lastEventId?: string

            Last event Id. If provided it is possible to continue +

            blockingConnection?: boolean

            Denotes commands should retry indefinitely.

            +
            blockingTimeout?: number

            Timeout for the blocking XREAD call to the events stream.

            +
            connection: ConnectionOptions

            Options for connecting to a Redis instance.

            +
            lastEventId?: string

            Last event Id. If provided it is possible to continue consuming events from a known Id instead of from the last produced event.

            -
            prefix?: string

            Prefix for all queue keys.

            -
            skipVersionCheck?: boolean

            Avoid version validation to be greater or equal than v5.0.0.

            +
            prefix?: string

            Prefix for all queue keys.

            +
            skipVersionCheck?: boolean

            Avoid version validation to be greater or equal than v5.0.0.

            Default Value

            false
             
            -

            Generated using TypeDoc

            \ No newline at end of file +

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.QueueListener.html b/interfaces/v5.QueueListener.html index c21c08092c..21bb8e107c 100644 --- a/interfaces/v5.QueueListener.html +++ b/interfaces/v5.QueueListener.html @@ -1,4 +1,4 @@ -QueueListener | bullmq - v5.12.12

            Interface QueueListener<DataType, ResultType, NameType>

            interface QueueListener<DataType, ResultType, NameType> {
                cleaned: ((jobs, type) => void);
                error: ((err) => void);
                ioredis:close: (() => void);
                paused: (() => void);
                progress: ((job, progress) => void);
                removed: ((job) => void);
                resumed: (() => void);
                waiting: ((job) => void);
            }

            Type Parameters

            • DataType
            • ResultType
            • NameType extends string

            Hierarchy (view full)

            Properties

            cleaned +QueueListener | bullmq - v5.12.12

            Interface QueueListener<DataType, ResultType, NameType>

            interface QueueListener<DataType, ResultType, NameType> {
                cleaned: ((jobs, type) => void);
                error: ((err) => void);
                ioredis:close: (() => void);
                paused: (() => void);
                progress: ((job, progress) => void);
                removed: ((job) => void);
                resumed: (() => void);
                waiting: ((job) => void);
            }

            Type Parameters

            • DataType
            • ResultType
            • NameType extends string

            Hierarchy (view full)

            Properties

            cleaned error ioredis:close paused @@ -10,32 +10,32 @@

            This event is triggered when the queue calls clean method.

            Type declaration

              • (jobs, type): void
              • Listen to 'cleaned' event.

                This event is triggered when the queue calls clean method.

                -

                Parameters

                • jobs: string[]
                • type: string

                Returns void

            error: ((err) => void)

            Listen to 'error' event.

            +

            Parameters

            • jobs: string[]
            • type: string

            Returns void

            error: ((err) => void)

            Listen to 'error' event.

            This event is triggered when an error is thrown.

            Type declaration

              • (err): void
              • Listen to 'error' event.

                This event is triggered when an error is thrown.

                -

                Parameters

                • err: Error

                Returns void

            ioredis:close: (() => void)

            Listen to 'ioredis:close' event.

            +

            Parameters

            • err: Error

            Returns void

            ioredis:close: (() => void)

            Listen to 'ioredis:close' event.

            This event is triggered when ioredis is closed.

            Type declaration

              • (): void
              • Listen to 'ioredis:close' event.

                This event is triggered when ioredis is closed.

                -

                Returns void

            paused: (() => void)

            Listen to 'paused' event.

            +

            Returns void

            paused: (() => void)

            Listen to 'paused' event.

            This event is triggered when the queue is paused.

            Type declaration

              • (): void
              • Listen to 'paused' event.

                This event is triggered when the queue is paused.

                -

                Returns void

            progress: ((job, progress) => void)

            Listen to 'progress' event.

            +

            Returns void

            progress: ((job, progress) => void)

            Listen to 'progress' event.

            This event is triggered when the job updates its progress.

            Type declaration

              • (job, progress): void
              • Listen to 'progress' event.

                This event is triggered when the job updates its progress.

                -

                Parameters

                Returns void

            removed: ((job) => void)

            Listen to 'removed' event.

            +

            Parameters

            Returns void

            removed: ((job) => void)

            Listen to 'removed' event.

            This event is triggered when a job is removed.

            Type declaration

              • (job): void
              • Listen to 'removed' event.

                This event is triggered when a job is removed.

                -

                Parameters

                Returns void

            resumed: (() => void)

            Listen to 'resumed' event.

            +

            Parameters

            Returns void

            resumed: (() => void)

            Listen to 'resumed' event.

            This event is triggered when the queue is resumed.

            Type declaration

              • (): void
              • Listen to 'resumed' event.

                This event is triggered when the queue is resumed.

                -

                Returns void

            waiting: ((job) => void)

            Listen to 'waiting' event.

            +

            Returns void

            waiting: ((job) => void)

            Listen to 'waiting' event.

            This event is triggered when the queue creates a new job.

            Type declaration

              • (job): void
              • Listen to 'waiting' event.

                This event is triggered when the queue creates a new job.

                -

                Parameters

                Returns void

            Generated using TypeDoc

            \ No newline at end of file +

            Parameters

            Returns void

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.QueueOptions.html b/interfaces/v5.QueueOptions.html index e567695bb3..5028b0efd3 100644 --- a/interfaces/v5.QueueOptions.html +++ b/interfaces/v5.QueueOptions.html @@ -1,5 +1,5 @@ QueueOptions | bullmq - v5.12.12

            Interface QueueOptions

            Options for the Queue class.

            -
            interface QueueOptions {
                blockingConnection?: boolean;
                connection: ConnectionOptions;
                defaultJobOptions?: DefaultJobOptions;
                prefix?: string;
                settings?: AdvancedRepeatOptions;
                skipVersionCheck?: boolean;
                streams?: {
                    events: {
                        maxLen: number;
                    };
                };
            }

            Hierarchy (view full)

            Properties

            interface QueueOptions {
                blockingConnection?: boolean;
                connection: ConnectionOptions;
                defaultJobOptions?: DefaultJobOptions;
                prefix?: string;
                settings?: AdvancedRepeatOptions;
                skipVersionCheck?: boolean;
                streams?: {
                    events: {
                        maxLen: number;
                    };
                };
            }

            Hierarchy (view full)

            Properties

            blockingConnection?: boolean

            Denotes commands should retry indefinitely.

            -
            connection: ConnectionOptions

            Options for connecting to a Redis instance.

            -
            defaultJobOptions?: DefaultJobOptions
            prefix?: string

            Prefix for all queue keys.

            -
            skipVersionCheck?: boolean

            Avoid version validation to be greater or equal than v5.0.0.

            +
            connection: ConnectionOptions

            Options for connecting to a Redis instance.

            +
            defaultJobOptions?: DefaultJobOptions
            prefix?: string

            Prefix for all queue keys.

            +
            skipVersionCheck?: boolean

            Avoid version validation to be greater or equal than v5.0.0.

            Default Value

            false
             
            -
            streams?: {
                events: {
                    maxLen: number;
                };
            }

            Options for the streams used internally in BullMQ.

            +
            streams?: {
                events: {
                    maxLen: number;
                };
            }

            Options for the streams used internally in BullMQ.

            Type declaration

            • events: {
                  maxLen: number;
              }

              Options for the events stream.

              • maxLen: number

                Max approximated length for streams. Default is 10 000 events.

                -

            Generated using TypeDoc

            \ No newline at end of file +

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.RateLimiterOptions.html b/interfaces/v5.RateLimiterOptions.html index 3d19b6294c..530149c45e 100644 --- a/interfaces/v5.RateLimiterOptions.html +++ b/interfaces/v5.RateLimiterOptions.html @@ -1,7 +1,7 @@ -RateLimiterOptions | bullmq - v5.12.12

            Interface RateLimiterOptions

            interface RateLimiterOptions {
                duration: number;
                max: number;
            }

            Properties

            duration +RateLimiterOptions | bullmq - v5.12.12

            Interface RateLimiterOptions

            interface RateLimiterOptions {
                duration: number;
                max: number;
            }

            Properties

            Properties

            duration: number

            Time in milliseconds. During this time, a maximum of max jobs will be processed.

            -
            max: number

            Max number of jobs to process in the time period +

            max: number

            Max number of jobs to process in the time period specified in duration.

            -

            Generated using TypeDoc

            \ No newline at end of file +

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.RawCommand.html b/interfaces/v5.RawCommand.html index 62ba434635..682b8fc2aa 100644 --- a/interfaces/v5.RawCommand.html +++ b/interfaces/v5.RawCommand.html @@ -1,4 +1,4 @@ -RawCommand | bullmq - v5.12.12

            Interface RawCommand

            interface RawCommand {
                content: string;
                keys: number;
                name: string;
            }

            Properties

            content +RawCommand | bullmq - v5.12.12

            Interface RawCommand

            interface RawCommand {
                content: string;
                keys: number;
                name: string;
            }

            Properties

            Properties

            content: string
            keys: number
            name: string

            Generated using TypeDoc

            \ No newline at end of file +

            Properties

            content: string
            keys: number
            name: string

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.RepeatBaseOptions.html b/interfaces/v5.RepeatBaseOptions.html index 41f224f67f..a4c154e56a 100644 --- a/interfaces/v5.RepeatBaseOptions.html +++ b/interfaces/v5.RepeatBaseOptions.html @@ -1,13 +1,13 @@ RepeatBaseOptions | bullmq - v5.12.12

            Interface RepeatBaseOptions

            Options for the Repeat class.

            -
            interface RepeatBaseOptions {
                blockingConnection?: boolean;
                connection: ConnectionOptions;
                prefix?: string;
                settings?: AdvancedRepeatOptions;
                skipVersionCheck?: boolean;
            }

            Hierarchy (view full)

            Properties

            interface RepeatBaseOptions {
                blockingConnection?: boolean;
                connection: ConnectionOptions;
                prefix?: string;
                settings?: AdvancedRepeatOptions;
                skipVersionCheck?: boolean;
            }

            Hierarchy (view full)

            Properties

            blockingConnection?: boolean

            Denotes commands should retry indefinitely.

            -
            connection: ConnectionOptions

            Options for connecting to a Redis instance.

            -
            prefix?: string

            Prefix for all queue keys.

            -
            skipVersionCheck?: boolean

            Avoid version validation to be greater or equal than v5.0.0.

            +
            connection: ConnectionOptions

            Options for connecting to a Redis instance.

            +
            prefix?: string

            Prefix for all queue keys.

            +
            skipVersionCheck?: boolean

            Avoid version validation to be greater or equal than v5.0.0.

            Default Value

            false
             
            -

            Generated using TypeDoc

            \ No newline at end of file +

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.RepeatOptions.html b/interfaces/v5.RepeatOptions.html index cdcaabe8b9..a3dcedf960 100644 --- a/interfaces/v5.RepeatOptions.html +++ b/interfaces/v5.RepeatOptions.html @@ -1,6 +1,6 @@ RepeatOptions | bullmq - v5.12.12

            Interface RepeatOptions

            Settings for repeatable jobs

            interface RepeatOptions {
                count?: number;
                every?: number;
                immediately?: boolean;
                jobId?: string;
                key?: string;
                limit?: number;
                offset?: number;
                pattern?: string;
                prevMillis?: number;
            }

            Hierarchy

            • Omit<ParserOptions, "iterator">
              • RepeatOptions

            Properties

            interface RepeatOptions {
                count?: number;
                every?: number;
                immediately?: boolean;
                jobId?: string;
                key?: string;
                limit?: number;
                offset?: number;
                pattern?: string;
                prevMillis?: number;
            }

            Hierarchy

            • Omit<ParserOptions, "iterator">
              • RepeatOptions

            Properties

            Properties

            count?: number

            The start value for the repeat iteration count.

            -
            every?: number

            Repeat after this amount of milliseconds +

            every?: number

            Repeat after this amount of milliseconds (pattern setting cannot be used together with this setting.)

            -
            immediately?: boolean

            Repeated job should start right now +

            immediately?: boolean

            Repeated job should start right now ( work only with every settings)

            -
            jobId?: string
            key?: string

            Custom repeatable key. This is the key that holds the "metadata" +

            jobId?: string
            key?: string

            Custom repeatable key. This is the key that holds the "metadata" of a given repeatable job. This key is normally auto-generated but it is sometimes useful to specify a custom key for easier retrieval of repeatable jobs.

            -
            limit?: number

            Number of times the job should repeat at max.

            -
            offset?: number
            pattern?: string

            A repeat pattern

            -
            prevMillis?: number

            Generated using TypeDoc

            \ No newline at end of file +
            limit?: number

            Number of times the job should repeat at max.

            +
            offset?: number
            pattern?: string

            A repeat pattern

            +
            prevMillis?: number

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.SandboxedJob.html b/interfaces/v5.SandboxedJob.html index 59d793ad7b..98f6ab4594 100644 --- a/interfaces/v5.SandboxedJob.html +++ b/interfaces/v5.SandboxedJob.html @@ -1,5 +1,5 @@ SandboxedJob | bullmq - v5.12.12

            Interface SandboxedJob<T, R>

            interface SandboxedJob<T, R> {
                attemptsMade: number;
                attemptsStarted: number;
                data: T;
                debounceId?: string;
                failedReason: string;
                finishedOn?: number;
                id: string;
                log: ((row) => void);
                moveToDelayed: ((timestamp, token?) => Promise<void>);
                name: string;
                opts: JobsOptions;
                parent?: ParentKeys;
                parentKey?: string;
                prefix: string;
                processedBy?: string;
                processedOn?: number;
                progress: number | object;
                queueName: string;
                repeatJobKey?: string;
                returnValue: R;
                returnvalue: string;
                stacktrace: string;
                timestamp: number;
                updateData: ((data) => Promise<void>);
                updateProgress: ((value) => Promise<void>);
            }

            Type Parameters

            • T = any
            • R = any

            Hierarchy

            Properties

            interface SandboxedJob<T, R> {
                attemptsMade: number;
                attemptsStarted: number;
                data: T;
                debounceId?: string;
                failedReason: string;
                finishedOn?: number;
                id: string;
                log: ((row) => void);
                moveToDelayed: ((timestamp, token?) => Promise<void>);
                name: string;
                opts: JobsOptions;
                parent?: ParentKeys;
                parentKey?: string;
                prefix: string;
                processedBy?: string;
                processedOn?: number;
                progress: number | object;
                queueName: string;
                repeatJobKey?: string;
                returnValue: R;
                returnvalue: string;
                stacktrace: string;
                timestamp: number;
                updateData: ((data) => Promise<void>);
                updateProgress: ((value) => Promise<void>);
            }

            Type Parameters

            • T = any
            • R = any

            Hierarchy

            Properties

            attemptsMade: number
            attemptsStarted: number
            data: T
            debounceId?: string
            failedReason: string
            finishedOn?: number
            id: string
            log: ((row) => void)

            Type declaration

              • (row): void
              • Parameters

                • row: any

                Returns void

            moveToDelayed: ((timestamp, token?) => Promise<void>)

            Type declaration

              • (timestamp, token?): Promise<void>
              • Parameters

                • timestamp: number
                • Optional token: string

                Returns Promise<void>

            name: string
            parent?: ParentKeys
            parentKey?: string
            prefix: string
            processedBy?: string
            processedOn?: number
            progress: number | object
            queueName: string
            repeatJobKey?: string
            returnValue: R
            returnvalue: string
            stacktrace: string
            timestamp: number
            updateData: ((data) => Promise<void>)

            Type declaration

              • (data): Promise<void>
              • Parameters

                • data: any

                Returns Promise<void>

            updateProgress: ((value) => Promise<void>)

            Type declaration

              • (value): Promise<void>
              • Parameters

                • value: number | object

                Returns Promise<void>

            Generated using TypeDoc

            \ No newline at end of file +

            Properties

            attemptsMade: number
            attemptsStarted: number
            data: T
            debounceId?: string
            failedReason: string
            finishedOn?: number
            id: string
            log: ((row) => void)

            Type declaration

              • (row): void
              • Parameters

                • row: any

                Returns void

            moveToDelayed: ((timestamp, token?) => Promise<void>)

            Type declaration

              • (timestamp, token?): Promise<void>
              • Parameters

                • timestamp: number
                • Optional token: string

                Returns Promise<void>

            name: string
            parent?: ParentKeys
            parentKey?: string
            prefix: string
            processedBy?: string
            processedOn?: number
            progress: number | object
            queueName: string
            repeatJobKey?: string
            returnValue: R
            returnvalue: string
            stacktrace: string
            timestamp: number
            updateData: ((data) => Promise<void>)

            Type declaration

              • (data): Promise<void>
              • Parameters

                • data: any

                Returns Promise<void>

            updateProgress: ((value) => Promise<void>)

            Type declaration

              • (value): Promise<void>
              • Parameters

                • value: number | object

                Returns Promise<void>

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.WorkerListener.html b/interfaces/v5.WorkerListener.html index 74821f1336..b4884fc868 100644 --- a/interfaces/v5.WorkerListener.html +++ b/interfaces/v5.WorkerListener.html @@ -1,4 +1,4 @@ -WorkerListener | bullmq - v5.12.12

            Interface WorkerListener<DataType, ResultType, NameType>

            interface WorkerListener<DataType, ResultType, NameType> {
                active: ((job, prev) => void);
                closed: (() => void);
                closing: ((msg) => void);
                completed: ((job, result, prev) => void);
                drained: (() => void);
                error: ((failedReason) => void);
                failed: ((job, error, prev) => void);
                ioredis:close: (() => void);
                paused: (() => void);
                progress: ((job, progress) => void);
                ready: (() => void);
                resumed: (() => void);
                stalled: ((jobId, prev) => void);
            }

            Type Parameters

            • DataType = any
            • ResultType = any
            • NameType extends string = string

            Hierarchy (view full)

            Properties

            active +WorkerListener | bullmq - v5.12.12

            Interface WorkerListener<DataType, ResultType, NameType>

            interface WorkerListener<DataType, ResultType, NameType> {
                active: ((job, prev) => void);
                closed: (() => void);
                closing: ((msg) => void);
                completed: ((job, result, prev) => void);
                drained: (() => void);
                error: ((failedReason) => void);
                failed: ((job, error, prev) => void);
                ioredis:close: (() => void);
                paused: (() => void);
                progress: ((job, progress) => void);
                ready: (() => void);
                resumed: (() => void);
                stalled: ((jobId, prev) => void);
            }

            Type Parameters

            • DataType = any
            • ResultType = any
            • NameType extends string = string

            Hierarchy (view full)

            Properties

            active closed closing completed @@ -15,19 +15,19 @@

            This event is triggered when a job enters the 'active' state.

            Type declaration

              • (job, prev): void
              • Listen to 'active' event.

                This event is triggered when a job enters the 'active' state.

                -

                Parameters

                Returns void

            closed: (() => void)

            Listen to 'closing' event.

            +

            Parameters

            Returns void

            closed: (() => void)

            Listen to 'closing' event.

            This event is triggered when the worker is closed.

            Type declaration

              • (): void
              • Listen to 'closing' event.

                This event is triggered when the worker is closed.

                -

                Returns void

            closing: ((msg) => void)

            Listen to 'closing' event.

            +

            Returns void

            closing: ((msg) => void)

            Listen to 'closing' event.

            This event is triggered when the worker is closing.

            Type declaration

              • (msg): void
              • Listen to 'closing' event.

                This event is triggered when the worker is closing.

                -

                Parameters

                • msg: string

                Returns void

            completed: ((job, result, prev) => void)

            Listen to 'completed' event.

            +

            Parameters

            • msg: string

            Returns void

            completed: ((job, result, prev) => void)

            Listen to 'completed' event.

            This event is triggered when a job has successfully completed.

            Type declaration

              • (job, result, prev): void
              • Listen to 'completed' event.

                This event is triggered when a job has successfully completed.

                -

                Parameters

                Returns void

            drained: (() => void)

            Listen to 'drained' event.

            +

            Parameters

            Returns void

            drained: (() => void)

            Listen to 'drained' event.

            This event is triggered when the queue has drained the waiting list. Note that there could still be delayed jobs waiting their timers to expire and this event will still be triggered as long as the waiting list has emptied.

            @@ -35,11 +35,11 @@

            This event is triggered when the queue has drained the waiting list. Note that there could still be delayed jobs waiting their timers to expire and this event will still be triggered as long as the waiting list has emptied.

            -

            Returns void

            error: ((failedReason) => void)

            Listen to 'error' event.

            +

            Returns void

            error: ((failedReason) => void)

            Listen to 'error' event.

            This event is triggered when an error is throw.

            Type declaration

              • (failedReason): void
              • Listen to 'error' event.

                This event is triggered when an error is throw.

                -

                Parameters

                • failedReason: Error

                Returns void

            failed: ((job, error, prev) => void)

            Listen to 'failed' event.

            +

            Parameters

            • failedReason: Error

            Returns void

            failed: ((job, error, prev) => void)

            Listen to 'failed' event.

            This event is triggered when a job has thrown an exception. Note: job parameter could be received as undefined when an stalled job reaches the stalled limit and it is deleted by the removeOnFail option.

            @@ -47,15 +47,15 @@

            This event is triggered when a job has thrown an exception. Note: job parameter could be received as undefined when an stalled job reaches the stalled limit and it is deleted by the removeOnFail option.

            -

            Parameters

            Returns void

            ioredis:close: (() => void)

            Listen to 'ioredis:close' event.

            +

            Parameters

            Returns void

            ioredis:close: (() => void)

            Listen to 'ioredis:close' event.

            This event is triggered when ioredis is closed.

            Type declaration

              • (): void
              • Listen to 'ioredis:close' event.

                This event is triggered when ioredis is closed.

                -

                Returns void

            paused: (() => void)

            Listen to 'paused' event.

            +

            Returns void

            paused: (() => void)

            Listen to 'paused' event.

            This event is triggered when the queue is paused.

            Type declaration

              • (): void
              • Listen to 'paused' event.

                This event is triggered when the queue is paused.

                -

                Returns void

            progress: ((job, progress) => void)

            Listen to 'progress' event.

            +

            Returns void

            progress: ((job, progress) => void)

            Listen to 'progress' event.

            This event is triggered when a job updates it progress, i.e. the Job##updateProgress() method is called. This is useful to notify progress or any other data from within a processor to the rest of the @@ -65,18 +65,18 @@ Job##updateProgress() method is called. This is useful to notify progress or any other data from within a processor to the rest of the world.

            -

            Parameters

            Returns void

            ready: (() => void)

            Listen to 'ready' event.

            +

            Parameters

            Returns void

            ready: (() => void)

            Listen to 'ready' event.

            This event is triggered when blockingConnection is ready.

            Type declaration

              • (): void
              • Listen to 'ready' event.

                This event is triggered when blockingConnection is ready.

                -

                Returns void

            resumed: (() => void)

            Listen to 'resumed' event.

            +

            Returns void

            resumed: (() => void)

            Listen to 'resumed' event.

            This event is triggered when the queue is resumed.

            Type declaration

              • (): void
              • Listen to 'resumed' event.

                This event is triggered when the queue is resumed.

                -

                Returns void

            stalled: ((jobId, prev) => void)

            Listen to 'stalled' event.

            +

            Returns void

            stalled: ((jobId, prev) => void)

            Listen to 'stalled' event.

            This event is triggered when a job has stalled and has been moved back to the wait list.

            Type declaration

              • (jobId, prev): void
              • Listen to 'stalled' event.

                This event is triggered when a job has stalled and has been moved back to the wait list.

                -

                Parameters

                • jobId: string
                • prev: string

                Returns void

            Generated using TypeDoc

            \ No newline at end of file +

            Parameters

            Returns void

            Generated using TypeDoc

            \ No newline at end of file diff --git a/interfaces/v5.WorkerOptions.html b/interfaces/v5.WorkerOptions.html index b6da62c869..d282a383a6 100644 --- a/interfaces/v5.WorkerOptions.html +++ b/interfaces/v5.WorkerOptions.html @@ -1,5 +1,5 @@ WorkerOptions | bullmq - v5.12.12

            Interface WorkerOptions

            Base Queue options

            -
            interface WorkerOptions {
                autorun?: boolean;
                blockingConnection?: boolean;
                concurrency?: number;
                connection: ConnectionOptions;
                drainDelay?: number;
                limiter?: RateLimiterOptions;
                lockDuration?: number;
                lockRenewTime?: number;
                maxStalledCount?: number;
                metrics?: MetricsOptions;
                name?: string;
                prefix?: string;
                removeOnComplete?: KeepJobs;
                removeOnFail?: KeepJobs;
                runRetryDelay?: number;
                settings?: AdvancedOptions;
                skipLockRenewal?: boolean;
                skipStalledCheck?: boolean;
                skipVersionCheck?: boolean;
                stalledInterval?: number;
                useWorkerThreads?: boolean;
            }

            Hierarchy (view full)

            Properties

            interface WorkerOptions {
                autorun?: boolean;
                blockingConnection?: boolean;
                concurrency?: number;
                connection: ConnectionOptions;
                drainDelay?: number;
                limiter?: RateLimiterOptions;
                lockDuration?: number;
                lockRenewTime?: number;
                maxStalledCount?: number;
                metrics?: MetricsOptions;
                name?: string;
                prefix?: string;
                removeOnComplete?: KeepJobs;
                removeOnFail?: KeepJobs;
                runRetryDelay?: number;
                settings?: AdvancedOptions;
                skipLockRenewal?: boolean;
                skipStalledCheck?: boolean;
                skipVersionCheck?: boolean;
                stalledInterval?: number;
                useWorkerThreads?: boolean;
            }

            Hierarchy (view full)

            Properties

            Properties

            autorun?: boolean

            Condition to start processor at instance creation.

            Default

            true
             
            -
            blockingConnection?: boolean

            Denotes commands should retry indefinitely.

            -
            concurrency?: number

            Amount of jobs that a single worker is allowed to work on +

            blockingConnection?: boolean

            Denotes commands should retry indefinitely.

            +
            concurrency?: number

            Amount of jobs that a single worker is allowed to work on in parallel.

            connection: ConnectionOptions

            Options for connecting to a Redis instance.

            -
            drainDelay?: number

            Number of seconds to long poll for jobs when the queue is empty.

            +
            connection: ConnectionOptions

            Options for connecting to a Redis instance.

            +
            drainDelay?: number

            Number of seconds to long poll for jobs when the queue is empty.

            Default

            5
             
            -

            Enable rate limiter

            +

            Enable rate limiter

            lockDuration?: number

            Duration of the lock for the job in milliseconds. The lock represents that +

            lockDuration?: number

            Duration of the lock for the job in milliseconds. The lock represents that a worker is processing the job. If the lock is lost, the job will be eventually be picked up by the stalled checker and move back to wait so that another worker can process it again.

            Default

            30000
             
            -
            lockRenewTime?: number

            The time in milliseconds before the lock is automatically renewed.

            +
            lockRenewTime?: number

            The time in milliseconds before the lock is automatically renewed.

            It is not recommended to modify this value, which is by default set to halv the lockDuration value, which is optimal for most use cases.

            -
            maxStalledCount?: number

            Amount of times a job can be recovered from a stalled state +

            maxStalledCount?: number

            Amount of times a job can be recovered from a stalled state to the wait state. If this is exceeded, the job is moved to failed.

            Default

            1
             
            -
            metrics?: MetricsOptions

            Enable collect metrics.

            +
            metrics?: MetricsOptions

            Enable collect metrics.

            name?: string

            Optional worker name. The name will be stored on every job +

            name?: string

            Optional worker name. The name will be stored on every job processed by this worker instance, and can be used to monitor which worker is processing or has processed a given job.

            -
            prefix?: string

            Prefix for all queue keys.

            -
            removeOnComplete?: KeepJobs

            You can provide an object specifying max +

            prefix?: string

            Prefix for all queue keys.

            +
            removeOnComplete?: KeepJobs

            You can provide an object specifying max age and/or count to keep. Default behavior is to keep the job in the completed set.

            -
            removeOnFail?: KeepJobs

            You can provide an object specifying max +

            removeOnFail?: KeepJobs

            You can provide an object specifying max age and/or count to keep. Default behavior is to keep the job in the failed set.

            -
            runRetryDelay?: number

            This is an internal option that should not be modified.

            +
            runRetryDelay?: number

            This is an internal option that should not be modified.

            Default

            15000
             
            -
            settings?: AdvancedOptions

            More advanced options.

            -
            skipLockRenewal?: boolean

            Skip lock renewal for this worker. If set to true, the lock will expire +

            settings?: AdvancedOptions

            More advanced options.

            +
            skipLockRenewal?: boolean

            Skip lock renewal for this worker. If set to true, the lock will expire after lockDuration and moved back to the wait queue (if the stalled check is not disabled)

            Default

            false
             
            -
            skipStalledCheck?: boolean

            Skip stalled check for this worker. Note that other workers could still +

            skipStalledCheck?: boolean

            Skip stalled check for this worker. Note that other workers could still perform stalled checkd and move jobs back to wait for jobs being processed by this worker.

            Default

            false
             
            -
            skipVersionCheck?: boolean

            Avoid version validation to be greater or equal than v5.0.0.

            +
            skipVersionCheck?: boolean

            Avoid version validation to be greater or equal than v5.0.0.

            Default Value

            false
             
            -
            stalledInterval?: number

            Number of milliseconds between stallness checks.

            +
            stalledInterval?: number

            Number of milliseconds between stallness checks.

            Default

            30000
             
            -
            useWorkerThreads?: boolean

            Use Worker Threads instead of Child Processes. +

            useWorkerThreads?: boolean

            Use Worker Threads instead of Child Processes. Note: This option can only be used when specifying a file for the processor argument.

            Default

            false
             
            -

            Generated using TypeDoc

            \ No newline at end of file +

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.BackoffStrategy.html b/types/v5.BackoffStrategy.html index b20dbefee6..2897920643 100644 --- a/types/v5.BackoffStrategy.html +++ b/types/v5.BackoffStrategy.html @@ -1 +1 @@ -BackoffStrategy | bullmq - v5.12.12

            Type alias BackoffStrategy

            BackoffStrategy: ((attemptsMade, type?, err?, job?) => Promise<number> | number)

            Type declaration

              • (attemptsMade, type?, err?, job?): Promise<number> | number
              • Parameters

                • attemptsMade: number
                • Optional type: string
                • Optional err: Error
                • Optional job: MinimalJob

                Returns Promise<number> | number

            Generated using TypeDoc

            \ No newline at end of file +BackoffStrategy | bullmq - v5.12.12

            Type alias BackoffStrategy

            BackoffStrategy: ((attemptsMade, type?, err?, job?) => Promise<number> | number)

            Type declaration

              • (attemptsMade, type?, err?, job?): Promise<number> | number
              • Parameters

                • attemptsMade: number
                • Optional type: string
                • Optional err: Error
                • Optional job: MinimalJob

                Returns Promise<number> | number

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.BulkJobOptions.html b/types/v5.BulkJobOptions.html index bba27a7a5f..03bea395c2 100644 --- a/types/v5.BulkJobOptions.html +++ b/types/v5.BulkJobOptions.html @@ -1 +1 @@ -BulkJobOptions | bullmq - v5.12.12

            Type alias BulkJobOptions

            BulkJobOptions: Omit<JobsOptions, "repeat">

            Generated using TypeDoc

            \ No newline at end of file +BulkJobOptions | bullmq - v5.12.12

            Type alias BulkJobOptions

            BulkJobOptions: Omit<JobsOptions, "repeat">

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.ClusterOptions.html b/types/v5.ClusterOptions.html index d27b41bc6c..8f88d8a8c5 100644 --- a/types/v5.ClusterOptions.html +++ b/types/v5.ClusterOptions.html @@ -1 +1 @@ -ClusterOptions | bullmq - v5.12.12

            Type alias ClusterOptions

            ClusterOptions: IORedis.ClusterOptions & BaseOptions

            Generated using TypeDoc

            \ No newline at end of file +ClusterOptions | bullmq - v5.12.12

            Type alias ClusterOptions

            ClusterOptions: IORedis.ClusterOptions & BaseOptions

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.ConnectionOptions.html b/types/v5.ConnectionOptions.html index f73135a82d..da4baec7b1 100644 --- a/types/v5.ConnectionOptions.html +++ b/types/v5.ConnectionOptions.html @@ -1 +1 @@ -ConnectionOptions | bullmq - v5.12.12

            Type alias ConnectionOptions

            ConnectionOptions: RedisOptions | ClusterOptions | IORedis.Redis | IORedis.Cluster

            Generated using TypeDoc

            \ No newline at end of file +ConnectionOptions | bullmq - v5.12.12

            Type alias ConnectionOptions

            ConnectionOptions: RedisOptions | ClusterOptions | IORedis.Redis | IORedis.Cluster

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.EntryId.html b/types/v5.EntryId.html index c00e5b70aa..8624797b6f 100644 --- a/types/v5.EntryId.html +++ b/types/v5.EntryId.html @@ -1 +1 @@ -EntryId | bullmq - v5.12.12

            Type alias EntryId

            EntryId: string

            Generated using TypeDoc

            \ No newline at end of file +EntryId | bullmq - v5.12.12

            Type alias EntryId

            EntryId: string

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.EntryRaw.html b/types/v5.EntryRaw.html index e3ff2fd7c7..0ac6ad1c0c 100644 --- a/types/v5.EntryRaw.html +++ b/types/v5.EntryRaw.html @@ -1 +1 @@ -EntryRaw | bullmq - v5.12.12

            Type alias EntryRaw

            EntryRaw: [EntryId, string[]]

            Generated using TypeDoc

            \ No newline at end of file +EntryRaw | bullmq - v5.12.12

            Type alias EntryRaw

            EntryRaw: [EntryId, string[]]

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.FinishedPropValAttribute.html b/types/v5.FinishedPropValAttribute.html index de2395347c..21af6f928c 100644 --- a/types/v5.FinishedPropValAttribute.html +++ b/types/v5.FinishedPropValAttribute.html @@ -1 +1 @@ -FinishedPropValAttribute | bullmq - v5.12.12

            Type alias FinishedPropValAttribute

            FinishedPropValAttribute: "returnvalue" | "failedReason"

            Generated using TypeDoc

            \ No newline at end of file +FinishedPropValAttribute | bullmq - v5.12.12

            Type alias FinishedPropValAttribute

            FinishedPropValAttribute: "returnvalue" | "failedReason"

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.FinishedStatus.html b/types/v5.FinishedStatus.html index 322aaa807b..29a2ebccac 100644 --- a/types/v5.FinishedStatus.html +++ b/types/v5.FinishedStatus.html @@ -1 +1 @@ -FinishedStatus | bullmq - v5.12.12

            Type alias FinishedStatus

            FinishedStatus: "completed" | "failed"

            Generated using TypeDoc

            \ No newline at end of file +FinishedStatus | bullmq - v5.12.12

            Type alias FinishedStatus

            FinishedStatus: "completed" | "failed"

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.FlowChildJob.html b/types/v5.FlowChildJob.html index 93c0b3c2a7..3d3cc32bb2 100644 --- a/types/v5.FlowChildJob.html +++ b/types/v5.FlowChildJob.html @@ -1 +1 @@ -FlowChildJob | bullmq - v5.12.12

            Type alias FlowChildJob

            FlowChildJob: FlowJobBase<Omit<JobsOptions, "parent">>

            Generated using TypeDoc

            \ No newline at end of file +FlowChildJob | bullmq - v5.12.12

            Type alias FlowChildJob

            FlowChildJob: FlowJobBase<Omit<JobsOptions, "parent">>

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.FlowJob.html b/types/v5.FlowJob.html index 4582fccc5d..32b08dcaea 100644 --- a/types/v5.FlowJob.html +++ b/types/v5.FlowJob.html @@ -1 +1 @@ -FlowJob | bullmq - v5.12.12

            Generated using TypeDoc

            \ No newline at end of file +FlowJob | bullmq - v5.12.12

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.FlowQueuesOpts.html b/types/v5.FlowQueuesOpts.html index dab1b53180..35e6f29315 100644 --- a/types/v5.FlowQueuesOpts.html +++ b/types/v5.FlowQueuesOpts.html @@ -1 +1 @@ -FlowQueuesOpts | bullmq - v5.12.12

            Type alias FlowQueuesOpts

            FlowQueuesOpts: Record<string, Omit<QueueOptions, "connection" | "prefix">>

            Generated using TypeDoc

            \ No newline at end of file +FlowQueuesOpts | bullmq - v5.12.12

            Type alias FlowQueuesOpts

            FlowQueuesOpts: Record<string, Omit<QueueOptions, "connection" | "prefix">>

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.JobData.html b/types/v5.JobData.html index 103afb5738..b2553a18d4 100644 --- a/types/v5.JobData.html +++ b/types/v5.JobData.html @@ -1 +1 @@ -JobData | bullmq - v5.12.12

            Type alias JobData

            JobData: [JobJsonRaw | number, string?]

            Generated using TypeDoc

            \ No newline at end of file +JobData | bullmq - v5.12.12

            Type alias JobData

            JobData: [JobJsonRaw | number, string?]

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.JobJsonSandbox.html b/types/v5.JobJsonSandbox.html index 4d5245e8db..bc0a293870 100644 --- a/types/v5.JobJsonSandbox.html +++ b/types/v5.JobJsonSandbox.html @@ -1 +1 @@ -JobJsonSandbox | bullmq - v5.12.12

            Type alias JobJsonSandbox

            JobJsonSandbox: JobJson & {
                prefix: string;
                queueName: string;
            }

            Type declaration

            • prefix: string
            • queueName: string

            Generated using TypeDoc

            \ No newline at end of file +JobJsonSandbox | bullmq - v5.12.12

            Type alias JobJsonSandbox

            JobJsonSandbox: JobJson & {
                prefix: string;
                queueName: string;
            }

            Type declaration

            • prefix: string
            • queueName: string

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.JobState.html b/types/v5.JobState.html index 90e3395b53..19dd983206 100644 --- a/types/v5.JobState.html +++ b/types/v5.JobState.html @@ -1 +1 @@ -JobState | bullmq - v5.12.12

            Type alias JobState

            JobState: FinishedStatus | "active" | "delayed" | "prioritized" | "waiting" | "waiting-children"

            Generated using TypeDoc

            \ No newline at end of file +JobState | bullmq - v5.12.12

            Type alias JobState

            JobState: FinishedStatus | "active" | "delayed" | "prioritized" | "waiting" | "waiting-children"

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.JobType.html b/types/v5.JobType.html index 4fb6980003..a45dd6ef32 100644 --- a/types/v5.JobType.html +++ b/types/v5.JobType.html @@ -1 +1 @@ -JobType | bullmq - v5.12.12

            Type alias JobType

            JobType: JobState | "paused" | "repeat" | "wait"

            Generated using TypeDoc

            \ No newline at end of file +JobType | bullmq - v5.12.12

            Type alias JobType

            JobType: JobState | "paused" | "repeat" | "wait"

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.JobsOptions.html b/types/v5.JobsOptions.html index 2c6631890a..ae2331a835 100644 --- a/types/v5.JobsOptions.html +++ b/types/v5.JobsOptions.html @@ -2,4 +2,4 @@
          • Optional failParentOnFailure?: boolean

            If true, moves parent to failed.

          • Optional ignoreDependencyOnFailure?: boolean

            If true, moves the jobId from its parent dependencies to failed dependencies when it fails after all attempts.

          • Optional removeDependencyOnFailure?: boolean

            If true, removes the job from its parent dependencies when it fails after all attempts.

            -
          • Generated using TypeDoc

            \ No newline at end of file +

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.KeysMap.html b/types/v5.KeysMap.html index b6514c7b5f..5218da831e 100644 --- a/types/v5.KeysMap.html +++ b/types/v5.KeysMap.html @@ -1 +1 @@ -KeysMap | bullmq - v5.12.12

            Type alias KeysMap

            KeysMap: {
                [index in string]: string
            }

            Generated using TypeDoc

            \ No newline at end of file +KeysMap | bullmq - v5.12.12

            Type alias KeysMap

            KeysMap: {
                [index in string]: string
            }

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.MinimalQueue.html b/types/v5.MinimalQueue.html index 6125b12eb3..d470b36147 100644 --- a/types/v5.MinimalQueue.html +++ b/types/v5.MinimalQueue.html @@ -1 +1 @@ -MinimalQueue | bullmq - v5.12.12

            Type alias MinimalQueue

            MinimalQueue: Pick<QueueBase, "name" | "client" | "toKey" | "keys" | "opts" | "qualifiedName" | "closing" | "waitUntilReady" | "removeListener" | "emit" | "on" | "redisVersion">

            Generated using TypeDoc

            \ No newline at end of file +MinimalQueue | bullmq - v5.12.12

            Type alias MinimalQueue

            MinimalQueue: Pick<QueueBase, "name" | "client" | "toKey" | "keys" | "opts" | "qualifiedName" | "closing" | "waitUntilReady" | "removeListener" | "emit" | "on" | "redisVersion">

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.ParentOpts.html b/types/v5.ParentOpts.html index f453cc91f7..cf6f94fd3b 100644 --- a/types/v5.ParentOpts.html +++ b/types/v5.ParentOpts.html @@ -1 +1 @@ -ParentOpts | bullmq - v5.12.12

            Type alias ParentOpts

            ParentOpts: {
                parentDependenciesKey?: string;
                parentKey?: string;
                waitChildrenKey?: string;
            }

            Type declaration

            • Optional parentDependenciesKey?: string
            • Optional parentKey?: string
            • Optional waitChildrenKey?: string

            Generated using TypeDoc

            \ No newline at end of file +ParentOpts | bullmq - v5.12.12

            Type alias ParentOpts

            ParentOpts: {
                parentDependenciesKey?: string;
                parentKey?: string;
                waitChildrenKey?: string;
            }

            Type declaration

            • Optional parentDependenciesKey?: string
            • Optional parentKey?: string
            • Optional waitChildrenKey?: string

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.Processor.html b/types/v5.Processor.html index 0c5846fcf1..16e74a4c85 100644 --- a/types/v5.Processor.html +++ b/types/v5.Processor.html @@ -1,2 +1,2 @@ Processor | bullmq - v5.12.12

            Type alias Processor<T, R, N>

            Processor<T, R, N>: ((job, token?) => Promise<R>)

            An async function that receives Jobs and handles them.

            -

            Type Parameters

            • T = any
            • R = any
            • N extends string = string

            Type declaration

              • (job, token?): Promise<R>
              • Parameters

                • job: Job<T, R, N>
                • Optional token: string

                Returns Promise<R>

            Generated using TypeDoc

            \ No newline at end of file +

            Type Parameters

            Type declaration

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.RedisClient.html b/types/v5.RedisClient.html index 5e8b75fdc8..07cf1af3c7 100644 --- a/types/v5.RedisClient.html +++ b/types/v5.RedisClient.html @@ -1 +1 @@ -RedisClient | bullmq - v5.12.12

            Type alias RedisClient

            RedisClient: Redis | Cluster

            Generated using TypeDoc

            \ No newline at end of file +RedisClient | bullmq - v5.12.12

            Type alias RedisClient

            RedisClient: Redis | Cluster

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.RedisJobOptions.html b/types/v5.RedisJobOptions.html index 703de05582..8d4c95f9d9 100644 --- a/types/v5.RedisJobOptions.html +++ b/types/v5.RedisJobOptions.html @@ -4,4 +4,4 @@
          • Optional idof?: boolean

            If true, moves the jobId from its parent dependencies to failed dependencies when it fails after all attempts.

          • Optional kl?: number

            Maximum amount of log entries that will be preserved

          • Optional rdof?: boolean

            If true, removes the job from its parent dependencies when it fails after all attempts.

            -
          • Generated using TypeDoc

            \ No newline at end of file +

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.RedisOptions.html b/types/v5.RedisOptions.html index 06027f37ce..5a4320c4a6 100644 --- a/types/v5.RedisOptions.html +++ b/types/v5.RedisOptions.html @@ -1 +1 @@ -RedisOptions | bullmq - v5.12.12

            Type alias RedisOptions

            RedisOptions: IORedis.RedisOptions & BaseOptions

            Generated using TypeDoc

            \ No newline at end of file +RedisOptions | bullmq - v5.12.12

            Type alias RedisOptions

            RedisOptions: IORedis.RedisOptions & BaseOptions

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.RepeatStrategy.html b/types/v5.RepeatStrategy.html index d1faa450c3..eaf393a2c3 100644 --- a/types/v5.RepeatStrategy.html +++ b/types/v5.RepeatStrategy.html @@ -1 +1 @@ -RepeatStrategy | bullmq - v5.12.12

            Type alias RepeatStrategy

            RepeatStrategy: ((millis, opts, name?) => number | undefined | Promise<number | undefined>)

            Type declaration

              • (millis, opts, name?): number | undefined | Promise<number | undefined>
              • Parameters

                Returns number | undefined | Promise<number | undefined>

            Generated using TypeDoc

            \ No newline at end of file +RepeatStrategy | bullmq - v5.12.12

            Type alias RepeatStrategy

            RepeatStrategy: ((millis, opts, name?) => number | undefined | Promise<number | undefined>)

            Type declaration

              • (millis, opts, name?): number | undefined | Promise<number | undefined>
              • Parameters

                Returns number | undefined | Promise<number | undefined>

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.RepeatableJob.html b/types/v5.RepeatableJob.html index ccf39d6640..b42aa8cb14 100644 --- a/types/v5.RepeatableJob.html +++ b/types/v5.RepeatableJob.html @@ -1 +1 @@ -RepeatableJob | bullmq - v5.12.12

            Type alias RepeatableJob

            RepeatableJob: {
                endDate: number | null;
                every?: string | null;
                id?: string | null;
                key: string;
                name: string;
                next: number;
                pattern: string | null;
                tz: string | null;
            }

            Type declaration

            • endDate: number | null
            • Optional every?: string | null
            • Optional id?: string | null
            • key: string
            • name: string
            • next: number
            • pattern: string | null
            • tz: string | null

            Generated using TypeDoc

            \ No newline at end of file +RepeatableJob | bullmq - v5.12.12

            Type alias RepeatableJob

            RepeatableJob: {
                endDate: number | null;
                every?: string | null;
                id?: string | null;
                key: string;
                name: string;
                next: number;
                pattern: string | null;
                tz: string | null;
            }

            Type declaration

            • endDate: number | null
            • Optional every?: string | null
            • Optional id?: string | null
            • key: string
            • name: string
            • next: number
            • pattern: string | null
            • tz: string | null

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.RepeatableOptions.html b/types/v5.RepeatableOptions.html index a3c0263b8f..4cbd98c429 100644 --- a/types/v5.RepeatableOptions.html +++ b/types/v5.RepeatableOptions.html @@ -1 +1 @@ -RepeatableOptions | bullmq - v5.12.12

            Type alias RepeatableOptions

            RepeatableOptions: {
                endDate?: number;
                every?: number;
                name: string;
                pattern?: string;
                tz?: string;
            }

            Type declaration

            • Optional endDate?: number
            • Optional every?: number
            • name: string
            • Optional pattern?: string
            • Optional tz?: string

            Generated using TypeDoc

            \ No newline at end of file +RepeatableOptions | bullmq - v5.12.12

            Type alias RepeatableOptions

            RepeatableOptions: {
                endDate?: number;
                every?: number;
                name: string;
                pattern?: string;
                tz?: string;
            }

            Type declaration

            • Optional endDate?: number
            • Optional every?: number
            • name: string
            • Optional pattern?: string
            • Optional tz?: string

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.SandboxedJobProcessor.html b/types/v5.SandboxedJobProcessor.html index 46c6af01eb..2e26591a91 100644 --- a/types/v5.SandboxedJobProcessor.html +++ b/types/v5.SandboxedJobProcessor.html @@ -1,2 +1,2 @@ SandboxedJobProcessor | bullmq - v5.12.12

            Type alias SandboxedJobProcessor<T, R>

            SandboxedJobProcessor<T, R>: ((job) => R | PromiseLike<R>) | ((job, callback) => void)

            Type Parameters

            • T = any
            • R = any

            Type declaration

            Type declaration

              • (job, callback): void
              • Parameters

                • job: SandboxedJob<T, R>
                • callback: ((error, result) => void)
                    • (error, result): void
                    • Parameters

                      • error: unknown
                      • result: R

                      Returns void

                Returns void

            Generated using TypeDoc

            \ No newline at end of file +

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.StreamName.html b/types/v5.StreamName.html index 12878fee6e..c86e47544b 100644 --- a/types/v5.StreamName.html +++ b/types/v5.StreamName.html @@ -1 +1 @@ -StreamName | bullmq - v5.12.12

            Type alias StreamName

            StreamName: string

            Generated using TypeDoc

            \ No newline at end of file +StreamName | bullmq - v5.12.12

            Type alias StreamName

            StreamName: string

            Generated using TypeDoc

            \ No newline at end of file diff --git a/types/v5.StreamReadRaw.html b/types/v5.StreamReadRaw.html index 5706f1fd2d..cc213b084e 100644 --- a/types/v5.StreamReadRaw.html +++ b/types/v5.StreamReadRaw.html @@ -1 +1 @@ -StreamReadRaw | bullmq - v5.12.12

            Type alias StreamReadRaw

            StreamReadRaw: [StreamName, EntryRaw[]][] | null | undefined

            Generated using TypeDoc

            \ No newline at end of file +StreamReadRaw | bullmq - v5.12.12

            Type alias StreamReadRaw

            StreamReadRaw: [StreamName, EntryRaw[]][] | null | undefined

            Generated using TypeDoc

            \ No newline at end of file diff --git a/variables/v5.DELAY_TIME_1.html b/variables/v5.DELAY_TIME_1.html index dc5edd462d..3e4b568c2a 100644 --- a/variables/v5.DELAY_TIME_1.html +++ b/variables/v5.DELAY_TIME_1.html @@ -1 +1 @@ -DELAY_TIME_1 | bullmq - v5.12.12

            Variable DELAY_TIME_1Const

            DELAY_TIME_1: 100 = 100

            Generated using TypeDoc

            \ No newline at end of file +DELAY_TIME_1 | bullmq - v5.12.12

            Variable DELAY_TIME_1Const

            DELAY_TIME_1: 100 = 100

            Generated using TypeDoc

            \ No newline at end of file diff --git a/variables/v5.DELAY_TIME_5.html b/variables/v5.DELAY_TIME_5.html index 9613df5cb7..6ee8123f98 100644 --- a/variables/v5.DELAY_TIME_5.html +++ b/variables/v5.DELAY_TIME_5.html @@ -1 +1 @@ -DELAY_TIME_5 | bullmq - v5.12.12

            Variable DELAY_TIME_5Const

            DELAY_TIME_5: 5000 = 5000

            Generated using TypeDoc

            \ No newline at end of file +DELAY_TIME_5 | bullmq - v5.12.12

            Variable DELAY_TIME_5Const

            DELAY_TIME_5: 5000 = 5000

            Generated using TypeDoc

            \ No newline at end of file diff --git a/variables/v5.PRIORITY_LIMIT.html b/variables/v5.PRIORITY_LIMIT.html index a4363e15e9..c648c42a65 100644 --- a/variables/v5.PRIORITY_LIMIT.html +++ b/variables/v5.PRIORITY_LIMIT.html @@ -1 +1 @@ -PRIORITY_LIMIT | bullmq - v5.12.12

            Variable PRIORITY_LIMITConst

            PRIORITY_LIMIT: number = ...

            Generated using TypeDoc

            \ No newline at end of file +PRIORITY_LIMIT | bullmq - v5.12.12

            Variable PRIORITY_LIMITConst

            PRIORITY_LIMIT: number = ...

            Generated using TypeDoc

            \ No newline at end of file diff --git a/variables/v5.QUEUE_EVENT_SUFFIX.html b/variables/v5.QUEUE_EVENT_SUFFIX.html index ff0f1b130d..185e6adfb3 100644 --- a/variables/v5.QUEUE_EVENT_SUFFIX.html +++ b/variables/v5.QUEUE_EVENT_SUFFIX.html @@ -1 +1 @@ -QUEUE_EVENT_SUFFIX | bullmq - v5.12.12

            Variable QUEUE_EVENT_SUFFIXConst

            QUEUE_EVENT_SUFFIX: ":qe" = ':qe'

            Generated using TypeDoc

            \ No newline at end of file +QUEUE_EVENT_SUFFIX | bullmq - v5.12.12

            Variable QUEUE_EVENT_SUFFIXConst

            QUEUE_EVENT_SUFFIX: ":qe" = ':qe'

            Generated using TypeDoc

            \ No newline at end of file diff --git a/variables/v5.RATE_LIMIT_ERROR.html b/variables/v5.RATE_LIMIT_ERROR.html index 3ca63af2b8..78c73a075c 100644 --- a/variables/v5.RATE_LIMIT_ERROR.html +++ b/variables/v5.RATE_LIMIT_ERROR.html @@ -1 +1 @@ -RATE_LIMIT_ERROR | bullmq - v5.12.12

            Variable RATE_LIMIT_ERRORConst

            RATE_LIMIT_ERROR: "bullmq:rateLimitExceeded" = 'bullmq:rateLimitExceeded'

            Generated using TypeDoc

            \ No newline at end of file +RATE_LIMIT_ERROR | bullmq - v5.12.12

            Variable RATE_LIMIT_ERRORConst

            RATE_LIMIT_ERROR: "bullmq:rateLimitExceeded" = 'bullmq:rateLimitExceeded'

            Generated using TypeDoc

            \ No newline at end of file diff --git a/variables/v5.clientCommandMessageReg.html b/variables/v5.clientCommandMessageReg.html index 8dc5219ec7..06e98644b2 100644 --- a/variables/v5.clientCommandMessageReg.html +++ b/variables/v5.clientCommandMessageReg.html @@ -1 +1 @@ -clientCommandMessageReg | bullmq - v5.12.12

            Variable clientCommandMessageRegConst

            clientCommandMessageReg: RegExp = ...

            Generated using TypeDoc

            \ No newline at end of file +clientCommandMessageReg | bullmq - v5.12.12

            Variable clientCommandMessageRegConst

            clientCommandMessageReg: RegExp = ...

            Generated using TypeDoc

            \ No newline at end of file diff --git a/variables/v5.errorObject.html b/variables/v5.errorObject.html index de4abef493..faeafc177c 100644 --- a/variables/v5.errorObject.html +++ b/variables/v5.errorObject.html @@ -1 +1 @@ -errorObject | bullmq - v5.12.12

            Variable errorObjectConst

            errorObject: {
                [index: string]: any;
            } = ...

            Type declaration

            • [index: string]: any

            Generated using TypeDoc

            \ No newline at end of file +errorObject | bullmq - v5.12.12

            Variable errorObjectConst

            errorObject: {
                [index: string]: any;
            } = ...

            Type declaration

            • [index: string]: any

            Generated using TypeDoc

            \ No newline at end of file