| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273 | .. _guide-sets:.. _guide-groups:======================================= Groups, Chords, Chains and Callbacks=======================================.. contents::    :local:.. _sets-subtasks:.. _groups-subtasks:Subtasks========.. versionadded:: 2.0The :class:`~celery.task.sets.subtask` type is used to wrap the arguments andexecution options for a single task invocation:.. code-block:: python    from celery import subtask    subtask(task_name_or_cls, args, kwargs, options)For convenience every task also has a shortcut to create subtasks:.. code-block:: python    task.subtask(args, kwargs, options):class:`~celery.task.sets.subtask` is actually a :class:`dict` subclass,which means it can be serialized with JSON or other encodings that doesn'tsupport complex Python objects.Also it can be regarded as a type, as the following usage works::    >>> s = subtask("tasks.add", args=(2, 2), kwargs={})    >>> subtask(dict(s))  # coerce dict into subtaskThis makes it excellent as a means to pass callbacks around to tasks... _sets-callbacks:.. _groups-callbacks:Callbacks---------Callbacks can be added to any task using the ``link`` argumentto ``apply_async``:    add.apply_async((2, 2), link=other_task.subtask())The callback will only be applied if the task exited successfully,and it will be applied with the return value of the parent task as argument.The best thing is that any arguments you add to `subtask`,will be prepended to the arguments specified by the subtask itself!If you have the subtask::    >>> add.subtask(args=(10, ))`subtask.delay(result)` becomes::    >>> add.apply_async(args=(result, 10))...Now let's execute our ``add`` task with a callback using partialarguments::    >>> add.apply_async((2, 2), link=add.subtask((8, )))As expected this will first launch one task calculating :math:`2 + 2`, thenanother task calculating :math:`4 + 8`... _sets-taskset:.. _groups-group:Groups======The :class:`~celery.task.sets.group` enables easy invocation of severaltasks at once, and is then able to join the results in the same order as thetasks were invoked.``group`` takes a list of :class:`~celery.task.sets.subtask`'s::    >>> from celery import group    >>> from tasks import add    >>> job = group([    ...             add.subtask((2, 2)),    ...             add.subtask((4, 4)),    ...             add.subtask((8, 8)),    ...             add.subtask((16, 16)),    ...             add.subtask((32, 32)),    ... ])    >>> result = job.apply_async()    >>> result.ready()  # have all subtasks completed?    True    >>> result.successful() # were all subtasks successful?    True    >>> result.join()    [4, 8, 16, 32, 64]The first argument can alternatively be an iterator, like::    >>> group(add.subtask((i, i)) for i in range(100)).. _sets-results:Results-------When a  :class:`~celery.task.sets.group` is applied it returns a:class:`~celery.result.TaskSetResult` object.:class:`~celery.result.TaskSetResult` takes a list of:class:`~celery.result.AsyncResult` instances and operates on them as if it was asingle task.It supports the following operations:* :meth:`~celery.result.TaskSetResult.successful`    Returns :const:`True` if all of the subtasks finished    successfully (e.g. did not raise an exception).* :meth:`~celery.result.TaskSetResult.failed`    Returns :const:`True` if any of the subtasks failed.* :meth:`~celery.result.TaskSetResult.waiting`    Returns :const:`True` if any of the subtasks    is not ready yet.* :meth:`~celery.result.TaskSetResult.ready`    Return :const:`True` if all of the subtasks    are ready.* :meth:`~celery.result.TaskSetResult.completed_count`    Returns the number of completed subtasks.* :meth:`~celery.result.TaskSetResult.revoke`    Revokes all of the subtasks.* :meth:`~celery.result.TaskSetResult.iterate`    Iterates over the return values of the subtasks    as they finish, one by one.* :meth:`~celery.result.TaskSetResult.join`    Gather the results for all of the subtasks    and return a list with them ordered by the order of which they    were called... _chords:Chords======.. versionadded:: 2.3A chord is a task that only executes after all of the tasks in a taskset hasfinished executing.Let's calculate the sum of the expression:math:`1 + 1 + 2 + 2 + 3 + 3 ... n + n` up to a hundred digits.First we need two tasks, :func:`add` and :func:`tsum` (:func:`sum` isalready a standard function):.. code-block:: python    @celery.task    def add(x, y):        return x + y    @celery.task    def tsum(numbers):        return sum(numbers)Now we can use a chord to calculate each addition step in parallel, and thenget the sum of the resulting numbers::    >>> from celery import chord    >>> from tasks import add, tsum    >>> chord(add.subtask((i, i))    ...     for i in xrange(100))(tsum.subtask()).get()    9900This is obviously a very contrived example, the overhead of messaging andsynchronization makes this a lot slower than its Python counterpart::    sum(i + i for i in xrange(100))The synchronization step is costly, so you should avoid using chords as muchas possible. Still, the chord is a powerful primitive to have in your toolboxas synchronization is a required step for many parallel algorithms.Let's break the chord expression down::    >>> callback = tsum.subtask()    >>> header = [add.subtask((i, i)) for i in xrange(100)]    >>> result = chord(header)(callback)    >>> result.get()    9900Remember, the callback can only be executed after all of the tasks in theheader has returned.  Each step in the header is executed as a task, inparallel, possibly on different nodes.  The callback is then applied withthe return value of each task in the header.  The task id returned by:meth:`chord` is the id of the callback, so you can wait for it to completeand get the final return value (but remember to :ref:`never have a task waitfor other tasks <task-synchronous-subtasks>`).. _chord-important-notes:Important Notes---------------By default the synchronization step is implemented by having a recurring taskpoll the completion of the taskset every second, applying the subtask whenready.Example implementation:.. code-block:: python    def unlock_chord(taskset, callback, interval=1, max_retries=None):        if taskset.ready():            return subtask(callback).delay(taskset.join())        raise unlock_chord.retry(countdown=interval, max_retries=max_retries)This is used by all result backends except Redis and Memcached, which increment acounter after each task in the header, then applying the callback when thecounter exceeds the number of tasks in the set. *Note:* chords do not properlywork with Redis before version 2.2; you will need to upgrade to at least 2.2 touse them.The Redis and Memcached approach is a much better solution, but not easilyimplemented in other backends (suggestions welcome!)... note::    If you are using chords with the Redis result backend and also overriding    the :meth:`Task.after_return` method, you need to make sure to call the    super method or else the chord callback will not be applied.    .. code-block:: python        def after_return(self, *args, **kwargs):            do_something()            super(MyTask, self).after_return(*args, **kwargs)
 |