Index

Symbols | A | B | C | D | E | F | G | I | J | L | M | N | P | Q | R | S | T | U | W

Symbols

-c, --concurrency
celeryd command line option
-d, --daemon
celeryd command line option
-f, --logfile
celeryd command line option
-l, --loglevel
celeryd command line option
-p, --pidfile
celeryd command line option
-w, --wakeup-after
celeryd command line option

A

add() (celery.datastructures.TaskProcessQueue method)
AlreadyRegistered
AMQP_CONSUMER_QUEUE (in module celery.conf)
AMQP_EXCHANGE (in module celery.conf)
AMQP_ROUTING_KEY (in module celery.conf)
arguments (celery.task.TaskSet attribute)
AsynchronousMapTask (class in celery.task)
AsyncResult (class in celery.result)
autodiscover() (celery.registry.TaskRegistry method)
(in module celery.discovery)

B

backend (celery.result.AsyncResult attribute)
(celery.result.BaseAsyncResult attribute)
Backend (class in celery.backends.cache)
(class in celery.backends.database)
(class in celery.backends.tyrant)
BaseAsyncResult (class in celery.result)
BaseBackend (class in celery.backends.base)

C

celery.backends (module)
celery.backends.base (module)
celery.backends.cache (module)
celery.backends.database (module)
celery.backends.tyrant (module)
celery.bin.celeryd (module)
celery.conf (module)
celery.datastructures (module)
celery.discovery (module)
celery.log (module)
celery.managers (module)
celery.messaging (module)
celery.platform (module)
celery.registry (module)
celery.result (module)
celery.task (module)
celery.timer (module)
celery.worker (module)
celeryd command line option
-c, --concurrency
-d, --daemon
-f, --logfile
-l, --loglevel
-p, --pidfile
-w, --wakeup-after
check() (celery.platform.PIDFile method)
cleanup() (celery.backends.base.BaseBackend method)
(celery.backends.database.Backend method)
concurrency (celery.worker.TaskDaemon attribute)
connection_diagnostics() (celery.worker.TaskDaemon method)

D

DAEMON_CONCURRENCY (in module celery.conf)
DAEMON_LOG_FILE (in module celery.conf)
DAEMON_LOG_LEVEL (in module celery.conf)
DAEMON_PID_FILE (in module celery.conf)
daemonize() (in module celery.platform)
date_done (TaskMeta attribute)
DefaultBackend (class in celery.backends)
delay() (celery.task.Task class method)
(PeriodicTaskMeta method)
delay_task() (celery.messaging.TaskPublisher method)
(in module celery.task)
delay_task_in_set() (celery.messaging.TaskPublisher method)
delete_expired() (celery.managers.TaskManager method)
DeleteExpiredTaskMetaTask (class in celery.task)
discard_all() (in module celery.task)
dmap() (in module celery.task)
dmap_async() (in module celery.task)
done_msg (celery.datastructures.TaskProcessQueue attribute)

E

emergency_error() (in module celery.log)
empty_msg_emit_every (celery.worker.TaskDaemon attribute)
EMPTY_MSG_EMIT_EVERY (in module celery.conf)
EmptyQueue
event (celery.timer.EventTimer attribute)
EventTimer (class in celery.timer)
execute() (celery.worker.TaskWrapper method)
execute_next_task() (celery.worker.TaskDaemon method)
execute_remote() (in module celery.task)
execute_using_pool() (celery.worker.TaskWrapper method)
ExecuteRemoteTask (class in celery.task)
extend_kwargs_with_logging() (celery.worker.TaskWrapper method)

F

fetch_next_task() (celery.worker.TaskDaemon method)
filled (celery.datastructures.PositionQueue attribute)
filter_types() (celery.registry.TaskRegistry method)
find_related_module() (in module celery.discovery)
from_message() (celery.worker.TaskWrapper class method)
full() (celery.datastructures.PositionQueue method)

G

get() (celery.result.BaseAsyncResult method)
get_all() (celery.registry.TaskRegistry method)
get_all_expired() (celery.managers.TaskManager method)
get_all_periodic() (celery.registry.TaskRegistry method)
get_all_regular() (celery.registry.TaskRegistry method)
get_backend_cls() (in module celery.backends)
get_consumer() (celery.task.Task method)
get_default_backend_cls (in module celery.backends)
get_logger() (celery.task.Task method)
get_pid() (celery.platform.PIDFile method)
get_publisher() (celery.task.Task method)
get_result() (celery.backends.base.BaseBackend method)
(celery.backends.cache.Backend method)
(celery.backends.database.Backend method)
(celery.backends.tyrant.Backend method)
get_server() (celery.backends.tyrant.Backend method)
get_status() (celery.backends.base.BaseBackend method)
(celery.backends.cache.Backend method)
(celery.backends.database.Backend method)
(celery.backends.tyrant.Backend method)
get_task() (celery.managers.TaskManager method)
(celery.registry.TaskRegistry method)
get_waiting_tasks() (celery.managers.PeriodicTaskManager method)

I

interval (celery.timer.EventTimer attribute)
is_done() (celery.backends.base.BaseBackend method)
(celery.backends.cache.Backend method)
(celery.backends.database.Backend method)
(celery.backends.tyrant.Backend method)
(celery.managers.TaskManager method)
(celery.result.BaseAsyncResult method)
(in module celery.task)
iterate() (celery.task.TaskSet method)

J

jail() (in module celery.worker)
join() (celery.task.TaskSet method)

L

last_run_at (PeriodicTaskMeta attribute)
last_triggered (celery.timer.EventTimer attribute)
limit (celery.datastructures.TaskProcessQueue attribute)
LOG_FORMAT (in module celery.conf)
LOG_LEVELS (in module celery.conf)
logfile (celery.worker.TaskDaemon attribute)
logger (celery.datastructures.TaskProcessQueue attribute)
(celery.worker.TaskDaemon attribute)
loglevel (celery.worker.TaskDaemon attribute)

M

map() (celery.task.TaskSet class method)
map_async() (celery.task.TaskSet class method)
mark_as_done() (celery.backends.base.BaseBackend method)
mark_as_failure() (celery.backends.base.BaseBackend method)
mark_as_retry() (celery.backends.base.BaseBackend method)

N

name (celery.task.Task attribute)
(PeriodicTaskMeta attribute)
NoProcessConsumer (class in celery.messaging)
NotRegistered

P

PeriodicTask (class in celery.task)
PeriodicTaskManager (class in celery.managers)
PeriodicTaskMeta (built-in class)
PIDFile (class in celery.platform)
pool (celery.worker.TaskDaemon attribute)
PositionQueue (class in celery.datastructures)
PositionQueue.UnfilledPosition (class in celery.datastructures)
prepare_result() (celery.backends.base.BaseBackend method)

Q

queue_wakeup_after (celery.worker.TaskDaemon attribute)
QUEUE_WAKEUP_AFTER (in module celery.conf)

R

ready() (celery.result.BaseAsyncResult method)
receive_message() (celery.worker.TaskDaemon method)
receive_message_cc() (celery.worker.TaskDaemon method)
register() (celery.registry.TaskRegistry method)
remote_execute() (celery.task.TaskSet class method)
remove() (celery.platform.PIDFile method)
remove_pidfile() (in module celery.platform)
requeue_task() (celery.messaging.TaskPublisher method)
reset_connection() (celery.worker.TaskDaemon method)
result (celery.result.BaseAsyncResult attribute)
(TaskMeta attribute)
run() (celery.task.ExecuteRemoteTask method)
(celery.task.Task method)
(celery.task.TaskSet method)
(celery.worker.TaskDaemon method)
run_every (celery.task.PeriodicTask attribute)
run_periodic_tasks() (celery.worker.TaskDaemon method)

S

schedule_retry_tasks() (celery.worker.TaskDaemon method)
setup_logger() (in module celery.log)
status (celery.result.BaseAsyncResult attribute)
(TaskMeta attribute)
store_result() (celery.backends.base.BaseBackend method)
(celery.backends.cache.Backend method)
(celery.backends.database.Backend method)
(celery.backends.tyrant.Backend method)
(celery.managers.TaskManager method)
successful() (celery.result.BaseAsyncResult method)

T

Task (class in celery.task)
task (PeriodicTaskMeta attribute)
task_consumer (celery.worker.TaskDaemon attribute)
task_id (celery.result.AsyncResult attribute)
(TaskMeta attribute)
(celery.result.BaseAsyncResult attribute)
task_name (celery.task.TaskSet attribute)
TASK_STATUS_DONE (built-in variable)
TASK_STATUS_FAILURE (built-in variable)
TASK_STATUS_PENDING (built-in variable)
TASK_STATUS_RETRY (built-in variable)
TASK_STATUSES (built-in variable)
TASK_STATUSES_CHOICES (built-in variable)
TaskConsumer (class in celery.messaging)
TaskDaemon (class in celery.worker)
TaskManager (class in celery.managers)
TaskMeta (built-in class)
TaskProcessQueue (class in celery.datastructures)
TaskPublisher (class in celery.messaging)
TaskRegistry (class in celery.registry)
TaskRegistry.AlreadyRegistered
TaskRegistry.NotRegistered
TaskSet (class in celery.task)
TaskWrapper (class in celery.worker)
tick() (celery.timer.EventTimer method)
(celery.timer.TimeoutTimer method)
time_start (celery.timer.TimeoutTimer attribute)
timeout (celery.timer.TimeoutTimer attribute)
TimeoutError
TimeoutTimer (class in celery.timer)
total (celery.task.TaskSet attribute)
total_run_count (PeriodicTaskMeta attribute)
type (celery.task.Task attribute)
tyrant_host (celery.backends.tyrant.Backend attribute)
tyrant_port (celery.backends.tyrant.Backend attribute)

U

UnknownTask
unregister() (celery.registry.TaskRegistry method)

W

wait() (celery.result.BaseAsyncResult method)
wait_for() (celery.backends.base.BaseBackend method)
write() (celery.platform.PIDFile method)