Top "Celery" questions

Celery is a distributed task queue framework for Python, used for asynchronous and parallel execution.

How to dynamically add / remove periodic tasks to Celery (celerybeat)

If I have a function defined as follows: def add(x,y): return x+y Is there a way to …

python celery celerybeat
Retrieve task result by id in Celery

I am trying to retreive the result of a task which has completed. This works from proj.tasks import add …

celery
Running "unique" tasks with celery

I use celery to update RSS feeds in my news aggregation site. I use one @task for each feed, and …

python django celery
Celery Get List Of Registered Tasks

Is there a way to get a list of registered tasks? I tried: celery_app.tasks.keys() Which only returns …

python celery
What's the equivalent of Python's Celery project for Java?

I am trying to find an equivalent of Celery project for Java environment, I have looked at Spring Batch, but …

java python celery batch-processing spring-batch
Airflow - Python file NOT in the same DAG folder

I am trying to use Airflow to execute a simple task python. from __future__ import print_function from airflow.operators.…

python celery celery-task airflow
Celery: auto discovery does not find tasks module in app

I have the following setup with a fresh installed celery and django 1.4: settings.py: import djcelery djcelery.setup_loader() BROKER_…

python django celery django-celery
How to use Flask-SQLAlchemy in a Celery task

I recently switch to Celery 3.0. Before that I was using Flask-Celery in order to integrate Celery with Flask. Although it …

python flask celery flask-sqlalchemy
How to inspect and cancel Celery tasks by task name

I'm using Celery (3.0.15) with Redis as a broker. Is there a straightforward way to query the number of tasks with …

python redis celery
Why use Celery instead of RabbitMQ?

From my understanding, Celery is a distributed task queue, which means the only thing that it should do is dispatching …

python message-queue rabbitmq celery