taskforcesh/
BullMQ - Premium Message Queue for NodeJS based on Redis
USD raised
Recent activities
How to use moveToFailed and moveToCompleted
*drained* event emitting on intermittent basis
Flow Job Delay Not Working
Fatal exception: TypeError: proc.send is not a function
Queue.getJobs may return duplicates
Add metrics/statistics support
Support "steps" for processors so that long operations can be broken down in atomic ones
Checking for upstash introduces a bug
Why not create a FlowJob with parent id?
Jobs are processing more than the max attempts
Add support for Node-Redis connection
Warn users that BullMQ is not compatible with Upstash
Retrying job when limiter used
Promote Job when limiter used
Not used by Remix
Add method to get existing Queue Schedulers on a particular Queue
Avoid console.error when unable to connect to redis
Stream event keys in redis takes too much memory
getJobCounts does not properly add default types to support omitting any type
On failed jobs, why does it show "Failed reason" is null
Removing a job does not remove it's children
Job.queueName is undefined in sandboxed processor
Why can't the `volatile-lru` eviction policy be supported along with the `noeviction` policy?
Feature: Direct support for full redis URLs
Feature request: Including failed jobs in QueueEvents "failed"
Question: Where come from `cmsgpack.pack` lua func?
`getWorkers()` broken with v1.78.2- > v1.79.0 upgrade
cron expression error and cron job not working as expected.
Fix unstable tests
Feature: Support worker sharding using index keys
Scheduler stops after Redis reconnect
worker.close() does not handle process exit correctly
Stalled/failed jobs stay in queue
Error passing in ioredis v5 instance to connection
Job.createBulk doesnt not obey custom jobID
changeDelay does not update job properties to reflect new expected execution time
function properties of a job data are not available in the worker callback
Queue typings make no sense to me
Error: write EPIPE
When adding repeatable job, not all redis-connection.ts error event listeners are removed
BullMQ is interfering with process signal handling and prevents other graceful shutdowns (even when not running workers)
Recurring jobs sometimes run immediately when added to queue
Retry does not work with flows
Add UTC option for repeatable job RepeatOptions
Repeatable 1 hour interval not working
Adding the same ID to wait list many times
Accept/reject jobs by job name?
UnhandledPromiseRejectionWarning: TypeError: proc.send is not a function
Is there an ignoreLock option for moveToCompleted?
How do I log a job that has failed all retries?
[bug] memory leak if throw inside event listener
add child jobs to already existing parent job
ENOENT: no such file or directory, scandir
v1.59.1 client.moveToActive is not a function
bullmq@1.59.0: ScriptLoaderError: No .lua files found!
v1.57.4 client.moveToActive is not a function
Clarify what happens when adding job with duplicate id
ECONNREFUSED on initial Queue creation
Throw exception if trying to use a redis instance with a different eviction policy than "noeviction"
bullmq@1.56.0: SyntaxError: Named export 'Queue' not found
[Feature Request] Allow workers to pick up ioredis prefixes for ACL usage
[Feature Request] Worker Rate Limit without Duration
How to use `limiter` and `job#jobId` together?
problem with redis cluster
add default option values to api reference
Bug? - Error in processor permanently breaks entire queue
How to achieve Producer to Consumer(s) pattern? (Kafka like)
Mocha types are not included as part of bullmqs dependencies (But are needed?)
unexpected behavior: if worker process exit due to stalled, job will not get retried or moved to delayed, even if it has more attempts.
RFC: Script Loader
Using Job Id breaks adding jobs to the queue
Intermittent Connection is closed error
Emit 'cleaned' event on Queue.clean()
The count of completed job always is 1800
get status of the job
Job Chaining / Workflows
Flow job add new child job during runtime or on complete
Support for an efficient "retry all" failed jobs
Allow access to Job#queue
waitUntillFinished throws error for failed jobs
High Concurrency Lock / Not In Active State Errors
Support "removeOnComplete/Fail" based on time
Irregular use of lowercase "returnvalue" in `QueueEvents` listener interface (Low Priority)
`jobOpts.repeat.immediately` should work with cron
Change in how repeatable jobs keys are stored on redis
I can't add the connection options with queue options at the same time in Typescript
Webpack Production Build: paths is not iterable
[Feature Request] Proper pagination for `getJobs`
Provide state enum
Improve the logic of "attemptsMade"
Flow doesn't follow Queue's default job options
Redis parser error - ReplyError: ERR timeout is not an integer or out of range
Queue job counts
Recommended Express integration
Stalled/Failed Jobs Stay in Queue
Add a public method to Worker for starting polling job manually
Full list of events?
Flow not executed if jobId option is set in parent
Possible bug? Bullmq says my Redis version is <5.0.0 even though it isn't
Question: is there any reason why the max stream length is set to 10.000?
Can not add Queue in other queue
How to add Job to multiple queues atomically?
BullMQ Pro Job `timeout` usage
Maximum jobs per user
What is the design purpose of job name?
Ability to ignore max-memory policy
'recommeded to use a minimum Redis version of 6.2.0', orly?
Config Get maxmemory policy not possible on elasticache
Access job data or name in QueueEvents
No exported member "QueueScheduler"
Error: Must use import to load ES module
Events Documentation
Update function not available when using sandboxed processor
repeatable jobs not starting
How many times is a job retried based on the attempts we declare when adding a job in queue?
Jest Detects Open Handles when using a Queue
Getting complete duration in metrics
Type 'Redis' is not assignable to type 'ConnectionOptions'
Queue and Worker opts processing logic
Huskey install error
Job stuck in queue with timestamp NaN
Provide ESM
Removing completed jobs based on age not working as expected
Lua redis() command arguments must be strings or integers
Repeat Jobs not Rescheduling
`moveToCompleted` always error ` Missing lock for job <T>.finished` ?
Cannot get children jobs of flow when using FlowProducer with rate limiting
Sandboxed processors fails in NodeJS ECMA module
[Bug]: Flow, job.getChildrenValues returns an empty object
[Bug]: Expiry time not getting applied to flow job
[Bug]: v5.10.0 introducing "ReplyError: CROSSSLOT Keys in request don't hash to the same slot"
[Bug]: Connect BullMQ to AWS Redis MemoryDB
Possible memory leak?
Rate limiter with `max: 1` having unexpected results
Does removeOnComplete with a number of jobs to keep only remove the oldest Jobs ?
Multiple Jobs not working on pm2
Improve waitUntilFinished timeout
`worker.concurrency === undefined`
How to verify if a job was added to the queue?
Scheduler required for bullmq-pro?
Support for ioredis v5
Sandboxed workers... starting infinitely?
TypeError: The "original" argument must be of type Function
QueueScheduler doesn't queue delayed jobs after restarting the scheduler
FlowProducer and when to use them?
BullMQ causes segmentation fault on NodeJS 18.12.0
rate-limiting by groupKey - new implementation?
Job is not retried when concurrency > 1 + repeatable job is scheduled
Missing lock for job error
updateProgress doesn't work with REPEATABLE jobs
Event on parent job queue when child failed
Error when using with Redis Cluster
Add Bulk Fail Silently
Feature-Request/Change the number of concurrent processes
Question: Repeatable jobs are not executed at all
Getter test 'gets only workers related only to one queue' inaccurate if connection = new IORedis()
Jobs are always stalling in Redis
TypeError: Invalid Version: undefined
Migrating from Bull when using sandboxed and named processors together
How to notify queue that stalled job is still in progress?
BullMQ reusing redis connections
Acknowledge removal of job with removeRepeatable
bullmq with redis cluster error
Queue error: Connection is closed.
connection is closed from QueueEvents
Is there event for reaching rateLimit by groupKey?
`Error: Connection is closed.` for shared connection
[BullMQ Pro]: ERR Error running script (call to f_215bf405a5a0a694dae5966a9cd8b65f306174b5)
Removing Repeatable job does not emit a `Removed` QueueEvent
RemoveRepeatable always returns null
Bug: Incompatible Workers Versions
Repeatable docs code example error
Confusion Regarding Graceful Shutdown of Queue, Worker, and QueueScehduler
job.moveToWaitingChildren never returns an Error
Undefined error when checking Redis Cluster connection for Upstash
bullmq-redis
Queue Scheduler doesn't close its redis client
Jobs randomly failing with error messages, but worker never gets called
Add "log" event to Queue and Worker
RepeatOptions - is 'endDate' and 'tz' supported?
Job.getDependencies very bad performance
Rate limit w/ groupKey is not respecting groupKey limit
UnrecoverableError in sandboxed processors
Best way to persist data when redid is restarted/crashed
Repeatable job (after) not working.
Passing Set in job data param results in empty object
Rate limiting and backoff strategy
Typescript: discriminating worker
RemoveOnComplete: [number] per job, not supported or not working?
WorkerListener generic
Manual processing of jobs, grabs 2 jobs from waiting state
Can we make queue.close() quick?
Comprehension question: Multiple API servers with repeatable jobs
BaseJobOptions is missing timeout property in v1.86.2
How to fast forward days for testing purpose
Job delay and jobId
repeat option is ignored when using "defaultJobOptions"
Missing 'added' Events for Multiple Queues
stalledInterval when set to 0, returns redis error
How to use Worker with typescript processor file?
Lost listener event?
getJobs not returning all jobs in queue
JobFlow not registering names
Build error related to latest version (v1.16.0)
Missing lock for job 1 finished
CROSSSLOT Keys in request don't hash to the same slot
Job ID is not preventing duplicates?
[Question] Redis autopipelining
Repeatable jobs are duplicating due to "count" option field
Scheduler doesn't close it's connection
Alternative to named processors?
TypeError: Do not know how to serialize a BigInt
Stalled job not requeued
TypeError: Converting circular structure to JSON
Error: Retried job not failed
What's the scenario when the same job will be executed more than once?
Intermittent lua error "user_script:28: attempt to compare number with nil"
Wrong redis version recognition when using AWS ElastiCache
[Feature] Call Worker and QueueScheduler methods without launching the process
Concurrency inside of a given process
Delayed and Repeatable parameters together in one Job not working
[Feature request] Function to remove all jobs from Queue including Repeatable
client.moveToActive is not a function
Doc: Wrong comment on code sample on documentation
Graceful shutdown handler
add jobs to queues without creating separate Queue object
@user_script:86: user_script:86: too many results to unpack
Worker Error Recovery
Add duration property to completed jobs
Clarify timestamp in JobsOptions interface
Priority is illogical
Vulnerable dependecy : lodash
FlowJob
missing types for Worker event listeners
Add types for active event to QueueEvents
Feature request: non-blocking version of getNextJob
Bull is not removing idle keys from Redis for completed/failed jobs
Workflows -- use case
Flow task removed doesn't remove data relative
Add support for parent opts with addBulk
Debug cron that doesn't restart after Redis crash
worker.close leaks connection
wrong return types for job.getDependencies and job.getChildrenValues
token mandatory?
Error: Missing lock for job 84 failed
addBulk with multiple repeating jobs only enqueues one repeating job
Job#moveToCompleted on delayed job moves it to active
TypeScript class declaration â superfluous generic parameter
wrong delay on Repeatable
Vercel add Job : TypeError: client.addJob is not a function
Not remove failed jobs from queue
Order messed up?
What is rule of QueueScheduler?
Redis memory accumulates by job process return value
Update job options on the fly
Repeatedly pausing a worker can cause it to starve the event loop
Error: connect ECONNREFUSED 127.0.0.1:6379 even if I specify AWS host and port
How do I only process Jobs with a specific name?
QUESTION: Worker class generic type arguments
Global job history limits
If the job data is `0` the value is lost
migration example
Jests Tests Hanging
Increasing connection and listener count
Dependency on @types/ioredis is redundant
Discard or replace delayed job for a specific groupKey
Is it bad to have multiple instances of QueueScheduler running simultaneously?
Remove client property from QueueBaseOptions
RRULE - RFC5545
Build fails due to BullMq import errors
Pull next job from queue to process
GCP Unknown Client Command
Discarded jobs stay in the same state
Error: EMFILE: too many open files
install using npm?
Method pause() removes all waiting jobs.
Configuration BullMQ
removeRepeatableByKey does not remove the next repeatable job
How does bullmq ensure jobs arenât deleted by Redis evictions?
tsc errors about a missing argument to resolve() in src/classes/child-pool.ts and src/utils.ts
Sandboxed updateProgress()
Proces one job at time
API Reference Documentation is empty
Build error with Timeout and 'semver' missing declaration
Question: how to connect redis cluster using BullMQ ?
Question: Bullmq connection with redis cluster not added in types
ioredis vs redis support
How to update progress of a job?
Modify the way Error is displayed under FAILED tab
Repeatable jobs need serious work
[Interface change] attribute failedReason alter type to Object | string
Port BullMQ to Deno
Worker can get caught in infinite loop when redis connection is closed unexpectedly
How to store jobs created to find them in a easy way ?
Typescript Job.data attribute static typings
Is there a way for multiple consumers?
Will reschedule a failed/stalled job put it to the end of the queue?
Unpredictable time for queue.add to complete
[Feature request] add queue event enum
Documentation : Delay in "Queues" page is misleading
I start the serve by DEBUG=*, Then I see the output every seconds, is that ok?
Documentation: API Reference Page is blank
sandbox - stderr is not piped to parent process
Flows - passing returned data to the next job
ChangeDelay does not work
Bullmq connection issue docker
Docs: wrong example 'Returning job data'
[HOWTO] Update repeatable jobs
ECONNREFUSED Error when adding Job to Queue
Handling lost connection error
Worker loop does not restore after redis disconnects
Repeatable jobs do not check for existence
Repeatable jobs, queue identical job
Can't clean queue
Flows: Prefix always uses "bull"
prevMillis magically appearing field without any descriptive documentation
Jobs get error when using Redis Cluster
waitUntilFinished hang if removeOnComplete is set without TTL
Job.moveToFailed fails in Cluster mode
delay should throw if its not a number
TypeScript type for job status
Ordering Group Flow
Occasional error in QueueScheduler for repeatable jobs
QueueEvents needs to duplicate the connection if passed as option
Redis ECONNRESET causes waitUntilReady to fail
QueueScheduler & QueueEvents make the test suite suspend
timeout still working?
Graceful termination, closing queues and workers
Rename main branch to main?
Job property finishedOn is undefined
bullmq for ftp download file
Cannot obliterate non-paused queue
Repeatable Flows - only parent job get's repeated
Could you kindly add a section in your documentation on how to setup bullmq testing with Jest?
"updateParentDepsIfNeeded is not defined" still throwing on 1.51.1
How exactly are we supposed to use QueueScheduler?
Version 1.51.0 crashes with "updateParentDepsIfNeeded is not defined"
[question] why type job.id is optional? isn's it fallback to default value when not provided by user.
after update to 1.51.0,raise ReferenceError: updateParentDepsIfNeeded is not defined
Worker.close() won't take into account failed jobs
[Question] await queue.add(`name`, data) what is the meaning of `name`
Connection settings should be mandatory
Flow + JobId usage creates "zombie" jobs
flow doesn't work with worker's backoffStrategies
console.log used in child-pool's child.stdout.on adds extra newlines
Redis Replication vs. Cluster
How to get full job id in worker's processor?
Allow generating job ids via uuid4 by default
Issue with upgrade from 1.50.1 to 1.50.2
bullmq can't install in Node 16.x
job moves to completed when receiving data but before processing it.
Bug: exception when job processing returns immediately
getWorkers() includes workers for other queues with the same name prefix
Request to update Docs - Cron Task
How could i solve this? `job stalled more than allowable limit`
not work
Promise rejection error in waitForJob
Flows - Ratelimiting issues
repeat did nont remove whe set removeOnComplete:true
Global concurrency || Optional filterable job names
Under what conditions does `finishedOn` property is null
Dynamically add childJobs while the main job is running
What happens if removeOnComplete is true but a job is repeating?
[exiting] Fatal exception: Missing lock for job err
How to wait children in manual processing?
backoffStrategies not working
Difference between job.discard() and job.remove()
Using the "prefix" option
Pausing/resuming worker causes process to crash
whenCurrentJobsFinished reconnect arg
Cannot read property 'returnvalue' of undefined in waitUntilFinished
A better job.getState
FlowProducer: parent job does not contain dependencies if I set jobId
Latest changelog not preset at https://docs.bullmq.io/changelog
Flows not working if there are no children
Dynamically change delay of the job
Docs: wrong type used in sandboxed processors page
Problem Rate-Limiting a Worker
Adding multiple jobs at once?
No event fired when Job added to Queue with no Worker
Add types for event emitters
Add new sibling job in flow at runtime
Debounce example is confusing / misleading
How to fail a Job
Only every other message is pulled from the queue
How to get jobs from getNextJob() continuously?
Implement TTL mechanism for jobs being processed
Flow: order of jobs
Is there a way to simulate SQS "group ID" ?
Connection is closed
Handle connection errors on startup
Redis connection error event handler is set ONLY after connection is established
Instantiating a queue is blocking the node process. How to add a job to a queue from a web process?
Elasticache Jobs not always starting
RedisClient.waitUntilReady never resolves
Queue stuck with jobs in "active" state for hours, and rest of jobs not being processed
Jobs failing due to stalling more than the allowable limit don't respect the retry strategy.
Workers stop processing jobs after Redis reconnect
working with serverless server
[Flow] - waitUntilFinished of any children not fails when the job fails
Changelog is not updated
Support env variables when using sandbox mode
© 2019 BoostIO, Inc.