你正在阅读 Celery 3.1 的文档。开发版本文档见: 此处.

celery.exceptions

celery.exceptions

This module contains all exceptions used by the Celery API.

exception celery.exceptions.SecurityError[源代码]

Security related exceptions.

Handle with care.

exception celery.exceptions.Ignore[源代码]

A task can raise this to ignore doing state updates.

exception celery.exceptions.SystemTerminate[源代码]

Signals that the worker should terminate.

exception celery.exceptions.QueueNotFound[源代码]

Task routed to a queue not in CELERY_QUEUES.

exception celery.exceptions.ImproperlyConfigured[源代码]

Celery is somehow improperly configured.

exception celery.exceptions.NotRegistered[源代码]

The task is not registered.

exception celery.exceptions.AlreadyRegistered[源代码]

The task is already registered.

exception celery.exceptions.TimeoutError[源代码]

The operation timed out.

exception celery.exceptions.MaxRetriesExceededError[源代码]

The tasks max restart limit has been exceeded.

exception celery.exceptions.Retry(message=None, exc=None, when=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 int or datetime.

exception celery.exceptions.TaskRevokedError[源代码]

The task has been revoked, so no result available.

exception celery.exceptions.NotConfigured[源代码]

Celery has not been configured, as no config module has been found.

exception celery.exceptions.AlwaysEagerIgnored[源代码]

send_task ignores CELERY_ALWAYS_EAGER option

exception celery.exceptions.InvalidTaskError[源代码]

The task has invalid data or is not properly constructed.

exception celery.exceptions.ChordError[源代码]

A task part of the chord raised an exception.

exception celery.exceptions.CPendingDeprecationWarning[源代码]
exception celery.exceptions.CDeprecationWarning[源代码]
exception celery.exceptions.FixupWarning
exception celery.exceptions.DuplicateNodenameWarning

Multiple workers are using the same nodename.

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.TimeLimitExceeded

The time limit has been exceeded and the job has been terminated.

exception celery.exceptions.WorkerLostError

The worker processing a job has exited prematurely.

exception celery.exceptions.Terminated

The worker processing a job has been terminated by user request.

上一个主题

celery.utils.mail

下一个主题

celery.loaders

本页