Tasks - celery.task¶
Working with tasks and task sets.
- class celery.task.AsynchronousMapTask¶
- Task used internally by dmap_async() and TaskSet.map_async(). - run(serfunc, args, **kwargs)¶
- The method run by celeryd.
 
- class celery.task.DeleteExpiredTaskMetaTask¶
- A periodic task that deletes expired task metadata every day. - This runs the current backend’s celery.backends.base.BaseBackend.cleanup() method. - run(**kwargs)¶
- The method run by celeryd.
 
- class celery.task.ExecuteRemoteTask¶
- Execute an arbitrary function or object. - Note You probably want execute_remote() instead, which this is an internal component of. - The object must be pickleable, so you can’t use lambdas or functions defined in the REPL (that is the python shell, or ipython). - run(ser_callable, fargs, fkwargs, **kwargs)¶
- Parameters: - ser_callable – A pickled function or callable object.
- fargs – Positional arguments to apply to the function.
- fkwargs – Keyword arguments to apply to the function.
 
 
- class celery.task.PeriodicTask¶
- A periodic task is a task that behaves like a cron job. - run_every¶
- REQUIRED Defines how often the task is run (its interval), it can be either a datetime.timedelta object or an integer specifying the time in seconds.
 - Raises NotImplementedError: - if the run_every attribute is not defined. - You have to register the periodic task in the task registry. - Example - >>> from celery.task import tasks, PeriodicTask >>> from datetime import timedelta >>> class MyPeriodicTask(PeriodicTask): ... name = "my_periodic_task" ... run_every = timedelta(seconds=30) ... ... def run(self, **kwargs): ... logger = self.get_logger(**kwargs) ... logger.info("Running MyPeriodicTask") >>> tasks.register(MyPeriodicTask) 
- class celery.task.Task¶
- A task that can be delayed for execution by the celery daemon. - All subclasses of Task must define the run() method, which is the actual method the celery daemon executes. - The run() method supports both positional, and keyword arguments. - name¶
- REQUIRED All subclasses of Task has to define the name attribute. This is the name of the task, registered in the task registry, and passed to delay_task().
 - type¶
- The type of task, currently this can be regular, or periodic, however if you want a periodic task, you should subclass PeriodicTask instead.
 - Raises NotImplementedError: - if the name attribute is not set. - The resulting class is callable, which if called will apply the run() method. - Examples - This is a simple task just logging a message, - >>> from celery.task import tasks, Task >>> class MyTask(Task): ... name = "mytask" ... ... def run(self, some_arg=None, **kwargs): ... logger = self.get_logger(**kwargs) ... logger.info("Running MyTask with arg some_arg=%s" % ... some_arg)) ... return 42 ... tasks.register(MyTask) - You can delay the task using the classmethod delay()... - >>> result = MyTask.delay(some_arg="foo") >>> result.status # after some time 'DONE' >>> result.result 42 - ...or using the delay_task() function, by passing the name of the task. - >>> from celery.task import delay_task >>> result = delay_task(MyTask.name, some_arg="foo") - classmethod apply_async(args=None, kwargs=None, **options)¶
- Delay this task for execution by the celery daemon(s). - Parameters: - args – positional arguments passed on to the task.
- kwargs – keyword arguments passed on to the task.
 - Return type: - See apply_async(). 
 - classmethod delay(*args, **kwargs)¶
- Delay this task for execution by the celery daemon(s). - Parameters: - *args – positional arguments passed on to the task.
- **kwargs – keyword arguments passed on to the task.
 - Return type: - See delay_task(). 
 - get_consumer()¶
- Get a celery task message consumer. - Return type: - celery.messaging.TaskConsumer. - Please be sure to close the AMQP connection when you’re done with this object. i.e.: - >>> consumer = self.get_consumer() >>> # do something with consumer >>> consumer.connection.close() 
 - get_logger(**kwargs)¶
- Get process-aware logger object. 
 - get_publisher()¶
- Get a celery task message publisher. - Return type: - celery.messaging.TaskPublisher. - Please be sure to close the AMQP connection when you’re done with this object, i.e.: - >>> publisher = self.get_publisher() >>> # do something with publisher >>> publisher.connection.close() 
 
- class celery.task.TaskSet(task, args)¶
- A task containing several subtasks, making it possible to track how many, or when all of the tasks has been completed. - Parameters: - task – The task class or name. Can either be a fully qualified task name, or a task class.
- args – A list of args, kwargs pairs. e.g. [[args1, kwargs1], [args2, kwargs2], ..., [argsN, kwargsN]]
 - task_name¶
- The name of the task.
 - arguments¶
- The arguments, as passed to the task set constructor.
 - total¶
- Total number of tasks in this task set.
 - Example - >>> from djangofeeds.tasks import RefreshFeedTask >>> taskset = TaskSet(RefreshFeedTask, args=[ ... [], {"feed_url": "http://cnn.com/rss"}, ... [], {"feed_url": "http://bbc.com/rss"}, ... [], {"feed_url": "http://xkcd.com/rss"}]) - >>> taskset_result = taskset.run() >>> list_of_return_values = taskset.join() - iterate()¶
- Iterate over the results returned after calling run(). - If any of the tasks raises an exception, the exception will be re-raised. 
 - join(timeout=None)¶
- Gather the results for all of the tasks in the taskset, and return a list with them ordered by the order of which they were called. - Parameter: - timeout – The time in seconds, how long it will wait for results, before the operation times out. - Raises celery.timer.TimeoutError: - if timeout is not None and the operation takes longer than timeout seconds. - If any of the tasks raises an exception, the exception will be reraised by join(). - Returns: - list of return values for all tasks in the taskset. 
 - classmethod map(func, args, timeout=None)¶
- Distribute processing of the arguments and collect the results.
 - classmethod map_async(func, args, timeout=None)¶
- Distribute processing of the arguments and collect the results asynchronously. - Returns: - celery.result.AsyncResult instance. 
 - classmethod remote_execute(func, args)¶
- Apply args to function by distributing the args to the celery server(s).
 - run()¶
- Run all tasks in the taskset. - Returns: - A celery.result.TaskSetResult instance. - Example - >>> ts = TaskSet(RefreshFeedTask, [ ... ["http://foo.com/rss", {}], ... ["http://bar.com/rss", {}], ... ) >>> result = ts.run() >>> result.taskset_id "d2c9b261-8eff-4bfb-8459-1e1b72063514" >>> result.subtask_ids ["b4996460-d959-49c8-aeb9-39c530dcde25", "598d2d18-ab86-45ca-8b4f-0779f5d6a3cb"] >>> result.waiting() True >>> time.sleep(10) >>> result.ready() True >>> result.successful() True >>> result.failed() False >>> result.join() [True, True] 
 
- celery.task.apply_async(task, args=None, kwargs=None, routing_key=None, immediate=None, mandatory=None, connect_timeout=None, priority=None)¶
- Run a task asynchronously by the celery daemon(s). - Parameters: - task – The task to run (a callable object, or a Task instance
- args – The positional arguments to pass on to the task (a list).
- kwargs – The keyword arguments to pass on to the task (a dict)
- routing_key – The routing key used to route the task to a worker server.
- immediate – Request immediate delivery. Will raise an exception if the task cannot be routed to a worker immediately.
- mandatory – Mandatory routing. Raises an exception if there’s no running workers able to take on this task.
- connect_timeout – The timeout in seconds, before we give up on establishing a connection to the AMQP server.
- priority – The task priority, a number between 0 and 9.
 
- celery.task.delay_task(task_name, *args, **kwargs)¶
- Delay a task for execution by the celery daemon. - Parameters: - task_name – the name of a task registered in the task registry.
- *args – positional arguments to pass on to the task.
- **kwargs – keyword arguments to pass on to the task.
 - Raises celery.registry.NotRegistered: - exception if no such task has been registered in the task registry. - Return type: - Example - >>> r = delay_task("update_record", name="George Constanza", age=32) >>> r.ready() True >>> r.result "Record was updated" 
- celery.task.discard_all()¶
- Discard all waiting tasks. - This will ignore all tasks waiting for execution, and they will be deleted from the messaging server. - Returns: - the number of tasks discarded. - Return type: - int 
- celery.task.dmap(func, args, timeout=None)¶
- Distribute processing of the arguments and collect the results. - Example - >>> from celery.task import map >>> import operator >>> dmap(operator.add, [[2, 2], [4, 4], [8, 8]]) [4, 8, 16] 
- celery.task.dmap_async(func, args, timeout=None)¶
- Distribute processing of the arguments and collect the results asynchronously. - Returns: - celery.result.AsyncResult object. - Example - >>> from celery.task import dmap_async >>> import operator >>> presult = dmap_async(operator.add, [[2, 2], [4, 4], [8, 8]]) >>> presult <AsyncResult: 373550e8-b9a0-4666-bc61-ace01fa4f91d> >>> presult.status 'DONE' >>> presult.result [4, 8, 16] 
- celery.task.execute_remote(func, *args, **kwargs)¶
- Execute arbitrary function/object remotely. - Parameters: - func – A callable function or object.
- *args – Positional arguments to apply to the function.
- **kwargs – Keyword arguments to apply to the function.
 - The object must be picklable, so you can’t use lambdas or functions defined in the REPL (the objects must have an associated module). - Returns: - class:celery.result.AsyncResult. 
- celery.task.is_done(task_id)¶
- Returns True if task with task_id has been executed. - Return type: - bool