canvas.py 49 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401
  1. # -*- coding: utf-8 -*-
  2. """Composing task work-flows.
  3. .. seealso:
  4. You should import these from :mod:`celery` and not this module.
  5. """
  6. from __future__ import absolute_import, unicode_literals
  7. import itertools
  8. import operator
  9. from collections import MutableSequence, deque
  10. from copy import deepcopy
  11. from functools import partial as _partial
  12. from functools import reduce
  13. from operator import itemgetter
  14. from kombu.utils.functional import fxrange, reprcall
  15. from kombu.utils.objects import cached_property
  16. from kombu.utils.uuid import uuid
  17. from vine import barrier
  18. from celery._state import current_app
  19. from celery.five import PY3, python_2_unicode_compatible
  20. from celery.local import try_import
  21. from celery.result import GroupResult, allow_join_result
  22. from celery.utils import abstract
  23. from celery.utils.functional import _regen
  24. from celery.utils.functional import chunks as _chunks
  25. from celery.utils.functional import (is_list, maybe_list, regen,
  26. seq_concat_item, seq_concat_seq)
  27. from celery.utils.objects import getitem_property
  28. from celery.utils.text import remove_repeating_from_task, truncate
  29. __all__ = (
  30. 'Signature', 'chain', 'xmap', 'xstarmap', 'chunks',
  31. 'group', 'chord', 'signature', 'maybe_signature',
  32. )
  33. # json in Python 2.7 borks if dict contains byte keys.
  34. JSON_NEEDS_UNICODE_KEYS = PY3 and not try_import('simplejson')
  35. def maybe_unroll_group(g):
  36. """Unroll group with only one member."""
  37. # Issue #1656
  38. try:
  39. size = len(g.tasks)
  40. except TypeError:
  41. try:
  42. size = g.tasks.__length_hint__()
  43. except (AttributeError, TypeError):
  44. return g
  45. else:
  46. return list(g.tasks)[0] if size == 1 else g
  47. else:
  48. return g.tasks[0] if size == 1 else g
  49. def task_name_from(task):
  50. return getattr(task, 'name', task)
  51. def _upgrade(fields, sig):
  52. """Used by custom signatures in .from_dict, to keep common fields."""
  53. sig.update(chord_size=fields.get('chord_size'))
  54. return sig
  55. @abstract.CallableSignature.register
  56. @python_2_unicode_compatible
  57. class Signature(dict):
  58. """Task Signature.
  59. Class that wraps the arguments and execution options
  60. for a single task invocation.
  61. Used as the parts in a :class:`group` and other constructs,
  62. or to pass tasks around as callbacks while being compatible
  63. with serializers with a strict type subset.
  64. Signatures can also be created from tasks:
  65. - Using the ``.signature()`` method that has the same signature
  66. as ``Task.apply_async``:
  67. .. code-block:: pycon
  68. >>> add.signature(args=(1,), kwargs={'kw': 2}, options={})
  69. - or the ``.s()`` shortcut that works for star arguments:
  70. .. code-block:: pycon
  71. >>> add.s(1, kw=2)
  72. - the ``.s()`` shortcut does not allow you to specify execution options
  73. but there's a chaning `.set` method that returns the signature:
  74. .. code-block:: pycon
  75. >>> add.s(2, 2).set(countdown=10).set(expires=30).delay()
  76. Note:
  77. You should use :func:`~celery.signature` to create new signatures.
  78. The ``Signature`` class is the type returned by that function and
  79. should be used for ``isinstance`` checks for signatures.
  80. See Also:
  81. :ref:`guide-canvas` for the complete guide.
  82. Arguments:
  83. task (Task, str): Either a task class/instance, or the name of a task.
  84. args (Tuple): Positional arguments to apply.
  85. kwargs (Dict): Keyword arguments to apply.
  86. options (Dict): Additional options to :meth:`Task.apply_async`.
  87. Note:
  88. If the first argument is a :class:`dict`, the other
  89. arguments will be ignored and the values in the dict will be used
  90. instead::
  91. >>> s = signature('tasks.add', args=(2, 2))
  92. >>> signature(s)
  93. {'task': 'tasks.add', args=(2, 2), kwargs={}, options={}}
  94. """
  95. TYPES = {}
  96. _app = _type = None
  97. @classmethod
  98. def register_type(cls, name=None):
  99. def _inner(subclass):
  100. cls.TYPES[name or subclass.__name__] = subclass
  101. return subclass
  102. return _inner
  103. @classmethod
  104. def from_dict(cls, d, app=None):
  105. typ = d.get('subtask_type')
  106. if typ:
  107. target_cls = cls.TYPES[typ]
  108. if target_cls is not cls:
  109. return target_cls.from_dict(d, app=app)
  110. return Signature(d, app=app)
  111. def __init__(self, task=None, args=None, kwargs=None, options=None,
  112. type=None, subtask_type=None, immutable=False,
  113. app=None, **ex):
  114. self._app = app
  115. if isinstance(task, dict):
  116. super(Signature, self).__init__(task) # works like dict(d)
  117. else:
  118. # Also supports using task class/instance instead of string name.
  119. try:
  120. task_name = task.name
  121. except AttributeError:
  122. task_name = task
  123. else:
  124. self._type = task
  125. super(Signature, self).__init__(
  126. task=task_name, args=tuple(args or ()),
  127. kwargs=kwargs or {},
  128. options=dict(options or {}, **ex),
  129. subtask_type=subtask_type,
  130. immutable=immutable,
  131. chord_size=None,
  132. )
  133. def __call__(self, *partial_args, **partial_kwargs):
  134. """Call the task directly (in the current process)."""
  135. args, kwargs, _ = self._merge(partial_args, partial_kwargs, None)
  136. return self.type(*args, **kwargs)
  137. def delay(self, *partial_args, **partial_kwargs):
  138. """Shortcut to :meth:`apply_async` using star arguments."""
  139. return self.apply_async(partial_args, partial_kwargs)
  140. def apply(self, args=(), kwargs={}, **options):
  141. """Call task locally.
  142. Same as :meth:`apply_async` but executed the task inline instead
  143. of sending a task message.
  144. """
  145. # For callbacks: extra args are prepended to the stored args.
  146. args, kwargs, options = self._merge(args, kwargs, options)
  147. return self.type.apply(args, kwargs, **options)
  148. def apply_async(self, args=(), kwargs={}, route_name=None, **options):
  149. """Apply this task asynchronously.
  150. Arguments:
  151. args (Tuple): Partial args to be prepended to the existing args.
  152. kwargs (Dict): Partial kwargs to be merged with existing kwargs.
  153. options (Dict): Partial options to be merged
  154. with existing options.
  155. Returns:
  156. ~@AsyncResult: promise of future evaluation.
  157. See also:
  158. :meth:`~@Task.apply_async` and the :ref:`guide-calling` guide.
  159. """
  160. try:
  161. _apply = self._apply_async
  162. except IndexError: # pragma: no cover
  163. # no tasks for chain, etc to find type
  164. return
  165. # For callbacks: extra args are prepended to the stored args.
  166. if args or kwargs or options:
  167. args, kwargs, options = self._merge(args, kwargs, options)
  168. else:
  169. args, kwargs, options = self.args, self.kwargs, self.options
  170. # pylint: disable=too-many-function-args
  171. # Borks on this, as it's a property
  172. return _apply(args, kwargs, **options)
  173. def _merge(self, args=(), kwargs={}, options={}, force=False):
  174. if self.immutable and not force:
  175. return (self.args, self.kwargs,
  176. dict(self.options, **options) if options else self.options)
  177. return (tuple(args) + tuple(self.args) if args else self.args,
  178. dict(self.kwargs, **kwargs) if kwargs else self.kwargs,
  179. dict(self.options, **options) if options else self.options)
  180. def clone(self, args=(), kwargs={}, **opts):
  181. """Create a copy of this signature.
  182. Arguments:
  183. args (Tuple): Partial args to be prepended to the existing args.
  184. kwargs (Dict): Partial kwargs to be merged with existing kwargs.
  185. options (Dict): Partial options to be merged with
  186. existing options.
  187. """
  188. # need to deepcopy options so origins links etc. is not modified.
  189. if args or kwargs or opts:
  190. args, kwargs, opts = self._merge(args, kwargs, opts)
  191. else:
  192. args, kwargs, opts = self.args, self.kwargs, self.options
  193. s = Signature.from_dict({'task': self.task, 'args': tuple(args),
  194. 'kwargs': kwargs, 'options': deepcopy(opts),
  195. 'subtask_type': self.subtask_type,
  196. 'chord_size': self.chord_size,
  197. 'immutable': self.immutable}, app=self._app)
  198. s._type = self._type
  199. return s
  200. partial = clone
  201. def freeze(self, _id=None, group_id=None, chord=None,
  202. root_id=None, parent_id=None):
  203. """Finalize the signature by adding a concrete task id.
  204. The task won't be called and you shouldn't call the signature
  205. twice after freezing it as that'll result in two task messages
  206. using the same task id.
  207. Returns:
  208. ~@AsyncResult: promise of future evaluation.
  209. """
  210. # pylint: disable=redefined-outer-name
  211. # XXX chord is also a class in outer scope.
  212. opts = self.options
  213. try:
  214. tid = opts['task_id']
  215. except KeyError:
  216. tid = opts['task_id'] = _id or uuid()
  217. if root_id:
  218. opts['root_id'] = root_id
  219. if parent_id:
  220. opts['parent_id'] = parent_id
  221. if 'reply_to' not in opts:
  222. opts['reply_to'] = self.app.oid
  223. if group_id:
  224. opts['group_id'] = group_id
  225. if chord:
  226. opts['chord'] = chord
  227. # pylint: disable=too-many-function-args
  228. # Borks on this, as it's a property.
  229. return self.AsyncResult(tid)
  230. _freeze = freeze
  231. def replace(self, args=None, kwargs=None, options=None):
  232. """Replace the args, kwargs or options set for this signature.
  233. These are only replaced if the argument for the section is
  234. not :const:`None`.
  235. """
  236. s = self.clone()
  237. if args is not None:
  238. s.args = args
  239. if kwargs is not None:
  240. s.kwargs = kwargs
  241. if options is not None:
  242. s.options = options
  243. return s
  244. def set(self, immutable=None, **options):
  245. """Set arbitrary execution options (same as ``.options.update(…)``).
  246. Returns:
  247. Signature: This is a chaining method call
  248. (i.e., it will return ``self``).
  249. """
  250. if immutable is not None:
  251. self.set_immutable(immutable)
  252. self.options.update(options)
  253. return self
  254. def set_immutable(self, immutable):
  255. self.immutable = immutable
  256. def _with_list_option(self, key):
  257. items = self.options.setdefault(key, [])
  258. if not isinstance(items, MutableSequence):
  259. items = self.options[key] = [items]
  260. return items
  261. def append_to_list_option(self, key, value):
  262. items = self._with_list_option(key)
  263. if value not in items:
  264. items.append(value)
  265. return value
  266. def extend_list_option(self, key, value):
  267. items = self._with_list_option(key)
  268. items.extend(maybe_list(value))
  269. def link(self, callback):
  270. """Add callback task to be applied if this task succeeds.
  271. Returns:
  272. Signature: the argument passed, for chaining
  273. or use with :func:`~functools.reduce`.
  274. """
  275. return self.append_to_list_option('link', callback)
  276. def link_error(self, errback):
  277. """Add callback task to be applied on error in task execution.
  278. Returns:
  279. Signature: the argument passed, for chaining
  280. or use with :func:`~functools.reduce`.
  281. """
  282. return self.append_to_list_option('link_error', errback)
  283. def on_error(self, errback):
  284. """Version of :meth:`link_error` that supports chaining.
  285. on_error chains the original signature, not the errback so::
  286. >>> add.s(2, 2).on_error(errback.s()).delay()
  287. calls the ``add`` task, not the ``errback`` task, but the
  288. reverse is true for :meth:`link_error`.
  289. """
  290. self.link_error(errback)
  291. return self
  292. def flatten_links(self):
  293. """Return a recursive list of dependencies.
  294. "unchain" if you will, but with links intact.
  295. """
  296. return list(itertools.chain.from_iterable(itertools.chain(
  297. [[self]],
  298. (link.flatten_links()
  299. for link in maybe_list(self.options.get('link')) or [])
  300. )))
  301. def __or__(self, other):
  302. # These could be implemented in each individual class,
  303. # I'm sure, but for now we have this.
  304. if isinstance(self, group):
  305. if isinstance(other, group):
  306. # group() | group() -> single group
  307. return group(
  308. itertools.chain(self.tasks, other.tasks), app=self.app)
  309. # group() | task -> chord
  310. return chord(self, body=other, app=self._app)
  311. elif isinstance(other, group):
  312. # unroll group with one member
  313. other = maybe_unroll_group(other)
  314. if isinstance(self, _chain):
  315. # chain | group() -> chain
  316. return _chain(seq_concat_item(
  317. self.unchain_tasks(), other), app=self._app)
  318. # task | group() -> chain
  319. return _chain(self, other, app=self.app)
  320. if not isinstance(self, _chain) and isinstance(other, _chain):
  321. # task | chain -> chain
  322. return _chain(seq_concat_seq(
  323. (self,), other.unchain_tasks()), app=self._app)
  324. elif isinstance(other, _chain):
  325. # chain | chain -> chain
  326. return _chain(seq_concat_seq(
  327. self.unchain_tasks(), other.unchain_tasks()), app=self._app)
  328. elif isinstance(self, chord):
  329. # chord | task -> attach to body
  330. sig = self.clone()
  331. sig.body = sig.body | other
  332. return sig
  333. elif isinstance(other, Signature):
  334. if isinstance(self, _chain):
  335. if self.tasks and isinstance(self.tasks[-1], group):
  336. # CHAIN [last item is group] | TASK -> chord
  337. sig = self.clone()
  338. sig.tasks[-1] = chord(
  339. sig.tasks[-1], other, app=self._app)
  340. return sig
  341. elif self.tasks and isinstance(self.tasks[-1], chord):
  342. # CHAIN [last item is chord] -> chain with chord body.
  343. sig = self.clone()
  344. sig.tasks[-1].body = sig.tasks[-1].body | other
  345. return sig
  346. else:
  347. # chain | task -> chain
  348. return _chain(seq_concat_item(
  349. self.unchain_tasks(), other), app=self._app)
  350. # task | task -> chain
  351. return _chain(self, other, app=self._app)
  352. return NotImplemented
  353. def election(self):
  354. type = self.type
  355. app = type.app
  356. tid = self.options.get('task_id') or uuid()
  357. with app.producer_or_acquire(None) as P:
  358. props = type.backend.on_task_call(P, tid)
  359. app.control.election(tid, 'task', self.clone(task_id=tid, **props),
  360. connection=P.connection)
  361. return type.AsyncResult(tid)
  362. def reprcall(self, *args, **kwargs):
  363. args, kwargs, _ = self._merge(args, kwargs, {}, force=True)
  364. return reprcall(self['task'], args, kwargs)
  365. def __deepcopy__(self, memo):
  366. memo[id(self)] = self
  367. return dict(self)
  368. def __invert__(self):
  369. return self.apply_async().get()
  370. def __reduce__(self):
  371. # for serialization, the task type is lazily loaded,
  372. # and not stored in the dict itself.
  373. return signature, (dict(self),)
  374. def __json__(self):
  375. return dict(self)
  376. def __repr__(self):
  377. return self.reprcall()
  378. if JSON_NEEDS_UNICODE_KEYS: # pragma: no cover
  379. def items(self):
  380. for k, v in dict.items(self):
  381. yield k.decode() if isinstance(k, bytes) else k, v
  382. @property
  383. def name(self):
  384. # for duck typing compatibility with Task.name
  385. return self.task
  386. @cached_property
  387. def type(self):
  388. return self._type or self.app.tasks[self['task']]
  389. @cached_property
  390. def app(self):
  391. return self._app or current_app
  392. @cached_property
  393. def AsyncResult(self):
  394. try:
  395. return self.type.AsyncResult
  396. except KeyError: # task not registered
  397. return self.app.AsyncResult
  398. @cached_property
  399. def _apply_async(self):
  400. try:
  401. return self.type.apply_async
  402. except KeyError:
  403. return _partial(self.app.send_task, self['task'])
  404. id = getitem_property('options.task_id', 'Task UUID')
  405. parent_id = getitem_property('options.parent_id', 'Task parent UUID.')
  406. root_id = getitem_property('options.root_id', 'Task root UUID.')
  407. task = getitem_property('task', 'Name of task.')
  408. args = getitem_property('args', 'Positional arguments to task.')
  409. kwargs = getitem_property('kwargs', 'Keyword arguments to task.')
  410. options = getitem_property('options', 'Task execution options.')
  411. subtask_type = getitem_property('subtask_type', 'Type of signature')
  412. chord_size = getitem_property(
  413. 'chord_size', 'Size of chord (if applicable)')
  414. immutable = getitem_property(
  415. 'immutable', 'Flag set if no longer accepts new arguments')
  416. @Signature.register_type(name='chain')
  417. @python_2_unicode_compatible
  418. class _chain(Signature):
  419. tasks = getitem_property('kwargs.tasks', 'Tasks in chain.')
  420. @classmethod
  421. def from_dict(cls, d, app=None):
  422. tasks = d['kwargs']['tasks']
  423. if tasks:
  424. if isinstance(tasks, tuple): # aaaargh
  425. tasks = d['kwargs']['tasks'] = list(tasks)
  426. tasks = [maybe_signature(task, app=app) for task in tasks]
  427. return _upgrade(d, _chain(tasks, app=app, **d['options']))
  428. def __init__(self, *tasks, **options):
  429. tasks = (regen(tasks[0]) if len(tasks) == 1 and is_list(tasks[0])
  430. else tasks)
  431. Signature.__init__(
  432. self, 'celery.chain', (), {'tasks': tasks}, **options
  433. )
  434. self._use_link = options.pop('use_link', None)
  435. self.subtask_type = 'chain'
  436. self._frozen = None
  437. def __call__(self, *args, **kwargs):
  438. if self.tasks:
  439. return self.apply_async(args, kwargs)
  440. def clone(self, *args, **kwargs):
  441. to_signature = maybe_signature
  442. s = Signature.clone(self, *args, **kwargs)
  443. s.kwargs['tasks'] = [
  444. to_signature(sig, app=self._app, clone=True)
  445. for sig in s.kwargs['tasks']
  446. ]
  447. return s
  448. def unchain_tasks(self):
  449. # Clone chain's tasks assigning sugnatures from link_error
  450. # to each task
  451. tasks = [t.clone() for t in self.tasks]
  452. for sig in self.options.get('link_error', []):
  453. for task in tasks:
  454. task.link_error(sig)
  455. return tasks
  456. def apply_async(self, args=(), kwargs={}, **options):
  457. # python is best at unpacking kwargs, so .run is here to do that.
  458. app = self.app
  459. if app.conf.task_always_eager:
  460. with allow_join_result():
  461. return self.apply(args, kwargs, **options)
  462. return self.run(args, kwargs, app=app, **(
  463. dict(self.options, **options) if options else self.options))
  464. def run(self, args=(), kwargs={}, group_id=None, chord=None,
  465. task_id=None, link=None, link_error=None, publisher=None,
  466. producer=None, root_id=None, parent_id=None, app=None, **options):
  467. # pylint: disable=redefined-outer-name
  468. # XXX chord is also a class in outer scope.
  469. app = app or self.app
  470. use_link = self._use_link
  471. if use_link is None and app.conf.task_protocol == 1:
  472. use_link = True
  473. args = (tuple(args) + tuple(self.args)
  474. if args and not self.immutable else self.args)
  475. tasks, results = self.prepare_steps(
  476. args, kwargs, self.tasks, root_id, parent_id, link_error, app,
  477. task_id, group_id, chord,
  478. )
  479. if results:
  480. if link:
  481. tasks[0].extend_list_option('link', link)
  482. first_task = tasks.pop()
  483. # chain option may already be set, resulting in
  484. # "multiple values for keyword argument 'chain'" error.
  485. # Issue #3379.
  486. options['chain'] = tasks if not use_link else None
  487. first_task.apply_async(**options)
  488. return results[0]
  489. def freeze(self, _id=None, group_id=None, chord=None,
  490. root_id=None, parent_id=None):
  491. # pylint: disable=redefined-outer-name
  492. # XXX chord is also a class in outer scope.
  493. _, results = self._frozen = self.prepare_steps(
  494. self.args, self.kwargs, self.tasks, root_id, parent_id, None,
  495. self.app, _id, group_id, chord, clone=False,
  496. )
  497. return results[0]
  498. def prepare_steps(self, args, kwargs, tasks,
  499. root_id=None, parent_id=None, link_error=None, app=None,
  500. last_task_id=None, group_id=None, chord_body=None,
  501. clone=True, from_dict=Signature.from_dict):
  502. app = app or self.app
  503. # use chain message field for protocol 2 and later.
  504. # this avoids pickle blowing the stack on the recursion
  505. # required by linking task together in a tree structure.
  506. # (why is pickle using recursion? or better yet why cannot python
  507. # do tail call optimization making recursion actually useful?)
  508. use_link = self._use_link
  509. if use_link is None and app.conf.task_protocol == 1:
  510. use_link = True
  511. steps = deque(tasks)
  512. steps_pop = steps.pop
  513. steps_extend = steps.extend
  514. prev_task = None
  515. prev_res = None
  516. tasks, results = [], []
  517. i = 0
  518. # NOTE: We are doing this in reverse order.
  519. # The result is a list of tasks in reverse order, that is
  520. # passed as the ``chain`` message field.
  521. # As it's reversed the worker can just do ``chain.pop()`` to
  522. # get the next task in the chain.
  523. while steps:
  524. task = steps_pop()
  525. is_first_task, is_last_task = not steps, not i
  526. if not isinstance(task, abstract.CallableSignature):
  527. task = from_dict(task, app=app)
  528. if isinstance(task, group):
  529. task = maybe_unroll_group(task)
  530. # first task gets partial args from chain
  531. if clone:
  532. if is_first_task:
  533. task = task.clone(args, kwargs)
  534. else:
  535. task = task.clone()
  536. elif is_first_task:
  537. task.args = tuple(args) + tuple(task.args)
  538. if isinstance(task, _chain):
  539. # splice the chain
  540. steps_extend(task.tasks)
  541. continue
  542. if isinstance(task, group) and prev_task:
  543. # automatically upgrade group(...) | s to chord(group, s)
  544. # for chords we freeze by pretending it's a normal
  545. # signature instead of a group.
  546. tasks.pop()
  547. results.pop()
  548. task = chord(
  549. task, body=prev_task,
  550. task_id=prev_res.task_id, root_id=root_id, app=app,
  551. )
  552. if is_last_task:
  553. # chain(task_id=id) means task id is set for the last task
  554. # in the chain. If the chord is part of a chord/group
  555. # then that chord/group must synchronize based on the
  556. # last task in the chain, so we only set the group_id and
  557. # chord callback for the last task.
  558. res = task.freeze(
  559. last_task_id,
  560. root_id=root_id, group_id=group_id, chord=chord_body,
  561. )
  562. else:
  563. res = task.freeze(root_id=root_id)
  564. i += 1
  565. if prev_task:
  566. if use_link:
  567. # link previous task to this task.
  568. task.link(prev_task)
  569. if prev_res and not prev_res.parent:
  570. prev_res.parent = res
  571. if link_error:
  572. for errback in maybe_list(link_error):
  573. task.link_error(errback)
  574. tasks.append(task)
  575. results.append(res)
  576. prev_task, prev_res = task, res
  577. if isinstance(task, chord):
  578. app.backend.ensure_chords_allowed()
  579. # If the task is a chord, and the body is a chain
  580. # the chain has already been prepared, and res is
  581. # set to the last task in the callback chain.
  582. # We need to change that so that it points to the
  583. # group result object.
  584. node = res
  585. while node.parent:
  586. node = node.parent
  587. prev_res = node
  588. return tasks, results
  589. def apply(self, args=(), kwargs={}, **options):
  590. last, (fargs, fkwargs) = None, (args, kwargs)
  591. for task in self.tasks:
  592. res = task.clone(fargs, fkwargs).apply(
  593. last and (last.get(),), **dict(self.options, **options))
  594. res.parent, last, (fargs, fkwargs) = last, res, (None, None)
  595. return last
  596. @property
  597. def app(self):
  598. app = self._app
  599. if app is None:
  600. try:
  601. app = self.tasks[0]._app
  602. except LookupError:
  603. pass
  604. return app or current_app
  605. def __repr__(self):
  606. if not self.tasks:
  607. return '<{0}@{1:#x}: empty>'.format(
  608. type(self).__name__, id(self))
  609. return remove_repeating_from_task(
  610. self.tasks[0]['task'],
  611. ' | '.join(repr(t) for t in self.tasks))
  612. class chain(_chain):
  613. """Chain tasks together.
  614. Each tasks follows one another,
  615. by being applied as a callback of the previous task.
  616. Note:
  617. If called with only one argument, then that argument must
  618. be an iterable of tasks to chain: this allows us
  619. to use generator expressions.
  620. Example:
  621. This is effectively :math:`((2 + 2) + 4)`:
  622. .. code-block:: pycon
  623. >>> res = chain(add.s(2, 2), add.s(4))()
  624. >>> res.get()
  625. 8
  626. Calling a chain will return the result of the last task in the chain.
  627. You can get to the other tasks by following the ``result.parent``'s:
  628. .. code-block:: pycon
  629. >>> res.parent.get()
  630. 4
  631. Using a generator expression:
  632. .. code-block:: pycon
  633. >>> lazy_chain = chain(add.s(i) for i in range(10))
  634. >>> res = lazy_chain(3)
  635. Arguments:
  636. *tasks (Signature): List of task signatures to chain.
  637. If only one argument is passed and that argument is
  638. an iterable, then that'll be used as the list of signatures
  639. to chain instead. This means that you can use a generator
  640. expression.
  641. Returns:
  642. ~celery.chain: A lazy signature that can be called to apply the first
  643. task in the chain. When that task succeeed the next task in the
  644. chain is applied, and so on.
  645. """
  646. # could be function, but must be able to reference as :class:`chain`.
  647. def __new__(cls, *tasks, **kwargs):
  648. # This forces `chain(X, Y, Z)` to work the same way as `X | Y | Z`
  649. if not kwargs and tasks:
  650. if len(tasks) != 1 or is_list(tasks[0]):
  651. tasks = tasks[0] if len(tasks) == 1 else tasks
  652. return reduce(operator.or_, tasks)
  653. return super(chain, cls).__new__(cls, *tasks, **kwargs)
  654. class _basemap(Signature):
  655. _task_name = None
  656. _unpack_args = itemgetter('task', 'it')
  657. @classmethod
  658. def from_dict(cls, d, app=None):
  659. return _upgrade(
  660. d, cls(*cls._unpack_args(d['kwargs']), app=app, **d['options']),
  661. )
  662. def __init__(self, task, it, **options):
  663. Signature.__init__(
  664. self, self._task_name, (),
  665. {'task': task, 'it': regen(it)}, immutable=True, **options
  666. )
  667. def apply_async(self, args=(), kwargs={}, **opts):
  668. # need to evaluate generators
  669. task, it = self._unpack_args(self.kwargs)
  670. return self.type.apply_async(
  671. (), {'task': task, 'it': list(it)},
  672. route_name=task_name_from(self.kwargs.get('task')), **opts
  673. )
  674. @Signature.register_type()
  675. @python_2_unicode_compatible
  676. class xmap(_basemap):
  677. """Map operation for tasks.
  678. Note:
  679. Tasks executed sequentially in process, this is not a
  680. parallel operation like :class:`group`.
  681. """
  682. _task_name = 'celery.map'
  683. def __repr__(self):
  684. task, it = self._unpack_args(self.kwargs)
  685. return '[{0}(x) for x in {1}]'.format(
  686. task.task, truncate(repr(it), 100))
  687. @Signature.register_type()
  688. @python_2_unicode_compatible
  689. class xstarmap(_basemap):
  690. """Map operation for tasks, using star arguments."""
  691. _task_name = 'celery.starmap'
  692. def __repr__(self):
  693. task, it = self._unpack_args(self.kwargs)
  694. return '[{0}(*x) for x in {1}]'.format(
  695. task.task, truncate(repr(it), 100))
  696. @Signature.register_type()
  697. class chunks(Signature):
  698. """Partition of tasks in n chunks."""
  699. _unpack_args = itemgetter('task', 'it', 'n')
  700. @classmethod
  701. def from_dict(cls, d, app=None):
  702. return _upgrade(
  703. d, chunks(*cls._unpack_args(
  704. d['kwargs']), app=app, **d['options']),
  705. )
  706. def __init__(self, task, it, n, **options):
  707. Signature.__init__(
  708. self, 'celery.chunks', (),
  709. {'task': task, 'it': regen(it), 'n': n},
  710. immutable=True, **options
  711. )
  712. def __call__(self, **options):
  713. return self.apply_async(**options)
  714. def apply_async(self, args=(), kwargs={}, **opts):
  715. return self.group().apply_async(
  716. args, kwargs,
  717. route_name=task_name_from(self.kwargs.get('task')), **opts
  718. )
  719. def group(self):
  720. # need to evaluate generators
  721. task, it, n = self._unpack_args(self.kwargs)
  722. return group((xstarmap(task, part, app=self._app)
  723. for part in _chunks(iter(it), n)),
  724. app=self._app)
  725. @classmethod
  726. def apply_chunks(cls, task, it, n, app=None):
  727. return cls(task, it, n, app=app)()
  728. def _maybe_group(tasks, app):
  729. if isinstance(tasks, dict):
  730. tasks = signature(tasks, app=app)
  731. if isinstance(tasks, (group, _chain)):
  732. tasks = tasks.tasks
  733. elif isinstance(tasks, abstract.CallableSignature):
  734. tasks = [tasks]
  735. else:
  736. tasks = [signature(t, app=app) for t in tasks]
  737. return tasks
  738. @Signature.register_type()
  739. @python_2_unicode_compatible
  740. class group(Signature):
  741. """Creates a group of tasks to be executed in parallel.
  742. A group is lazy so you must call it to take action and evaluate
  743. the group.
  744. Note:
  745. If only one argument is passed, and that argument is an iterable
  746. then that'll be used as the list of tasks instead: this
  747. allows us to use ``group`` with generator expressions.
  748. Example:
  749. >>> lazy_group = group([add.s(2, 2), add.s(4, 4)])
  750. >>> promise = lazy_group() # <-- evaluate: returns lazy result.
  751. >>> promise.get() # <-- will wait for the task to return
  752. [4, 8]
  753. Arguments:
  754. *tasks (List[Signature]): A list of signatures that this group will
  755. call. If there's only one argument, and that argument is an
  756. iterable, then that'll define the list of signatures instead.
  757. **options (Any): Execution options applied to all tasks
  758. in the group.
  759. Returns:
  760. ~celery.group: signature that when called will then call all of the
  761. tasks in the group (and return a :class:`GroupResult` instance
  762. that can be used to inspect the state of the group).
  763. """
  764. tasks = getitem_property('kwargs.tasks', 'Tasks in group.')
  765. @classmethod
  766. def from_dict(cls, d, app=None):
  767. return _upgrade(
  768. d, group(d['kwargs']['tasks'], app=app, **d['options']),
  769. )
  770. def __init__(self, *tasks, **options):
  771. if len(tasks) == 1:
  772. tasks = tasks[0]
  773. if isinstance(tasks, group):
  774. tasks = tasks.tasks
  775. if isinstance(tasks, abstract.CallableSignature):
  776. tasks = [tasks.clone()]
  777. if not isinstance(tasks, _regen):
  778. tasks = regen(tasks)
  779. Signature.__init__(
  780. self, 'celery.group', (), {'tasks': tasks}, **options
  781. )
  782. self.subtask_type = 'group'
  783. def __call__(self, *partial_args, **options):
  784. return self.apply_async(partial_args, **options)
  785. def skew(self, start=1.0, stop=None, step=1.0):
  786. it = fxrange(start, stop, step, repeatlast=True)
  787. for task in self.tasks:
  788. task.set(countdown=next(it))
  789. return self
  790. def apply_async(self, args=(), kwargs=None, add_to_parent=True,
  791. producer=None, link=None, link_error=None, **options):
  792. if link is not None:
  793. raise TypeError('Cannot add link to group: use a chord')
  794. if link_error is not None:
  795. raise TypeError(
  796. 'Cannot add link to group: do that on individual tasks')
  797. app = self.app
  798. if app.conf.task_always_eager:
  799. return self.apply(args, kwargs, **options)
  800. if not self.tasks:
  801. return self.freeze()
  802. options, group_id, root_id = self._freeze_gid(options)
  803. tasks = self._prepared(self.tasks, [], group_id, root_id, app)
  804. p = barrier()
  805. results = list(self._apply_tasks(tasks, producer, app, p,
  806. args=args, kwargs=kwargs, **options))
  807. result = self.app.GroupResult(group_id, results, ready_barrier=p)
  808. p.finalize()
  809. # - Special case of group(A.s() | group(B.s(), C.s()))
  810. # That is, group with single item that's a chain but the
  811. # last task in that chain is a group.
  812. #
  813. # We cannot actually support arbitrary GroupResults in chains,
  814. # but this special case we can.
  815. if len(result) == 1 and isinstance(result[0], GroupResult):
  816. result = result[0]
  817. parent_task = app.current_worker_task
  818. if add_to_parent and parent_task:
  819. parent_task.add_trail(result)
  820. return result
  821. def apply(self, args=(), kwargs={}, **options):
  822. app = self.app
  823. if not self.tasks:
  824. return self.freeze() # empty group returns GroupResult
  825. options, group_id, root_id = self._freeze_gid(options)
  826. tasks = self._prepared(self.tasks, [], group_id, root_id, app)
  827. return app.GroupResult(group_id, [
  828. sig.apply(args=args, kwargs=kwargs, **options) for sig, _ in tasks
  829. ])
  830. def set_immutable(self, immutable):
  831. for task in self.tasks:
  832. task.set_immutable(immutable)
  833. def link(self, sig):
  834. # Simply link to first task
  835. sig = sig.clone().set(immutable=True)
  836. return self.tasks[0].link(sig)
  837. def link_error(self, sig):
  838. sig = sig.clone().set(immutable=True)
  839. return self.tasks[0].link_error(sig)
  840. def _prepared(self, tasks, partial_args, group_id, root_id, app,
  841. CallableSignature=abstract.CallableSignature,
  842. from_dict=Signature.from_dict,
  843. isinstance=isinstance, tuple=tuple):
  844. for task in tasks:
  845. if isinstance(task, CallableSignature):
  846. # local sigs are always of type Signature, and we
  847. # clone them to make sure we don't modify the originals.
  848. task = task.clone()
  849. else:
  850. # serialized sigs must be converted to Signature.
  851. task = from_dict(task, app=app)
  852. if isinstance(task, group):
  853. # needs yield_from :(
  854. unroll = task._prepared(
  855. task.tasks, partial_args, group_id, root_id, app,
  856. )
  857. for taskN, resN in unroll:
  858. yield taskN, resN
  859. else:
  860. if partial_args and not task.immutable:
  861. task.args = tuple(partial_args) + tuple(task.args)
  862. yield task, task.freeze(group_id=group_id, root_id=root_id)
  863. def _apply_tasks(self, tasks, producer=None, app=None, p=None,
  864. add_to_parent=None, chord=None,
  865. args=None, kwargs=None, **options):
  866. # pylint: disable=redefined-outer-name
  867. # XXX chord is also a class in outer scope.
  868. app = app or self.app
  869. with app.producer_or_acquire(producer) as producer:
  870. for sig, res in tasks:
  871. sig.apply_async(producer=producer, add_to_parent=False,
  872. chord=sig.options.get('chord') or chord,
  873. args=args, kwargs=kwargs,
  874. **options)
  875. # adding callback to result, such that it will gradually
  876. # fulfill the barrier.
  877. #
  878. # Using barrier.add would use result.then, but we need
  879. # to add the weak argument here to only create a weak
  880. # reference to the object.
  881. if p and not p.cancelled and not p.ready:
  882. p.size += 1
  883. res.then(p, weak=True)
  884. yield res # <-- r.parent, etc set in the frozen result.
  885. def _freeze_gid(self, options):
  886. # remove task_id and use that as the group_id,
  887. # if we don't remove it then every task will have the same id...
  888. options = dict(self.options, **options)
  889. options['group_id'] = group_id = (
  890. options.pop('task_id', uuid()))
  891. return options, group_id, options.get('root_id')
  892. def freeze(self, _id=None, group_id=None, chord=None,
  893. root_id=None, parent_id=None):
  894. # pylint: disable=redefined-outer-name
  895. # XXX chord is also a class in outer scope.
  896. opts = self.options
  897. try:
  898. gid = opts['task_id']
  899. except KeyError:
  900. gid = opts['task_id'] = uuid()
  901. if group_id:
  902. opts['group_id'] = group_id
  903. if chord:
  904. opts['chord'] = chord
  905. root_id = opts.setdefault('root_id', root_id)
  906. parent_id = opts.setdefault('parent_id', parent_id)
  907. new_tasks = []
  908. # Need to unroll subgroups early so that chord gets the
  909. # right result instance for chord_unlock etc.
  910. results = list(self._freeze_unroll(
  911. new_tasks, group_id, chord, root_id, parent_id,
  912. ))
  913. if isinstance(self.tasks, MutableSequence):
  914. self.tasks[:] = new_tasks
  915. else:
  916. self.tasks = new_tasks
  917. return self.app.GroupResult(gid, results)
  918. _freeze = freeze
  919. def _freeze_unroll(self, new_tasks, group_id, chord, root_id, parent_id):
  920. # pylint: disable=redefined-outer-name
  921. # XXX chord is also a class in outer scope.
  922. stack = deque(self.tasks)
  923. while stack:
  924. task = maybe_signature(stack.popleft(), app=self._app).clone()
  925. if isinstance(task, group):
  926. stack.extendleft(task.tasks)
  927. else:
  928. new_tasks.append(task)
  929. yield task.freeze(group_id=group_id,
  930. chord=chord, root_id=root_id,
  931. parent_id=parent_id)
  932. def __repr__(self):
  933. if self.tasks:
  934. return remove_repeating_from_task(
  935. self.tasks[0]['task'],
  936. 'group({0.tasks!r})'.format(self))
  937. return 'group(<empty>)'
  938. def __len__(self):
  939. return len(self.tasks)
  940. @property
  941. def app(self):
  942. app = self._app
  943. if app is None:
  944. try:
  945. app = self.tasks[0].app
  946. except LookupError:
  947. pass
  948. return app if app is not None else current_app
  949. @Signature.register_type()
  950. @python_2_unicode_compatible
  951. class chord(Signature):
  952. r"""Barrier synchronization primitive.
  953. A chord consists of a header and a body.
  954. The header is a group of tasks that must complete before the callback is
  955. called. A chord is essentially a callback for a group of tasks.
  956. The body is applied with the return values of all the header
  957. tasks as a list.
  958. Example:
  959. The chord:
  960. .. code-block:: pycon
  961. >>> res = chord([add.s(2, 2), add.s(4, 4)])(sum_task.s())
  962. is effectively :math:`\Sigma ((2 + 2) + (4 + 4))`:
  963. .. code-block:: pycon
  964. >>> res.get()
  965. 12
  966. """
  967. @classmethod
  968. def from_dict(cls, d, app=None):
  969. options = d.copy()
  970. args, options['kwargs'] = cls._unpack_args(**options['kwargs'])
  971. return _upgrade(d, cls(*args, app=app, **options))
  972. @staticmethod
  973. def _unpack_args(header=None, body=None, **kwargs):
  974. # Python signatures are better at extracting keys from dicts
  975. # than manually popping things off.
  976. return (header, body), kwargs
  977. def __init__(self, header, body=None, task='celery.chord',
  978. args=(), kwargs={}, app=None, **options):
  979. Signature.__init__(
  980. self, task, args,
  981. {'kwargs': kwargs, 'header': _maybe_group(header, app),
  982. 'body': maybe_signature(body, app=app)}, app=app, **options
  983. )
  984. self.subtask_type = 'chord'
  985. def __call__(self, body=None, **options):
  986. return self.apply_async((), {'body': body} if body else {}, **options)
  987. def freeze(self, _id=None, group_id=None, chord=None,
  988. root_id=None, parent_id=None):
  989. # pylint: disable=redefined-outer-name
  990. # XXX chord is also a class in outer scope.
  991. if not isinstance(self.tasks, group):
  992. self.tasks = group(self.tasks, app=self.app)
  993. header_result = self.tasks.freeze(
  994. parent_id=parent_id, root_id=root_id, chord=self.body)
  995. bodyres = self.body.freeze(_id, root_id=root_id)
  996. # we need to link the body result back to the group result,
  997. # but the body may actually be a chain,
  998. # so find the first result without a parent
  999. node = bodyres
  1000. seen = set()
  1001. while node:
  1002. if node.id in seen:
  1003. raise RuntimeError('Recursive result parents')
  1004. seen.add(node.id)
  1005. if node.parent is None:
  1006. node.parent = header_result
  1007. break
  1008. node = node.parent
  1009. self.id = self.tasks.id
  1010. return bodyres
  1011. def apply_async(self, args=(), kwargs={}, task_id=None,
  1012. producer=None, publisher=None, connection=None,
  1013. router=None, result_cls=None, **options):
  1014. kwargs = kwargs or {}
  1015. args = (tuple(args) + tuple(self.args)
  1016. if args and not self.immutable else self.args)
  1017. body = kwargs.pop('body', None) or self.kwargs['body']
  1018. kwargs = dict(self.kwargs['kwargs'], **kwargs)
  1019. body = body.clone(**options)
  1020. app = self._get_app(body)
  1021. tasks = (self.tasks.clone() if isinstance(self.tasks, group)
  1022. else group(self.tasks, app=app))
  1023. if app.conf.task_always_eager:
  1024. with allow_join_result():
  1025. return self.apply(args, kwargs,
  1026. body=body, task_id=task_id, **options)
  1027. # chord([A, B, ...], C)
  1028. return self.run(tasks, body, args, task_id=task_id, **options)
  1029. def apply(self, args=(), kwargs={}, propagate=True, body=None, **options):
  1030. body = self.body if body is None else body
  1031. tasks = (self.tasks.clone() if isinstance(self.tasks, group)
  1032. else group(self.tasks, app=self.app))
  1033. return body.apply(
  1034. args=(tasks.apply(args, kwargs).get(propagate=propagate),),
  1035. )
  1036. def _traverse_tasks(self, tasks, value=None):
  1037. stack = deque(tasks)
  1038. while stack:
  1039. task = stack.popleft()
  1040. if isinstance(task, group):
  1041. stack.extend(task.tasks)
  1042. else:
  1043. yield task if value is None else value
  1044. def __length_hint__(self):
  1045. tasks = (self.tasks.tasks if isinstance(self.tasks, group)
  1046. else self.tasks)
  1047. return sum(self._traverse_tasks(tasks, 1))
  1048. def run(self, header, body, partial_args, app=None, interval=None,
  1049. countdown=1, max_retries=None, eager=False,
  1050. task_id=None, **options):
  1051. app = app or self._get_app(body)
  1052. group_id = header.options.get('task_id') or uuid()
  1053. root_id = body.options.get('root_id')
  1054. body.chord_size = self.__length_hint__()
  1055. options = dict(self.options, **options) if options else self.options
  1056. if options:
  1057. options.pop('task_id', None)
  1058. body.options.update(options)
  1059. bodyres = body.freeze(task_id, root_id=root_id)
  1060. # Chains should not be passed to the header tasks. See #3771
  1061. options.pop('chain', None)
  1062. # Neither should chords, for deeply nested chords to work
  1063. options.pop('chord', None)
  1064. options.pop('task_id', None)
  1065. header.freeze(group_id=group_id, chord=body, root_id=root_id)
  1066. header_result = header(*partial_args, task_id=group_id, **options)
  1067. if len(header_result) > 0:
  1068. app.backend.apply_chord(
  1069. header_result,
  1070. body,
  1071. interval=interval,
  1072. countdown=countdown,
  1073. max_retries=max_retries,
  1074. )
  1075. # The execution of a chord body is normally triggered by its header's
  1076. # tasks completing. If the header is empty this will never happen, so
  1077. # we execute the body manually here.
  1078. else:
  1079. body.delay([])
  1080. bodyres.parent = header_result
  1081. return bodyres
  1082. def clone(self, *args, **kwargs):
  1083. s = Signature.clone(self, *args, **kwargs)
  1084. # need to make copy of body
  1085. try:
  1086. s.kwargs['body'] = maybe_signature(s.kwargs['body'], clone=True)
  1087. except (AttributeError, KeyError):
  1088. pass
  1089. return s
  1090. def link(self, callback):
  1091. self.body.link(callback)
  1092. return callback
  1093. def link_error(self, errback):
  1094. self.body.link_error(errback)
  1095. return errback
  1096. def set_immutable(self, immutable):
  1097. # changes mutability of header only, not callback.
  1098. for task in self.tasks:
  1099. task.set_immutable(immutable)
  1100. def __repr__(self):
  1101. if self.body:
  1102. if isinstance(self.body, _chain):
  1103. return remove_repeating_from_task(
  1104. self.body.tasks[0]['task'],
  1105. '%({0} | {1!r})'.format(
  1106. self.body.tasks[0].reprcall(self.tasks),
  1107. chain(self.body.tasks[1:], app=self._app),
  1108. ),
  1109. )
  1110. return '%' + remove_repeating_from_task(
  1111. self.body['task'], self.body.reprcall(self.tasks))
  1112. return '<chord without body: {0.tasks!r}>'.format(self)
  1113. @cached_property
  1114. def app(self):
  1115. return self._get_app(self.body)
  1116. def _get_app(self, body=None):
  1117. app = self._app
  1118. if app is None:
  1119. try:
  1120. tasks = self.tasks.tasks # is a group
  1121. except AttributeError:
  1122. tasks = self.tasks
  1123. if len(tasks):
  1124. app = tasks[0]._app
  1125. if app is None and body is not None:
  1126. app = body._app
  1127. return app if app is not None else current_app
  1128. tasks = getitem_property('kwargs.header', 'Tasks in chord header.')
  1129. body = getitem_property('kwargs.body', 'Body task of chord.')
  1130. def signature(varies, *args, **kwargs):
  1131. """Create new signature.
  1132. - if the first argument is a signature already then it's cloned.
  1133. - if the first argument is a dict, then a Signature version is returned.
  1134. Returns:
  1135. Signature: The resulting signature.
  1136. """
  1137. app = kwargs.get('app')
  1138. if isinstance(varies, dict):
  1139. if isinstance(varies, abstract.CallableSignature):
  1140. return varies.clone()
  1141. return Signature.from_dict(varies, app=app)
  1142. return Signature(varies, *args, **kwargs)
  1143. subtask = signature # noqa: E305 XXX compat
  1144. def maybe_signature(d, app=None, clone=False):
  1145. """Ensure obj is a signature, or None.
  1146. Arguments:
  1147. d (Optional[Union[abstract.CallableSignature, Mapping]]):
  1148. Signature or dict-serialized signature.
  1149. app (celery.Celery):
  1150. App to bind signature to.
  1151. clone (bool):
  1152. If d' is already a signature, the signature
  1153. will be cloned when this flag is enabled.
  1154. Returns:
  1155. Optional[abstract.CallableSignature]
  1156. """
  1157. if d is not None:
  1158. if isinstance(d, abstract.CallableSignature):
  1159. if clone:
  1160. d = d.clone()
  1161. elif isinstance(d, dict):
  1162. d = signature(d)
  1163. if app is not None:
  1164. d._app = app
  1165. return d
  1166. maybe_subtask = maybe_signature # noqa: E305 XXX compat