result.py 34 KB

1234567891011121314151617181920212223242526272829303132333435363738394041424344454647484950515253545556575859606162636465666768697071727374757677787980818283848586878889909192939495969798991001011021031041051061071081091101111121131141151161171181191201211221231241251261271281291301311321331341351361371381391401411421431441451461471481491501511521531541551561571581591601611621631641651661671681691701711721731741751761771781791801811821831841851861871881891901911921931941951961971981992002012022032042052062072082092102112122132142152162172182192202212222232242252262272282292302312322332342352362372382392402412422432442452462472482492502512522532542552562572582592602612622632642652662672682692702712722732742752762772782792802812822832842852862872882892902912922932942952962972982993003013023033043053063073083093103113123133143153163173183193203213223233243253263273283293303313323333343353363373383393403413423433443453463473483493503513523533543553563573583593603613623633643653663673683693703713723733743753763773783793803813823833843853863873883893903913923933943953963973983994004014024034044054064074084094104114124134144154164174184194204214224234244254264274284294304314324334344354364374384394404414424434444454464474484494504514524534544554564574584594604614624634644654664674684694704714724734744754764774784794804814824834844854864874884894904914924934944954964974984995005015025035045055065075085095105115125135145155165175185195205215225235245255265275285295305315325335345355365375385395405415425435445455465475485495505515525535545555565575585595605615625635645655665675685695705715725735745755765775785795805815825835845855865875885895905915925935945955965975985996006016026036046056066076086096106116126136146156166176186196206216226236246256266276286296306316326336346356366376386396406416426436446456466476486496506516526536546556566576586596606616626636646656666676686696706716726736746756766776786796806816826836846856866876886896906916926936946956966976986997007017027037047057067077087097107117127137147157167177187197207217227237247257267277287297307317327337347357367377387397407417427437447457467477487497507517527537547557567577587597607617627637647657667677687697707717727737747757767777787797807817827837847857867877887897907917927937947957967977987998008018028038048058068078088098108118128138148158168178188198208218228238248258268278288298308318328338348358368378388398408418428438448458468478488498508518528538548558568578588598608618628638648658668678688698708718728738748758768778788798808818828838848858868878888898908918928938948958968978988999009019029039049059069079089099109119129139149159169179189199209219229239249259269279289299309319329339349359369379389399409419429439449459469479489499509519529539549559569579589599609619629639649659669679689699709719729739749759769779789799809819829839849859869879889899909919929939949959969979989991000100110021003100410051006100710081009101010111012101310141015101610171018101910201021102210231024102510261027102810291030103110321033103410351036103710381039104010411042104310441045104610471048104910501051105210531054105510561057
  1. # -*- coding: utf-8 -*-
  2. """Task results/state and results for groups of tasks."""
  3. from __future__ import absolute_import, unicode_literals
  4. import time
  5. from collections import OrderedDict, deque
  6. from contextlib import contextmanager
  7. from copy import copy
  8. from kombu.utils.objects import cached_property
  9. from vine import Thenable, barrier, promise
  10. from . import current_app, states
  11. from ._state import _set_task_join_will_block, task_join_will_block
  12. from .app import app_or_default
  13. from .exceptions import ImproperlyConfigured, IncompleteStream, TimeoutError
  14. from .five import (items, monotonic, python_2_unicode_compatible, range,
  15. string_t)
  16. from .utils import deprecated
  17. from .utils.graph import DependencyGraph, GraphFormatter
  18. try:
  19. import tblib
  20. except ImportError:
  21. tblib = None
  22. __all__ = (
  23. 'ResultBase', 'AsyncResult', 'ResultSet',
  24. 'GroupResult', 'EagerResult', 'result_from_tuple',
  25. )
  26. E_WOULDBLOCK = """\
  27. Never call result.get() within a task!
  28. See http://docs.celeryq.org/en/latest/userguide/tasks.html\
  29. #task-synchronous-subtasks
  30. """
  31. def assert_will_not_block():
  32. if task_join_will_block():
  33. raise RuntimeError(E_WOULDBLOCK)
  34. @contextmanager
  35. def allow_join_result():
  36. reset_value = task_join_will_block()
  37. _set_task_join_will_block(False)
  38. try:
  39. yield
  40. finally:
  41. _set_task_join_will_block(reset_value)
  42. @contextmanager
  43. def denied_join_result():
  44. reset_value = task_join_will_block()
  45. _set_task_join_will_block(True)
  46. try:
  47. yield
  48. finally:
  49. _set_task_join_will_block(reset_value)
  50. class ResultBase(object):
  51. """Base class for results."""
  52. #: Parent result (if part of a chain)
  53. parent = None
  54. @Thenable.register
  55. @python_2_unicode_compatible
  56. class AsyncResult(ResultBase):
  57. """Query task state.
  58. Arguments:
  59. id (str): See :attr:`id`.
  60. backend (Backend): See :attr:`backend`.
  61. """
  62. app = None
  63. #: Error raised for timeouts.
  64. TimeoutError = TimeoutError
  65. #: The task's UUID.
  66. id = None
  67. #: The task result backend to use.
  68. backend = None
  69. def __init__(self, id, backend=None,
  70. task_name=None, # deprecated
  71. app=None, parent=None):
  72. if id is None:
  73. raise ValueError(
  74. 'AsyncResult requires valid id, not {0}'.format(type(id)))
  75. self.app = app_or_default(app or self.app)
  76. self.id = id
  77. self.backend = backend or self.app.backend
  78. self.parent = parent
  79. self.on_ready = promise(self._on_fulfilled)
  80. self._cache = None
  81. self._ignored = False
  82. @property
  83. def ignored(self):
  84. """"If True, task result retrieval is disabled."""
  85. if hasattr(self, '_ignored'):
  86. return self._ignored
  87. return False
  88. @ignored.setter
  89. def ignored(self, value):
  90. """Enable/disable task result retrieval."""
  91. self._ignored = value
  92. def then(self, callback, on_error=None, weak=False):
  93. self.backend.add_pending_result(self, weak=weak)
  94. return self.on_ready.then(callback, on_error)
  95. def _on_fulfilled(self, result):
  96. self.backend.remove_pending_result(self)
  97. return result
  98. def as_tuple(self):
  99. parent = self.parent
  100. return (self.id, parent and parent.as_tuple()), None
  101. def forget(self):
  102. """Forget about (and possibly remove the result of) this task."""
  103. self._cache = None
  104. self.backend.forget(self.id)
  105. def revoke(self, connection=None, terminate=False, signal=None,
  106. wait=False, timeout=None):
  107. """Send revoke signal to all workers.
  108. Any worker receiving the task, or having reserved the
  109. task, *must* ignore it.
  110. Arguments:
  111. terminate (bool): Also terminate the process currently working
  112. on the task (if any).
  113. signal (str): Name of signal to send to process if terminate.
  114. Default is TERM.
  115. wait (bool): Wait for replies from workers.
  116. The ``timeout`` argument specifies the seconds to wait.
  117. Disabled by default.
  118. timeout (float): Time in seconds to wait for replies when
  119. ``wait`` is enabled.
  120. """
  121. self.app.control.revoke(self.id, connection=connection,
  122. terminate=terminate, signal=signal,
  123. reply=wait, timeout=timeout)
  124. def get(self, timeout=None, propagate=True, interval=0.5,
  125. no_ack=True, follow_parents=True, callback=None, on_message=None,
  126. on_interval=None, disable_sync_subtasks=True,
  127. EXCEPTION_STATES=states.EXCEPTION_STATES,
  128. PROPAGATE_STATES=states.PROPAGATE_STATES):
  129. """Wait until task is ready, and return its result.
  130. Warning:
  131. Waiting for tasks within a task may lead to deadlocks.
  132. Please read :ref:`task-synchronous-subtasks`.
  133. Warning:
  134. Backends use resources to store and transmit results. To ensure
  135. that resources are released, you must eventually call
  136. :meth:`~@AsyncResult.get` or :meth:`~@AsyncResult.forget` on
  137. EVERY :class:`~@AsyncResult` instance returned after calling
  138. a task.
  139. Arguments:
  140. timeout (float): How long to wait, in seconds, before the
  141. operation times out.
  142. propagate (bool): Re-raise exception if the task failed.
  143. interval (float): Time to wait (in seconds) before retrying to
  144. retrieve the result. Note that this does not have any effect
  145. when using the RPC/redis result store backends, as they don't
  146. use polling.
  147. no_ack (bool): Enable amqp no ack (automatically acknowledge
  148. message). If this is :const:`False` then the message will
  149. **not be acked**.
  150. follow_parents (bool): Re-raise any exception raised by
  151. parent tasks.
  152. disable_sync_subtasks (bool): Disable tasks to wait for sub tasks
  153. this is the default configuration. CAUTION do not enable this
  154. unless you must.
  155. Raises:
  156. celery.exceptions.TimeoutError: if `timeout` isn't
  157. :const:`None` and the result does not arrive within
  158. `timeout` seconds.
  159. Exception: If the remote call raised an exception then that
  160. exception will be re-raised in the caller process.
  161. """
  162. if self.ignored:
  163. return
  164. if disable_sync_subtasks:
  165. assert_will_not_block()
  166. _on_interval = promise()
  167. if follow_parents and propagate and self.parent:
  168. on_interval = promise(self._maybe_reraise_parent_error)
  169. self._maybe_reraise_parent_error()
  170. if on_interval:
  171. _on_interval.then(on_interval)
  172. if self._cache:
  173. if propagate:
  174. self.maybe_throw(callback=callback)
  175. return self.result
  176. self.backend.add_pending_result(self)
  177. return self.backend.wait_for_pending(
  178. self, timeout=timeout,
  179. interval=interval,
  180. on_interval=_on_interval,
  181. no_ack=no_ack,
  182. propagate=propagate,
  183. callback=callback,
  184. on_message=on_message,
  185. )
  186. wait = get # deprecated alias to :meth:`get`.
  187. def _maybe_reraise_parent_error(self):
  188. for node in reversed(list(self._parents())):
  189. node.maybe_throw()
  190. def _parents(self):
  191. node = self.parent
  192. while node:
  193. yield node
  194. node = node.parent
  195. def collect(self, intermediate=False, **kwargs):
  196. """Collect results as they return.
  197. Iterator, like :meth:`get` will wait for the task to complete,
  198. but will also follow :class:`AsyncResult` and :class:`ResultSet`
  199. returned by the task, yielding ``(result, value)`` tuples for each
  200. result in the tree.
  201. An example would be having the following tasks:
  202. .. code-block:: python
  203. from celery import group
  204. from proj.celery import app
  205. @app.task(trail=True)
  206. def A(how_many):
  207. return group(B.s(i) for i in range(how_many))()
  208. @app.task(trail=True)
  209. def B(i):
  210. return pow2.delay(i)
  211. @app.task(trail=True)
  212. def pow2(i):
  213. return i ** 2
  214. .. code-block:: pycon
  215. >>> from celery.result import ResultBase
  216. >>> from proj.tasks import A
  217. >>> result = A.delay(10)
  218. >>> [v for v in result.collect()
  219. ... if not isinstance(v, (ResultBase, tuple))]
  220. [0, 1, 4, 9, 16, 25, 36, 49, 64, 81]
  221. Note:
  222. The ``Task.trail`` option must be enabled
  223. so that the list of children is stored in ``result.children``.
  224. This is the default but enabled explicitly for illustration.
  225. Yields:
  226. Tuple[AsyncResult, Any]: tuples containing the result instance
  227. of the child task, and the return value of that task.
  228. """
  229. for _, R in self.iterdeps(intermediate=intermediate):
  230. yield R, R.get(**kwargs)
  231. def get_leaf(self):
  232. value = None
  233. for _, R in self.iterdeps():
  234. value = R.get()
  235. return value
  236. def iterdeps(self, intermediate=False):
  237. stack = deque([(None, self)])
  238. while stack:
  239. parent, node = stack.popleft()
  240. yield parent, node
  241. if node.ready():
  242. stack.extend((node, child) for child in node.children or [])
  243. else:
  244. if not intermediate:
  245. raise IncompleteStream()
  246. def ready(self):
  247. """Return :const:`True` if the task has executed.
  248. If the task is still running, pending, or is waiting
  249. for retry then :const:`False` is returned.
  250. """
  251. return self.state in self.backend.READY_STATES
  252. def successful(self):
  253. """Return :const:`True` if the task executed successfully."""
  254. return self.state == states.SUCCESS
  255. def failed(self):
  256. """Return :const:`True` if the task failed."""
  257. return self.state == states.FAILURE
  258. def throw(self, *args, **kwargs):
  259. self.on_ready.throw(*args, **kwargs)
  260. def maybe_throw(self, propagate=True, callback=None):
  261. cache = self._get_task_meta() if self._cache is None else self._cache
  262. state, value, tb = (
  263. cache['status'], cache['result'], cache.get('traceback'))
  264. if state in states.PROPAGATE_STATES and propagate:
  265. self.throw(value, self._to_remote_traceback(tb))
  266. if callback is not None:
  267. callback(self.id, value)
  268. return value
  269. maybe_reraise = maybe_throw # XXX compat alias
  270. def _to_remote_traceback(self, tb):
  271. if tb and tblib is not None and self.app.conf.task_remote_tracebacks:
  272. return tblib.Traceback.from_string(tb).as_traceback()
  273. def build_graph(self, intermediate=False, formatter=None):
  274. graph = DependencyGraph(
  275. formatter=formatter or GraphFormatter(root=self.id, shape='oval'),
  276. )
  277. for parent, node in self.iterdeps(intermediate=intermediate):
  278. graph.add_arc(node)
  279. if parent:
  280. graph.add_edge(parent, node)
  281. return graph
  282. def __str__(self):
  283. """`str(self) -> self.id`."""
  284. return str(self.id)
  285. def __hash__(self):
  286. """`hash(self) -> hash(self.id)`."""
  287. return hash(self.id)
  288. def __repr__(self):
  289. return '<{0}: {1}>'.format(type(self).__name__, self.id)
  290. def __eq__(self, other):
  291. if isinstance(other, AsyncResult):
  292. return other.id == self.id
  293. elif isinstance(other, string_t):
  294. return other == self.id
  295. return NotImplemented
  296. def __ne__(self, other):
  297. res = self.__eq__(other)
  298. return True if res is NotImplemented else not res
  299. def __copy__(self):
  300. return self.__class__(
  301. self.id, self.backend, None, self.app, self.parent,
  302. )
  303. def __reduce__(self):
  304. return self.__class__, self.__reduce_args__()
  305. def __reduce_args__(self):
  306. return self.id, self.backend, None, None, self.parent
  307. def __del__(self):
  308. """Cancel pending operations when the instance is destroyed."""
  309. if self.backend is not None:
  310. self.backend.remove_pending_result(self)
  311. @cached_property
  312. def graph(self):
  313. return self.build_graph()
  314. @property
  315. def supports_native_join(self):
  316. return self.backend.supports_native_join
  317. @property
  318. def children(self):
  319. return self._get_task_meta().get('children')
  320. def _maybe_set_cache(self, meta):
  321. if meta:
  322. state = meta['status']
  323. if state in states.READY_STATES:
  324. d = self._set_cache(self.backend.meta_from_decoded(meta))
  325. self.on_ready(self)
  326. return d
  327. return meta
  328. def _get_task_meta(self):
  329. if self._cache is None:
  330. return self._maybe_set_cache(self.backend.get_task_meta(self.id))
  331. return self._cache
  332. def _iter_meta(self):
  333. return iter([self._get_task_meta()])
  334. def _set_cache(self, d):
  335. children = d.get('children')
  336. if children:
  337. d['children'] = [
  338. result_from_tuple(child, self.app) for child in children
  339. ]
  340. self._cache = d
  341. return d
  342. @property
  343. def result(self):
  344. """Task return value.
  345. Note:
  346. When the task has been executed, this contains the return value.
  347. If the task raised an exception, this will be the exception
  348. instance.
  349. """
  350. return self._get_task_meta()['result']
  351. info = result
  352. @property
  353. def traceback(self):
  354. """Get the traceback of a failed task."""
  355. return self._get_task_meta().get('traceback')
  356. @property
  357. def state(self):
  358. """The tasks current state.
  359. Possible values includes:
  360. *PENDING*
  361. The task is waiting for execution.
  362. *STARTED*
  363. The task has been started.
  364. *RETRY*
  365. The task is to be retried, possibly because of failure.
  366. *FAILURE*
  367. The task raised an exception, or has exceeded the retry limit.
  368. The :attr:`result` attribute then contains the
  369. exception raised by the task.
  370. *SUCCESS*
  371. The task executed successfully. The :attr:`result` attribute
  372. then contains the tasks return value.
  373. """
  374. return self._get_task_meta()['status']
  375. status = state # XXX compat
  376. @property
  377. def task_id(self):
  378. """Compat. alias to :attr:`id`."""
  379. return self.id
  380. @task_id.setter # noqa
  381. def task_id(self, id):
  382. self.id = id
  383. @Thenable.register
  384. @python_2_unicode_compatible
  385. class ResultSet(ResultBase):
  386. """A collection of results.
  387. Arguments:
  388. results (Sequence[AsyncResult]): List of result instances.
  389. """
  390. _app = None
  391. #: List of results in in the set.
  392. results = None
  393. def __init__(self, results, app=None, ready_barrier=None, **kwargs):
  394. self._app = app
  395. self._cache = None
  396. self.results = results
  397. self.on_ready = promise(args=(self,))
  398. self._on_full = ready_barrier or barrier(results)
  399. if self._on_full:
  400. self._on_full.then(promise(self._on_ready))
  401. def add(self, result):
  402. """Add :class:`AsyncResult` as a new member of the set.
  403. Does nothing if the result is already a member.
  404. """
  405. if result not in self.results:
  406. self.results.append(result)
  407. if self._on_full:
  408. self._on_full.add(result)
  409. def _on_ready(self):
  410. if self.backend.is_async:
  411. self._cache = [r.get() for r in self.results]
  412. self.on_ready()
  413. def remove(self, result):
  414. """Remove result from the set; it must be a member.
  415. Raises:
  416. KeyError: if the result isn't a member.
  417. """
  418. if isinstance(result, string_t):
  419. result = self.app.AsyncResult(result)
  420. try:
  421. self.results.remove(result)
  422. except ValueError:
  423. raise KeyError(result)
  424. def discard(self, result):
  425. """Remove result from the set if it is a member.
  426. Does nothing if it's not a member.
  427. """
  428. try:
  429. self.remove(result)
  430. except KeyError:
  431. pass
  432. def update(self, results):
  433. """Extend from iterable of results."""
  434. self.results.extend(r for r in results if r not in self.results)
  435. def clear(self):
  436. """Remove all results from this set."""
  437. self.results[:] = [] # don't create new list.
  438. def successful(self):
  439. """Return true if all tasks successful.
  440. Returns:
  441. bool: true if all of the tasks finished
  442. successfully (i.e. didn't raise an exception).
  443. """
  444. return all(result.successful() for result in self.results)
  445. def failed(self):
  446. """Return true if any of the tasks failed.
  447. Returns:
  448. bool: true if one of the tasks failed.
  449. (i.e., raised an exception)
  450. """
  451. return any(result.failed() for result in self.results)
  452. def maybe_throw(self, callback=None, propagate=True):
  453. for result in self.results:
  454. result.maybe_throw(callback=callback, propagate=propagate)
  455. maybe_reraise = maybe_throw # XXX compat alias.
  456. def waiting(self):
  457. """Return true if any of the tasks are incomplete.
  458. Returns:
  459. bool: true if one of the tasks are still
  460. waiting for execution.
  461. """
  462. return any(not result.ready() for result in self.results)
  463. def ready(self):
  464. """Did all of the tasks complete? (either by success of failure).
  465. Returns:
  466. bool: true if all of the tasks have been executed.
  467. """
  468. return all(result.ready() for result in self.results)
  469. def completed_count(self):
  470. """Task completion count.
  471. Returns:
  472. int: the number of tasks completed.
  473. """
  474. return sum(int(result.successful()) for result in self.results)
  475. def forget(self):
  476. """Forget about (and possible remove the result of) all the tasks."""
  477. for result in self.results:
  478. result.forget()
  479. def revoke(self, connection=None, terminate=False, signal=None,
  480. wait=False, timeout=None):
  481. """Send revoke signal to all workers for all tasks in the set.
  482. Arguments:
  483. terminate (bool): Also terminate the process currently working
  484. on the task (if any).
  485. signal (str): Name of signal to send to process if terminate.
  486. Default is TERM.
  487. wait (bool): Wait for replies from worker.
  488. The ``timeout`` argument specifies the number of seconds
  489. to wait. Disabled by default.
  490. timeout (float): Time in seconds to wait for replies when
  491. the ``wait`` argument is enabled.
  492. """
  493. self.app.control.revoke([r.id for r in self.results],
  494. connection=connection, timeout=timeout,
  495. terminate=terminate, signal=signal, reply=wait)
  496. def __iter__(self):
  497. return iter(self.results)
  498. def __getitem__(self, index):
  499. """`res[i] -> res.results[i]`."""
  500. return self.results[index]
  501. @deprecated.Callable('4.0', '5.0')
  502. def iterate(self, timeout=None, propagate=True, interval=0.5):
  503. """Deprecated method, use :meth:`get` with a callback argument."""
  504. elapsed = 0.0
  505. results = OrderedDict((result.id, copy(result))
  506. for result in self.results)
  507. while results:
  508. removed = set()
  509. for task_id, result in items(results):
  510. if result.ready():
  511. yield result.get(timeout=timeout and timeout - elapsed,
  512. propagate=propagate)
  513. removed.add(task_id)
  514. else:
  515. if result.backend.subpolling_interval:
  516. time.sleep(result.backend.subpolling_interval)
  517. for task_id in removed:
  518. results.pop(task_id, None)
  519. time.sleep(interval)
  520. elapsed += interval
  521. if timeout and elapsed >= timeout:
  522. raise TimeoutError('The operation timed out')
  523. def get(self, timeout=None, propagate=True, interval=0.5,
  524. callback=None, no_ack=True, on_message=None,
  525. disable_sync_subtasks=True, on_interval=None):
  526. """See :meth:`join`.
  527. This is here for API compatibility with :class:`AsyncResult`,
  528. in addition it uses :meth:`join_native` if available for the
  529. current result backend.
  530. """
  531. if self._cache is not None:
  532. return self._cache
  533. return (self.join_native if self.supports_native_join else self.join)(
  534. timeout=timeout, propagate=propagate,
  535. interval=interval, callback=callback, no_ack=no_ack,
  536. on_message=on_message, disable_sync_subtasks=disable_sync_subtasks,
  537. on_interval=on_interval,
  538. )
  539. def join(self, timeout=None, propagate=True, interval=0.5,
  540. callback=None, no_ack=True, on_message=None,
  541. disable_sync_subtasks=True, on_interval=None):
  542. """Gather the results of all tasks as a list in order.
  543. Note:
  544. This can be an expensive operation for result store
  545. backends that must resort to polling (e.g., database).
  546. You should consider using :meth:`join_native` if your backend
  547. supports it.
  548. Warning:
  549. Waiting for tasks within a task may lead to deadlocks.
  550. Please see :ref:`task-synchronous-subtasks`.
  551. Arguments:
  552. timeout (float): The number of seconds to wait for results
  553. before the operation times out.
  554. propagate (bool): If any of the tasks raises an exception,
  555. the exception will be re-raised when this flag is set.
  556. interval (float): Time to wait (in seconds) before retrying to
  557. retrieve a result from the set. Note that this does not have
  558. any effect when using the amqp result store backend,
  559. as it does not use polling.
  560. callback (Callable): Optional callback to be called for every
  561. result received. Must have signature ``(task_id, value)``
  562. No results will be returned by this function if a callback
  563. is specified. The order of results is also arbitrary when a
  564. callback is used. To get access to the result object for
  565. a particular id you'll have to generate an index first:
  566. ``index = {r.id: r for r in gres.results.values()}``
  567. Or you can create new result objects on the fly:
  568. ``result = app.AsyncResult(task_id)`` (both will
  569. take advantage of the backend cache anyway).
  570. no_ack (bool): Automatic message acknowledgment (Note that if this
  571. is set to :const:`False` then the messages
  572. *will not be acknowledged*).
  573. disable_sync_subtasks (bool): Disable tasks to wait for sub tasks
  574. this is the default configuration. CAUTION do not enable this
  575. unless you must.
  576. Raises:
  577. celery.exceptions.TimeoutError: if ``timeout`` isn't
  578. :const:`None` and the operation takes longer than ``timeout``
  579. seconds.
  580. """
  581. if disable_sync_subtasks:
  582. assert_will_not_block()
  583. time_start = monotonic()
  584. remaining = None
  585. if on_message is not None:
  586. raise ImproperlyConfigured(
  587. 'Backend does not support on_message callback')
  588. results = []
  589. for result in self.results:
  590. remaining = None
  591. if timeout:
  592. remaining = timeout - (monotonic() - time_start)
  593. if remaining <= 0.0:
  594. raise TimeoutError('join operation timed out')
  595. value = result.get(
  596. timeout=remaining, propagate=propagate,
  597. interval=interval, no_ack=no_ack, on_interval=on_interval,
  598. )
  599. if callback:
  600. callback(result.id, value)
  601. else:
  602. results.append(value)
  603. return results
  604. def then(self, callback, on_error=None, weak=False):
  605. return self.on_ready.then(callback, on_error)
  606. def iter_native(self, timeout=None, interval=0.5, no_ack=True,
  607. on_message=None, on_interval=None):
  608. """Backend optimized version of :meth:`iterate`.
  609. .. versionadded:: 2.2
  610. Note that this does not support collecting the results
  611. for different task types using different backends.
  612. This is currently only supported by the amqp, Redis and cache
  613. result backends.
  614. """
  615. return self.backend.iter_native(
  616. self,
  617. timeout=timeout, interval=interval, no_ack=no_ack,
  618. on_message=on_message, on_interval=on_interval,
  619. )
  620. def join_native(self, timeout=None, propagate=True,
  621. interval=0.5, callback=None, no_ack=True,
  622. on_message=None, on_interval=None,
  623. disable_sync_subtasks=True):
  624. """Backend optimized version of :meth:`join`.
  625. .. versionadded:: 2.2
  626. Note that this does not support collecting the results
  627. for different task types using different backends.
  628. This is currently only supported by the amqp, Redis and cache
  629. result backends.
  630. """
  631. if disable_sync_subtasks:
  632. assert_will_not_block()
  633. order_index = None if callback else {
  634. result.id: i for i, result in enumerate(self.results)
  635. }
  636. acc = None if callback else [None for _ in range(len(self))]
  637. for task_id, meta in self.iter_native(timeout, interval, no_ack,
  638. on_message, on_interval):
  639. value = meta['result']
  640. if propagate and meta['status'] in states.PROPAGATE_STATES:
  641. raise value
  642. if callback:
  643. callback(task_id, value)
  644. else:
  645. acc[order_index[task_id]] = value
  646. return acc
  647. def _iter_meta(self):
  648. return (meta for _, meta in self.backend.get_many(
  649. {r.id for r in self.results}, max_iterations=1,
  650. ))
  651. def _failed_join_report(self):
  652. return (res for res in self.results
  653. if res.backend.is_cached(res.id) and
  654. res.state in states.PROPAGATE_STATES)
  655. def __len__(self):
  656. return len(self.results)
  657. def __eq__(self, other):
  658. if isinstance(other, ResultSet):
  659. return other.results == self.results
  660. return NotImplemented
  661. def __ne__(self, other):
  662. res = self.__eq__(other)
  663. return True if res is NotImplemented else not res
  664. def __repr__(self):
  665. return '<{0}: [{1}]>'.format(type(self).__name__,
  666. ', '.join(r.id for r in self.results))
  667. @property
  668. def supports_native_join(self):
  669. try:
  670. return self.results[0].supports_native_join
  671. except IndexError:
  672. pass
  673. @property
  674. def app(self):
  675. if self._app is None:
  676. self._app = (self.results[0].app if self.results else
  677. current_app._get_current_object())
  678. return self._app
  679. @app.setter
  680. def app(self, app): # noqa
  681. self._app = app
  682. @property
  683. def backend(self):
  684. return self.app.backend if self.app else self.results[0].backend
  685. @Thenable.register
  686. @python_2_unicode_compatible
  687. class GroupResult(ResultSet):
  688. """Like :class:`ResultSet`, but with an associated id.
  689. This type is returned by :class:`~celery.group`.
  690. It enables inspection of the tasks state and return values as
  691. a single entity.
  692. Arguments:
  693. id (str): The id of the group.
  694. results (Sequence[AsyncResult]): List of result instances.
  695. parent (ResultBase): Parent result of this group.
  696. """
  697. #: The UUID of the group.
  698. id = None
  699. #: List/iterator of results in the group
  700. results = None
  701. def __init__(self, id=None, results=None, parent=None, **kwargs):
  702. self.id = id
  703. self.parent = parent
  704. ResultSet.__init__(self, results, **kwargs)
  705. def _on_ready(self):
  706. self.backend.remove_pending_result(self)
  707. ResultSet._on_ready(self)
  708. def save(self, backend=None):
  709. """Save group-result for later retrieval using :meth:`restore`.
  710. Example:
  711. >>> def save_and_restore(result):
  712. ... result.save()
  713. ... result = GroupResult.restore(result.id)
  714. """
  715. return (backend or self.app.backend).save_group(self.id, self)
  716. def delete(self, backend=None):
  717. """Remove this result if it was previously saved."""
  718. (backend or self.app.backend).delete_group(self.id)
  719. def __reduce__(self):
  720. return self.__class__, self.__reduce_args__()
  721. def __reduce_args__(self):
  722. return self.id, self.results
  723. def __bool__(self):
  724. return bool(self.id or self.results)
  725. __nonzero__ = __bool__ # Included for Py2 backwards compatibility
  726. def __eq__(self, other):
  727. if isinstance(other, GroupResult):
  728. return (
  729. other.id == self.id and
  730. other.results == self.results and
  731. other.parent == self.parent
  732. )
  733. elif isinstance(other, string_t):
  734. return other == self.id
  735. return NotImplemented
  736. def __ne__(self, other):
  737. res = self.__eq__(other)
  738. return True if res is NotImplemented else not res
  739. def __repr__(self):
  740. return '<{0}: {1} [{2}]>'.format(
  741. type(self).__name__, self.id,
  742. ', '.join(r.id for r in self.results)
  743. )
  744. def __str__(self):
  745. """`str(self) -> self.id`."""
  746. return str(self.id)
  747. def __hash__(self):
  748. """`hash(self) -> hash(self.id)`."""
  749. return hash(self.id)
  750. def as_tuple(self):
  751. return (
  752. (self.id, self.parent and self.parent.as_tuple()),
  753. [r.as_tuple() for r in self.results]
  754. )
  755. @property
  756. def children(self):
  757. return self.results
  758. @classmethod
  759. def restore(cls, id, backend=None, app=None):
  760. """Restore previously saved group result."""
  761. app = app or (
  762. cls.app if not isinstance(cls.app, property) else current_app
  763. )
  764. backend = backend or app.backend
  765. return backend.restore_group(id)
  766. @Thenable.register
  767. @python_2_unicode_compatible
  768. class EagerResult(AsyncResult):
  769. """Result that we know has already been executed."""
  770. def __init__(self, id, ret_value, state, traceback=None):
  771. # pylint: disable=super-init-not-called
  772. # XXX should really not be inheriting from AsyncResult
  773. self.id = id
  774. self._result = ret_value
  775. self._state = state
  776. self._traceback = traceback
  777. self.on_ready = promise()
  778. self.on_ready(self)
  779. def then(self, callback, on_error=None, weak=False):
  780. return self.on_ready.then(callback, on_error)
  781. def _get_task_meta(self):
  782. return self._cache
  783. def __reduce__(self):
  784. return self.__class__, self.__reduce_args__()
  785. def __reduce_args__(self):
  786. return (self.id, self._result, self._state, self._traceback)
  787. def __copy__(self):
  788. cls, args = self.__reduce__()
  789. return cls(*args)
  790. def ready(self):
  791. return True
  792. def get(self, timeout=None, propagate=True,
  793. disable_sync_subtasks=True, **kwargs):
  794. if disable_sync_subtasks:
  795. assert_will_not_block()
  796. if self.successful():
  797. return self.result
  798. elif self.state in states.PROPAGATE_STATES:
  799. if propagate:
  800. raise self.result
  801. return self.result
  802. wait = get # XXX Compat (remove 5.0)
  803. def forget(self):
  804. pass
  805. def revoke(self, *args, **kwargs):
  806. self._state = states.REVOKED
  807. def __repr__(self):
  808. return '<EagerResult: {0.id}>'.format(self)
  809. @property
  810. def _cache(self):
  811. return {
  812. 'task_id': self.id,
  813. 'result': self._result,
  814. 'status': self._state,
  815. 'traceback': self._traceback,
  816. }
  817. @property
  818. def result(self):
  819. """The tasks return value."""
  820. return self._result
  821. @property
  822. def state(self):
  823. """The tasks state."""
  824. return self._state
  825. status = state
  826. @property
  827. def traceback(self):
  828. """The traceback if the task failed."""
  829. return self._traceback
  830. @property
  831. def supports_native_join(self):
  832. return False
  833. def result_from_tuple(r, app=None):
  834. """Deserialize result from tuple."""
  835. # earlier backends may just pickle, so check if
  836. # result is already prepared.
  837. app = app_or_default(app)
  838. Result = app.AsyncResult
  839. if not isinstance(r, ResultBase):
  840. res, nodes = r
  841. id, parent = res if isinstance(res, (list, tuple)) else (res, None)
  842. if parent:
  843. parent = result_from_tuple(parent, app)
  844. if nodes is not None:
  845. return app.GroupResult(
  846. id, [result_from_tuple(child, app) for child in nodes],
  847. parent=parent,
  848. )
  849. return Result(id, parent=parent)
  850. return r