celery.worker
Executes tasks waiting in the task queue.
Execute the next task on the queue using the multiprocessing pool.
Catches all exceptions and logs them with level logging.CRITICAL.
Fetch the next task from the AMQP broker.
Raises :class`EmptyQueue` exception if there is no messages waiting on the queue.
Return type: | TaskWrapper instance. |
---|
Receive the next message from the Task consumer queue.
Tries to reset the AMQP connection if not available. Returns None if no message is waiting on the queue.
Return type: | carrot.messaging.Message instance. |
---|
Schedule all waiting periodic tasks for execution.
Return type: | list of celery.models.PeriodicTaskMeta objects. |
---|
Class defining a task to be run.
Like execute, but using the multiprocessing pool.
Return type: | multiprocessing.AsyncResult instance. |
---|
Extend the tasks keyword arguments with standard task arguments.
These are logfile, loglevel, task_id and task_name.
Create a TaskWrapper from a message returned by celery.messaging.TaskConsumer.
If the message is not a proper task it raises UnknownTask exception.
Return type: | TaskWrapper instance. |
---|
Wraps the task in a jail which saves the status and result of the task execution to the task meta backend.
If the call results in an exception, it saves the exception as the task result, and sets the task status to FAILURE.
If the call was successful, it saves the result to the task result backend, and sets the task status to DONE.