Index

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

Symbols

--chroot
celeryd command line option
--discard
celeryd command line option
--umask
celeryd command line option
--workdir
celeryd command line option
-c, --concurrency
celeryd command line option
-d, --detach, --daemon
celeryd command line option
-f, --logfile
celeryd command line option
-g, --gid
celeryd command line option
-l, --loglevel
celeryd command line option
-p, --pidfile
celeryd command line option
-s, --statistics
celeryd command line option
-S, --supervised
celeryd command line option
-u, --uid
celeryd command line option

A

acquire_pidlock() (in module celery.bin.celeryd)
AlreadyRegistered
AMQP_CONNECTION_TIMEOUT (in module celery.conf), [1]
AMQP_CONSUMER_QUEUE (in module celery.conf), [1]
AMQP_CONSUMER_ROUTING_KEY (in module celery.conf), [1]
AMQP_EXCHANGE (in module celery.conf), [1]
AMQP_EXCHANGE_TYPE (in module celery.conf), [1]
amqp_listener (celery.worker.WorkController attribute)
AMQP_PUBLISHER_ROUTING_KEY (in module celery.conf), [1]
AMQPListener (class in celery.worker)
apply() (in module celery.views)
apply_async() (celery.pool.TaskPool method)
(celery.task.base.Task class method)
(in module celery.execute)
args (celery.supervisor.OFASupervisor attribute)
(celery.worker.job.TaskWrapper attribute)
arguments (celery.task.base.TaskSet attribute)
AsynchronousMapTask (class in celery.task.builtins)
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)
BaseAsyncResult.TimeoutError
BaseBackend (class in celery.backends.base)
BaseBackend.TimeoutError
BaseBackend.UnpickleableExceptionWrapper
bucket_queue (celery.worker.AMQPListener attribute)
(celery.worker.WorkController attribute)
(celery.worker.controllers.Mediator attribute)

C

callback (celery.worker.controllers.Mediator attribute)
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.execute (module)
celery.fields (module)
celery.log (module)
celery.managers (module)
celery.messaging (module)
celery.monitoring (module)
celery.pool (module)
celery.registry (module)
celery.result (module)
celery.supervisor (module)
celery.task (module)
celery.task.base (module)
celery.task.builtins (module)
celery.utils (module)
celery.views (module)
celery.worker (module)
celery.worker.controllers (module)
celery.worker.job (module)
celeryd command line option
--chroot
--discard
--umask
--workdir
-S, --supervised
-c, --concurrency
-d, --detach, --daemon
-f, --logfile
-g, --gid
-l, --loglevel
-p, --pidfile
-s, --statistics
-u, --uid
check_interval (celery.supervisor.OFASupervisor attribute)
chunks() (in module celery.utils)
cleanup() (celery.backends.base.BaseBackend method)
(celery.backends.database.Backend method)
close_connection() (celery.worker.AMQPListener method)
collect() (celery.monitoring.StatsCollector method)
completed_count() (celery.result.TaskSetResult method)
concurrency (celery.worker.WorkController attribute)
create_exception_cls() (celery.backends.base.BaseBackend method)

D

DAEMON_CONCURRENCY (in module celery.conf), [1]
DAEMON_LOG_FILE (in module celery.conf), [1]
DAEMON_LOG_LEVEL (in module celery.conf), [1]
DAEMON_PID_FILE (in module celery.conf), [1]
date_done (TaskMeta attribute)
decoder() (celery.messaging.TaskConsumer method)
DEFAULT_STATISTICS_COLLECT_INTERVAL (in module celery.conf)
DefaultBackend (class in celery.backends)
delay() (celery.task.base.Task class method)
(PeriodicTaskMeta method)
delay_task() (celery.messaging.TaskPublisher method)
(in module celery.execute)
delay_task_in_set() (celery.messaging.TaskPublisher method)
delete_expired() (celery.managers.TaskManager method)
DeleteExpiredTaskMetaTask (class in celery.task.builtins)
disable_error_emails (celery.task.base.Task attribute)
discard_all() (in module celery.task)
dmap() (in module celery.task)
dmap_async() (in module celery.task)
dump_to_cache() (celery.monitoring.StatsCollector method)

E

emergency_error() (in module celery.log)
encoder() (celery.messaging.TaskPublisher method)
exc_args (celery.backends.base.BaseBackend.UnpickleableExceptionWrapper attribute)
(celery.backends.base.UnpickleableExceptionWrapper attribute)
exc_cls_name (celery.backends.base.BaseBackend.UnpickleableExceptionWrapper attribute)
(celery.backends.base.UnpickleableExceptionWrapper attribute)
exc_module (celery.backends.base.BaseBackend.UnpickleableExceptionWrapper attribute)
(celery.backends.base.UnpickleableExceptionWrapper attribute)
exception (celery.datastructures.ExceptionInfo attribute)
exception_to_python() (celery.backends.base.BaseBackend method)
ExceptionInfo (class in celery.datastructures)
execute() (celery.worker.job.TaskWrapper method)
execute_remote() (in module celery.task)
execute_using_pool() (celery.worker.job.TaskWrapper method)
ExecuteRemoteTask (class in celery.task.builtins)
extend_with_default_kwargs() (celery.worker.job.TaskWrapper method)

F

failed() (celery.result.TaskSetResult method)
filled (celery.datastructures.PositionQueue attribute)
filter_types() (celery.registry.TaskRegistry method)
find_nearest_pickleable_exception() (in module celery.backends.base)
find_related_module() (in module celery.discovery)
from_message() (celery.worker.job.TaskWrapper class method)
full() (celery.datastructures.PositionQueue method)
(celery.pool.TaskPool 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.base.Task method)
get_db_prep_lookup() (celery.fields.PickledObjectField method)
get_db_prep_save() (celery.fields.PickledObjectField method)
get_default_backend_cls (in module celery.backends)
get_default_periodicstatus_backend_cls (in module celery.backends)
get_default_periodicstatus_backend_cls() (in module celery.backends)
get_internal_type() (celery.fields.PickledObjectField method)
get_logger() (celery.task.base.Task method)
get_publisher() (celery.task.base.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_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)
get_worker_pids() (celery.pool.TaskPool method)

H

hold_queue (celery.worker.AMQPListener attribute)
(celery.worker.WorkController attribute)

I

ignore_result (celery.task.base.Task attribute)
InfinityThread (class in celery.worker.controllers)
is_detached (celery.worker.WorkController 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)
is_task_done() (in module celery.views)
iterate() (celery.result.TaskSetResult method)
(celery.task.base.TaskSet method)
itersubtasks() (celery.result.TaskSetResult method)

J

jail() (in module celery.worker.job)
join() (celery.result.TaskSetResult method)
(celery.task.base.TaskSet method)
join_timeout (celery.supervisor.OFASupervisor attribute)

K

kwargs (celery.supervisor.OFASupervisor attribute)
(celery.worker.job.TaskWrapper attribute)

L

last_run_at (PeriodicTaskMeta attribute)
length (celery.datastructures.PositionQueue attribute)
limit (celery.pool.TaskPool attribute)
LOG_FORMAT (in module celery.conf), [1]
LOG_LEVELS (in module celery.conf), [1]
logfile (celery.worker.WorkController attribute)
logger (celery.pool.TaskPool attribute)
(celery.worker.AMQPListener attribute)
(celery.worker.WorkController attribute)
loglevel (celery.worker.WorkController attribute)

M

mandatory (celery.task.base.Task attribute)
map() (celery.task.base.TaskSet class method)
map_async() (celery.task.base.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)
max_restart_freq (celery.supervisor.OFASupervisor attribute)
max_restart_freq_time (celery.supervisor.OFASupervisor attribute)
mediator (celery.worker.WorkController attribute)
Mediator (class in celery.worker.controllers)
message (celery.worker.job.TaskWrapper attribute)

N

name (celery.task.base.Task attribute)
(PeriodicTaskMeta attribute)
NotRegistered

O

OFASupervisor (class in celery.supervisor)
on_failure() (celery.worker.job.TaskWrapper method)
on_finish() (celery.monitoring.TimerStats method)
on_iteration() (celery.worker.controllers.InfinityThread method)
on_ready() (celery.pool.TaskPool method)
on_return() (celery.pool.TaskPool method)
on_start() (celery.monitoring.Statistics method)
(celery.monitoring.TimerStats method)
on_stop() (celery.monitoring.Statistics method)
on_success() (celery.worker.job.TaskWrapper method)
open() (celery.backends.tyrant.Backend method)

P

parse_options() (in module celery.bin.celeryd)
periodic_work_controller (celery.worker.WorkController attribute)
PeriodicTask (class in celery.task.base)
PeriodicTaskManager (class in celery.managers)
PeriodicTaskMeta (built-in class)
PeriodicWorkController (class in celery.worker.controllers)
PickledObject (class in celery.fields)
PickledObjectField (class in celery.fields)
ping() (in module celery.task)
PingTask (class in celery.task.builtins)
pool (celery.worker.WorkController attribute)
PositionQueue (class in celery.datastructures)
PositionQueue.UnfilledPosition (class in celery.datastructures)
prepare_exception() (celery.backends.base.BaseBackend method)
prepare_result() (celery.backends.base.BaseBackend method)
process_cleanup() (celery.backends.base.BaseBackend method)
process_hold_queue() (celery.worker.controllers.PeriodicWorkController method)
process_task() (celery.worker.WorkController method)
publish() (celery.monitoring.Statistics method)

R

raise_ping_timeout() (in module celery.supervisor)
ready() (celery.result.BaseAsyncResult method)
(celery.result.TaskSetResult method)
reap() (celery.pool.TaskPool method)
receive_message() (celery.worker.AMQPListener method)
register() (celery.registry.TaskRegistry method)
remote_execute() (celery.task.base.TaskSet class method)
report() (celery.monitoring.StatsCollector method)
requeue_task() (celery.messaging.TaskPublisher method)
reset_connection() (celery.worker.AMQPListener method)
result (celery.result.BaseAsyncResult attribute)
(TaskMeta attribute)
routing_key (celery.task.base.Task attribute)
run() (celery.monitoring.Statistics method)
(celery.task.base.Task method)
(celery.task.base.TaskSet method)
(celery.task.builtins.AsynchronousMapTask method)
(celery.task.builtins.DeleteExpiredTaskMetaTask method)
(celery.task.builtins.ExecuteRemoteTask method)
(celery.task.builtins.PingTask method)
(celery.worker.controllers.InfinityThread method)
run_every (celery.task.base.PeriodicTask attribute)
run_periodic_tasks() (celery.backends.database.Backend method)
run_worker() (in module celery.bin.celeryd)

S

safe_process_task() (celery.worker.WorkController method)
SEND_CELERY_TASK_ERROR_EMAILS (in module celery.conf), [1]
setup_logger() (in module celery.log)
start() (celery.monitoring.Statistics class method)
(celery.pool.TaskPool method)
(celery.supervisor.OFASupervisor method)
(celery.worker.AMQPListener method)
(celery.worker.WorkController method)
Statistics (class in celery.monitoring)
STATISTICS_COLLECT_INTERVAL (in module celery.conf)
StatsCollector (class in celery.monitoring)
status (celery.result.BaseAsyncResult attribute)
(TaskMeta attribute)
stop() (celery.monitoring.Statistics method)
(celery.pool.TaskPool method)
(celery.worker.AMQPListener method)
(celery.worker.WorkController method)
(celery.worker.controllers.InfinityThread method)
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)
subtasks (celery.result.TaskSetResult attribute)
successful() (celery.result.BaseAsyncResult method)
(celery.result.TaskSetResult method)

T

target (celery.supervisor.OFASupervisor attribute)
Task (class in celery.task.base)
task (PeriodicTaskMeta attribute)
task_func (celery.worker.job.TaskWrapper attribute)
task_id (celery.result.AsyncResult attribute)
(TaskMeta attribute)
(celery.result.BaseAsyncResult attribute)
(celery.worker.job.TaskWrapper attribute)
task_name (celery.task.base.TaskSet attribute)
(celery.worker.job.TaskWrapper attribute)
task_status() (in module celery.views)
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)
task_time_running() (celery.monitoring.StatsCollector method)
TaskConsumer (class in celery.messaging)
TaskManager (class in celery.managers)
TaskMeta (built-in class)
TaskPool (class in celery.pool)
TaskPublisher (class in celery.messaging)
TaskRegistry (class in celery.registry)
TaskRegistry.AlreadyRegistered
TaskRegistry.NotRegistered
TaskSet (class in celery.task.base)
taskset_id (celery.result.TaskSetResult attribute)
TaskSetResult (class in celery.result)
TaskTimerStats (class in celery.monitoring)
TaskWrapper (class in celery.worker.job)
time_start (celery.monitoring.TimerStats attribute)
TimeoutError, [1]
TimerStats (class in celery.monitoring)
to_python() (celery.fields.PickledObjectField method)
total (celery.result.TaskSetResult attribute)
(celery.task.base.TaskSet attribute)
total_run_count (PeriodicTaskMeta attribute)
total_task_time_running (celery.monitoring.StatsCollector attribute)
total_task_time_running_by_type (celery.monitoring.StatsCollector attribute)
total_tasks_processed (celery.monitoring.StatsCollector attribute)
total_tasks_processed_by_type (celery.monitoring.StatsCollector attribute)
traceback (celery.datastructures.ExceptionInfo attribute)
type (celery.monitoring.Statistics attribute)
(celery.task.base.Task attribute)
tyrant_host (celery.backends.tyrant.Backend attribute)
tyrant_port (celery.backends.tyrant.Backend attribute)

U

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

W

wait() (celery.result.BaseAsyncResult method)
wait_for() (celery.backends.base.BaseBackend method)
wait_for_result() (celery.pool.TaskPool method)
waiting() (celery.result.TaskSetResult method)
WorkController (class in celery.worker)