123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327 |
- ===========================================
- :mod:`celery` --- Distributed processing
- ===========================================
- .. currentmodule:: celery
- .. module:: celery
- :synopsis: Distributed processing
- .. moduleauthor:: Ask Solem <ask@celeryproject.org>
- .. sectionauthor:: Ask Solem <ask@celeryproject.org>
- --------------
- This module is the main entry-point for the Celery API.
- It includes commonly needed things for calling tasks,
- and creating Celery applications.
- ===================== ===================================================
- :class:`Celery` celery application instance
- :class:`group` group tasks together
- :class:`chain` chain tasks together
- :class:`chord` chords enable callbacks for groups
- :class:`signature` object describing a task invocation
- :data:`current_app` proxy to the current application instance
- :data:`current_task` proxy to the currently executing task
- ===================== ===================================================
- :class:`Celery` application objects
- -----------------------------------
- .. versionadded:: 2.5
- .. autoclass:: Celery
- .. autoattribute:: user_options
- .. autoattribute:: steps
- .. autoattribute:: current_task
- .. autoattribute:: current_worker_task
- .. autoattribute:: amqp
- .. autoattribute:: backend
- .. autoattribute:: loader
- .. autoattribute:: control
- .. autoattribute:: events
- .. autoattribute:: log
- .. autoattribute:: tasks
- .. autoattribute:: pool
- .. autoattribute:: producer_pool
- .. autoattribute:: Task
- .. autoattribute:: timezone
- .. autoattribute:: builtin_fixups
- .. autoattribute:: oid
- .. automethod:: close
- .. automethod:: signature
- .. automethod:: bugreport
- .. automethod:: config_from_object
- .. automethod:: config_from_envvar
- .. automethod:: autodiscover_tasks
- .. automethod:: add_defaults
- .. automethod:: add_periodic_task
- .. automethod:: setup_security
- .. automethod:: start
- .. automethod:: task
- .. automethod:: send_task
- .. automethod:: gen_task_name
- .. autoattribute:: AsyncResult
- .. autoattribute:: GroupResult
- .. automethod:: worker_main
- .. autoattribute:: Worker
- .. autoattribute:: WorkController
- .. autoattribute:: Beat
- .. automethod:: connection_for_read
- .. automethod:: connection_for_write
- .. automethod:: connection
- .. automethod:: connection_or_acquire
- .. automethod:: producer_or_acquire
- .. automethod:: select_queues
- .. automethod:: now
- .. automethod:: set_current
- .. automethod:: set_default
- .. automethod:: finalize
- .. automethod:: on_init
- .. automethod:: prepare_config
- .. data:: on_configure
- Signal sent when app is loading configuration.
- .. data:: on_after_configure
- Signal sent after app has prepared the configuration.
- .. data:: on_after_finalize
- Signal sent after app has been finalized.
- .. data:: on_after_fork
- Signal sent in child process after fork.
- Canvas primitives
- -----------------
- See :ref:`guide-canvas` for more about creating task work-flows.
- .. class:: group(task1[, task2[, task3[,… taskN]]])
- Creates a group of tasks to be executed in parallel.
- Example:
- .. code-block:: pycon
- >>> res = group([add.s(2, 2), add.s(4, 4)])()
- >>> res.get()
- [4, 8]
- A group is lazy so you must call it to take action and evaluate
- the group.
- Will return a `group` task that when called will then call all of the
- tasks in the group (and return a :class:`GroupResult` instance
- that can be used to inspect the state of the group).
- .. class:: chain(task1[, task2[, task3[,… taskN]]])
- Chains tasks together, so that each tasks follows each other
- by being applied as a callback of the previous task.
- If called with only one argument, then that argument must
- be an iterable of tasks to chain.
- Example:
- .. code-block:: pycon
- >>> res = chain(add.s(2, 2), add.s(4))()
- is effectively :math:`(2 + 2) + 4)`:
- .. code-block:: pycon
- >>> res.get()
- 8
- Calling a chain will return the result of the last task in the chain.
- You can get to the other tasks by following the ``result.parent``'s:
- .. code-block:: pycon
- >>> res.parent.get()
- 4
- .. class:: chord(header[, body])
- A chord consists of a header and a body.
- The header is a group of tasks that must complete before the callback is
- called. A chord is essentially a callback for a group of tasks.
- Example:
- .. code-block:: pycon
- >>> res = chord([add.s(2, 2), add.s(4, 4)])(sum_task.s())
- is effectively :math:`\Sigma ((2 + 2) + (4 + 4))`:
- .. code-block:: pycon
- >>> res.get()
- 12
- The body is applied with the return values of all the header
- tasks as a list.
- .. class:: signature(task=None, args=(), kwargs={}, options={})
- Describes the arguments and execution options for a single task invocation.
- Used as the parts in a :class:`group` or to safely pass
- tasks around as callbacks.
- Signatures can also be created from tasks:
- .. code-block:: pycon
- >>> add.signature(args=(), kwargs={}, options={})
- or the ``.s()`` shortcut:
- .. code-block:: pycon
- >>> add.s(*args, **kwargs)
- :param task: Either a task class/instance, or the name of a task.
- :keyword args: Positional arguments to apply.
- :keyword kwargs: Keyword arguments to apply.
- :keyword options: Additional options to :meth:`Task.apply_async`.
- Note that if the first argument is a :class:`dict`, the other
- arguments will be ignored and the values in the dict will be used
- instead.
- >>> s = app.signature('tasks.add', args=(2, 2))
- >>> app.signature(s)
- {'task': 'tasks.add', args=(2, 2), kwargs={}, options={}}
- .. method:: signature.__call__(*args \*\*kwargs)
- Call the task directly (in the current process).
- .. method:: signature.delay(*args, \*\*kwargs)
- Shortcut to :meth:`apply_async`.
- .. method:: signature.apply_async(args=(), kwargs={}, …)
- Apply this task asynchronously.
- :keyword args: Partial args to be prepended to the existing args.
- :keyword kwargs: Partial kwargs to be merged with the existing kwargs.
- :keyword options: Partial options to be merged with the existing
- options.
- See :meth:`~@Task.apply_async`.
- .. method:: signature.apply(args=(), kwargs={}, …)
- Same as :meth:`apply_async` but executed the task inline instead
- of sending a task message.
- .. method:: signature.freeze(_id=None)
- Finalize the signature by adding a concrete task id.
- The task will not be called and you should not call the signature
- twice after freezing it as that will result in two task messages
- using the same task id.
- :returns: :class:`@AsyncResult` instance.
- .. method:: signature.clone(args=(), kwargs={}, …)
- Return a copy of this signature.
- :keyword args: Partial args to be prepended to the existing args.
- :keyword kwargs: Partial kwargs to be merged with the existing kwargs.
- :keyword options: Partial options to be merged with the existing
- options.
- .. method:: signature.replace(args=None, kwargs=None, options=None)
- Replace the args, kwargs or options set for this signature.
- These are only replaced if the selected is not :const:`None`.
- .. method:: signature.link(other_signature)
- Add a callback task to be applied if this task
- executes successfully.
- :returns: ``other_signature`` (to work with :func:`~functools.reduce`).
- .. method:: signature.link_error(other_signature)
- Add a callback task to be applied if an error occurs
- while executing this task.
- :returns: ``other_signature`` (to work with :func:`~functools.reduce`)
- .. method:: signature.set(…)
- Set arbitrary options (same as ``.options.update(…)``).
- This is a chaining method call (i.e. it will return ``self``).
- .. method:: signature.flatten_links()
- Gives a recursive list of dependencies (unchain if you will,
- but with links intact).
- Proxies
- -------
- .. data:: current_app
- The currently set app for this thread.
- .. data:: current_task
- The task currently being executed
- (only set in the worker, or when eager/apply is used).
|