celery.exceptions
¶
Celery error types.
Error Hierarchy¶
Exception
kombu.exceptions.KombuError
-
Raised when a transport connection error occurs while sending a message (be it a task, remote control command error).
Примечание
This exception does not inherit from
CeleryError
.
-
- billiard errors (prefork pool)
- exception celery.exceptions.AlreadyRegistered[исходный код]¶
The task is already registered.
- exception celery.exceptions.AlwaysEagerIgnored[исходный код]¶
send_task ignores
task_always_eager
option.
- exception celery.exceptions.BackendError[исходный код]¶
An issue writing or reading to/from the backend.
- exception celery.exceptions.BackendGetMetaError(*args, **kwargs)[исходный код]¶
An issue reading from the backend.
- exception celery.exceptions.BackendStoreError(*args, **kwargs)[исходный код]¶
An issue writing to the backend.
- exception celery.exceptions.CDeprecationWarning[исходный код]¶
Warning of deprecation.
- exception celery.exceptions.CPendingDeprecationWarning[исходный код]¶
Warning of pending deprecation.
- exception celery.exceptions.CeleryCommandException(message, exit_code)[исходный код]¶
A general command exception which stores an exit code.
- exception celery.exceptions.CeleryError[исходный код]¶
Base class for all Celery errors.
- exception celery.exceptions.CeleryWarning[исходный код]¶
Base class for all Celery warnings.
- exception celery.exceptions.ChordError[исходный код]¶
A task part of the chord raised an exception.
- exception celery.exceptions.DuplicateNodenameWarning[исходный код]¶
Multiple workers are using the same nodename.
- exception celery.exceptions.FixupWarning[исходный код]¶
Fixup related warning.
- exception celery.exceptions.Ignore[исходный код]¶
A task can raise this to ignore doing state updates.
- exception celery.exceptions.ImproperlyConfigured[исходный код]¶
Celery is somehow improperly configured.
- exception celery.exceptions.IncompleteStream[исходный код]¶
Found the end of a stream of data, but the data isn’t complete.
- exception celery.exceptions.InvalidTaskError[исходный код]¶
The task has invalid data or ain’t properly constructed.
- exception celery.exceptions.MaxRetriesExceededError(*args, **kwargs)[исходный код]¶
The tasks max restart limit has been exceeded.
- exception celery.exceptions.NotConfigured[исходный код]¶
Celery hasn’t been configured, as no config module has been found.
- exception celery.exceptions.NotRegistered[исходный код]¶
The task is not registered.
- exception celery.exceptions.OperationalError[исходный код]¶
Recoverable message transport connection error.
- exception celery.exceptions.QueueNotFound[исходный код]¶
Task routed to a queue not in
conf.queues
.
- exception celery.exceptions.Reject(reason=None, requeue=False)[исходный код]¶
A task can raise this if it wants to reject/re-queue the message.
- exception celery.exceptions.Retry(message=None, exc=None, when=None, is_eager=False, sig=None, **kwargs)[исходный код]¶
The task is to be retried later.
- exc = None¶
Exception (if any) that caused the retry to happen.
- humanize()[исходный код]¶
- message = None¶
Optional message describing context of retry.
- when = None¶
Time of retry (ETA), either
numbers.Real
ordatetime
.
- exception celery.exceptions.SecurityError[исходный код]¶
Security related exception.
- exception celery.exceptions.SecurityWarning[исходный код]¶
Potential security issue found.
- exception celery.exceptions.SoftTimeLimitExceeded[исходный код]¶
The soft time limit has been exceeded. This exception is raised to give the task a chance to clean up.
- exception celery.exceptions.TaskError[исходный код]¶
Task related errors.
- exception celery.exceptions.TaskPredicate[исходный код]¶
Base class for task-related semi-predicates.
- exception celery.exceptions.TaskRevokedError[исходный код]¶
The task has been revoked, so no result available.
- exception celery.exceptions.Terminated[исходный код]¶
The worker processing a job has been terminated by user request.
- exception celery.exceptions.TimeLimitExceeded[исходный код]¶
The time limit has been exceeded and the job has been terminated.
- exception celery.exceptions.TimeoutError[исходный код]¶
The operation timed out.
- exception celery.exceptions.WorkerLostError[исходный код]¶
The worker processing a job has exited prematurely.
- exception celery.exceptions.WorkerShutdown[исходный код]¶
Signals that the worker should perform a warm shutdown.
- exception celery.exceptions.WorkerTerminate[исходный код]¶
Signals that the worker should terminate immediately.
- celery.exceptions.reraise(tp, value, tb=None)[исходный код]¶
Reraise exception.