exceptions.py 7.3 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255
  1. # -*- coding: utf-8 -*-
  2. """Celery error types.
  3. Error Hierarchy
  4. ===============
  5. - :exc:`Exception`
  6. - :exc:`celery.exceptions.CeleryError`
  7. - :exc:`~celery.exceptions.ImproperlyConfigured`
  8. - :exc:`~celery.exceptions.SecurityError`
  9. - :exc:`~celery.exceptions.TaskPredicate`
  10. - :exc:`~celery.exceptions.Ignore`
  11. - :exc:`~celery.exceptions.Reject`
  12. - :exc:`~celery.exceptions.Retry`
  13. - :exc:`~celery.exceptions.TaskError`
  14. - :exc:`~celery.exceptions.QueueNotFound`
  15. - :exc:`~celery.exceptions.IncompleteStream`
  16. - :exc:`~celery.exceptions.NotRegistered`
  17. - :exc:`~celery.exceptions.AlreadyRegistered`
  18. - :exc:`~celery.exceptions.TimeoutError`
  19. - :exc:`~celery.exceptions.MaxRetriesExceededError`
  20. - :exc:`~celery.exceptions.TaskRevokedError`
  21. - :exc:`~celery.exceptions.InvalidTaskError`
  22. - :exc:`~celery.exceptions.ChordError`
  23. - :class:`kombu.exceptions.KombuError`
  24. - :exc:`~celery.exceptions.OperationalError`
  25. Raised when a transport connection error occurs while
  26. sending a message (be it a task, remote control command error).
  27. .. note::
  28. This exception does not inherit from
  29. :exc:`~celery.exceptions.CeleryError`.
  30. - **billiard errors** (prefork pool)
  31. - :exc:`~celery.exceptions.SoftTimeLimitExceeded`
  32. - :exc:`~celery.exceptions.TimeLimitExceeded`
  33. - :exc:`~celery.exceptions.WorkerLostError`
  34. - :exc:`~celery.exceptions.Terminated`
  35. - :class:`UserWarning`
  36. - :class:`~celery.exceptions.CeleryWarning`
  37. - :class:`~celery.exceptions.AlwaysEagerIgnored`
  38. - :class:`~celery.exceptions.DuplicateNodenameWarning`
  39. - :class:`~celery.exceptions.FixupWarning`
  40. - :class:`~celery.exceptions.NotConfigured`
  41. - :exc:`BaseException`
  42. - :exc:`SystemExit`
  43. - :exc:`~celery.exceptions.WorkerTerminate`
  44. - :exc:`~celery.exceptions.WorkerShutdown`
  45. """
  46. from __future__ import absolute_import, unicode_literals
  47. import numbers
  48. from billiard.exceptions import (SoftTimeLimitExceeded, Terminated,
  49. TimeLimitExceeded, WorkerLostError)
  50. from kombu.exceptions import OperationalError
  51. from .five import python_2_unicode_compatible, string_t
  52. __all__ = (
  53. # Warnings
  54. 'CeleryWarning',
  55. 'AlwaysEagerIgnored', 'DuplicateNodenameWarning',
  56. 'FixupWarning', 'NotConfigured',
  57. # Core errors
  58. 'CeleryError',
  59. 'ImproperlyConfigured', 'SecurityError',
  60. # Kombu (messaging) errors.
  61. 'OperationalError',
  62. # Task semi-predicates
  63. 'TaskPredicate', 'Ignore', 'Reject', 'Retry',
  64. # Task related errors.
  65. 'TaskError', 'QueueNotFound', 'IncompleteStream',
  66. 'NotRegistered', 'AlreadyRegistered', 'TimeoutError',
  67. 'MaxRetriesExceededError', 'TaskRevokedError',
  68. 'InvalidTaskError', 'ChordError',
  69. # Billiard task errors.
  70. 'SoftTimeLimitExceeded', 'TimeLimitExceeded',
  71. 'WorkerLostError', 'Terminated',
  72. # Deprecation warnings (forcing Python to emit them).
  73. 'CPendingDeprecationWarning', 'CDeprecationWarning',
  74. # Worker shutdown semi-predicates (inherits from SystemExit).
  75. 'WorkerShutdown', 'WorkerTerminate',
  76. )
  77. UNREGISTERED_FMT = """\
  78. Task of kind {0} never registered, please make sure it's imported.\
  79. """
  80. class CeleryWarning(UserWarning):
  81. """Base class for all Celery warnings."""
  82. class AlwaysEagerIgnored(CeleryWarning):
  83. """send_task ignores :setting:`task_always_eager` option."""
  84. class DuplicateNodenameWarning(CeleryWarning):
  85. """Multiple workers are using the same nodename."""
  86. class FixupWarning(CeleryWarning):
  87. """Fixup related warning."""
  88. class NotConfigured(CeleryWarning):
  89. """Celery hasn't been configured, as no config module has been found."""
  90. class CeleryError(Exception):
  91. """Base class for all Celery errors."""
  92. class TaskPredicate(CeleryError):
  93. """Base class for task-related semi-predicates."""
  94. @python_2_unicode_compatible
  95. class Retry(TaskPredicate):
  96. """The task is to be retried later."""
  97. #: Optional message describing context of retry.
  98. message = None
  99. #: Exception (if any) that caused the retry to happen.
  100. exc = None
  101. #: Time of retry (ETA), either :class:`numbers.Real` or
  102. #: :class:`~datetime.datetime`.
  103. when = None
  104. def __init__(self, message=None, exc=None, when=None, **kwargs):
  105. from kombu.utils.encoding import safe_repr
  106. self.message = message
  107. if isinstance(exc, string_t):
  108. self.exc, self.excs = None, exc
  109. else:
  110. self.exc, self.excs = exc, safe_repr(exc) if exc else None
  111. self.when = when
  112. super(Retry, self).__init__(self, exc, when, **kwargs)
  113. def humanize(self):
  114. if isinstance(self.when, numbers.Number):
  115. return 'in {0.when}s'.format(self)
  116. return 'at {0.when}'.format(self)
  117. def __str__(self):
  118. if self.message:
  119. return self.message
  120. if self.excs:
  121. return 'Retry {0}: {1}'.format(self.humanize(), self.excs)
  122. return 'Retry {0}'.format(self.humanize())
  123. def __reduce__(self):
  124. return self.__class__, (self.message, self.excs, self.when)
  125. RetryTaskError = Retry # noqa: E305 XXX compat
  126. class Ignore(TaskPredicate):
  127. """A task can raise this to ignore doing state updates."""
  128. @python_2_unicode_compatible
  129. class Reject(TaskPredicate):
  130. """A task can raise this if it wants to reject/re-queue the message."""
  131. def __init__(self, reason=None, requeue=False):
  132. self.reason = reason
  133. self.requeue = requeue
  134. super(Reject, self).__init__(reason, requeue)
  135. def __repr__(self):
  136. return 'reject requeue=%s: %s' % (self.requeue, self.reason)
  137. class ImproperlyConfigured(CeleryError):
  138. """Celery is somehow improperly configured."""
  139. class SecurityError(CeleryError):
  140. """Security related exception."""
  141. class TaskError(CeleryError):
  142. """Task related errors."""
  143. class QueueNotFound(KeyError, TaskError):
  144. """Task routed to a queue not in ``conf.queues``."""
  145. class IncompleteStream(TaskError):
  146. """Found the end of a stream of data, but the data isn't complete."""
  147. @python_2_unicode_compatible
  148. class NotRegistered(KeyError, TaskError):
  149. """The task ain't registered."""
  150. def __repr__(self):
  151. return UNREGISTERED_FMT.format(self)
  152. class AlreadyRegistered(TaskError):
  153. """The task is already registered."""
  154. # XXX Unused
  155. class TimeoutError(TaskError):
  156. """The operation timed out."""
  157. class MaxRetriesExceededError(TaskError):
  158. """The tasks max restart limit has been exceeded."""
  159. class TaskRevokedError(TaskError):
  160. """The task has been revoked, so no result available."""
  161. class InvalidTaskError(TaskError):
  162. """The task has invalid data or ain't properly constructed."""
  163. class ChordError(TaskError):
  164. """A task part of the chord raised an exception."""
  165. class CPendingDeprecationWarning(PendingDeprecationWarning):
  166. """Warning of pending deprecation."""
  167. class CDeprecationWarning(DeprecationWarning):
  168. """Warning of deprecation."""
  169. class WorkerTerminate(SystemExit):
  170. """Signals that the worker should terminate immediately."""
  171. SystemTerminate = WorkerTerminate # noqa: E305 XXX compat
  172. class WorkerShutdown(SystemExit):
  173. """Signals that the worker should perform a warm shutdown."""