|
@@ -1,6 +1,6 @@
|
|
# Sphinx inventory version 1
|
|
# Sphinx inventory version 1
|
|
# Project: Celery
|
|
# Project: Celery
|
|
-# Version: 0.2
|
|
|
|
|
|
+# Version: 0.3
|
|
celery.backends mod reference/celery.backends.html
|
|
celery.backends mod reference/celery.backends.html
|
|
celery.task mod reference/celery.task.html
|
|
celery.task mod reference/celery.task.html
|
|
celery.worker mod reference/celery.worker.html
|
|
celery.worker mod reference/celery.worker.html
|
|
@@ -23,13 +23,13 @@ celery.task.TaskSet.task_name attribute reference/celery.task.html
|
|
celery.log.emergency_error function reference/celery.log.html
|
|
celery.log.emergency_error function reference/celery.log.html
|
|
celery.backends.base.BaseBackend.get_result method reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.get_result method reference/celery.backends.base.html
|
|
celery.task.dmap function reference/celery.task.html
|
|
celery.task.dmap function reference/celery.task.html
|
|
-celery.messaging.NoProcessConsumer class reference/celery.messaging.html
|
|
|
|
celery.result.BaseAsyncResult.is_done method reference/celery.result.html
|
|
celery.result.BaseAsyncResult.is_done method reference/celery.result.html
|
|
celery.worker.TaskWrapper.execute method reference/celery.worker.html
|
|
celery.worker.TaskWrapper.execute method reference/celery.worker.html
|
|
|
|
+celery.result.TaskSetResult.subtasks attribute reference/celery.result.html
|
|
celery.backends.tyrant.Backend.tyrant_port attribute reference/celery.backends.tyrant.html
|
|
celery.backends.tyrant.Backend.tyrant_port attribute reference/celery.backends.tyrant.html
|
|
celery.worker.WorkController.task_consumer attribute reference/celery.worker.html
|
|
celery.worker.WorkController.task_consumer attribute reference/celery.worker.html
|
|
celery.task.delay_task function reference/celery.task.html
|
|
celery.task.delay_task function reference/celery.task.html
|
|
-celery.timer.TimeoutError exception reference/celery.timer.html
|
|
|
|
|
|
+celery.result.TaskSetResult.iterate method reference/celery.result.html
|
|
celery.registry.AlreadyRegistered exception reference/celery.registry.html
|
|
celery.registry.AlreadyRegistered exception reference/celery.registry.html
|
|
celery.backends.base.UnpickleableExceptionWrapper exception reference/celery.backends.base.html
|
|
celery.backends.base.UnpickleableExceptionWrapper exception reference/celery.backends.base.html
|
|
TASK_STATUS_FAILURE data reference/celery.models.html
|
|
TASK_STATUS_FAILURE data reference/celery.models.html
|
|
@@ -52,10 +52,12 @@ celery.task.DeleteExpiredTaskMetaTask class reference/celery.task.html
|
|
celery.managers.TaskManager.get_all_expired method reference/celery.managers.html
|
|
celery.managers.TaskManager.get_all_expired method reference/celery.managers.html
|
|
TaskMeta.task_id attribute reference/celery.models.html
|
|
TaskMeta.task_id attribute reference/celery.models.html
|
|
celery.discovery.autodiscover function reference/celery.discovery.html
|
|
celery.discovery.autodiscover function reference/celery.discovery.html
|
|
|
|
+celery.result.TaskSetResult.ready method reference/celery.result.html
|
|
celery.worker.WorkController.receive_message method reference/celery.worker.html
|
|
celery.worker.WorkController.receive_message method reference/celery.worker.html
|
|
celery.backends.get_default_backend_cls data reference/celery.backends.html
|
|
celery.backends.get_default_backend_cls data reference/celery.backends.html
|
|
celery.task.Task.apply_async classmethod reference/celery.task.html
|
|
celery.task.Task.apply_async classmethod reference/celery.task.html
|
|
celery.backends.tyrant.Backend.get_result method reference/celery.backends.tyrant.html
|
|
celery.backends.tyrant.Backend.get_result method reference/celery.backends.tyrant.html
|
|
|
|
+celery.result.TaskSetResult.total attribute reference/celery.result.html
|
|
celery.task.TaskSet class reference/celery.task.html
|
|
celery.task.TaskSet class reference/celery.task.html
|
|
celery.task.AsynchronousMapTask class reference/celery.task.html
|
|
celery.task.AsynchronousMapTask class reference/celery.task.html
|
|
celery.managers.PeriodicTaskManager class reference/celery.managers.html
|
|
celery.managers.PeriodicTaskManager class reference/celery.managers.html
|
|
@@ -73,6 +75,7 @@ celery.platform.PIDFile.remove method reference/celery.platform.html
|
|
celery.worker.WorkController.schedule_retry_tasks method reference/celery.worker.html
|
|
celery.worker.WorkController.schedule_retry_tasks method reference/celery.worker.html
|
|
PeriodicTaskMeta.task attribute reference/celery.models.html
|
|
PeriodicTaskMeta.task attribute reference/celery.models.html
|
|
celery.conf.EMPTY_MSG_EMIT_EVERY data reference/celery.conf.html
|
|
celery.conf.EMPTY_MSG_EMIT_EVERY data reference/celery.conf.html
|
|
|
|
+celery.result.TaskSetResult.successful method reference/celery.result.html
|
|
celery.backends.base.BaseBackend.wait_for method reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.wait_for method reference/celery.backends.base.html
|
|
celery.task.Task.name attribute reference/celery.task.html
|
|
celery.task.Task.name attribute reference/celery.task.html
|
|
celery.backends.base.BaseBackend.mark_as_done method reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.mark_as_done method reference/celery.backends.base.html
|
|
@@ -80,6 +83,7 @@ celery.conf.DEFAULT_DAEMON_LOG_FILE data reference/celery.conf.html
|
|
celery.registry.TaskRegistry.get_all_periodic method reference/celery.registry.html
|
|
celery.registry.TaskRegistry.get_all_periodic method reference/celery.registry.html
|
|
PeriodicTaskMeta.last_run_at attribute reference/celery.models.html
|
|
PeriodicTaskMeta.last_run_at attribute reference/celery.models.html
|
|
celery.task.Task.get_publisher method reference/celery.task.html
|
|
celery.task.Task.get_publisher method reference/celery.task.html
|
|
|
|
+celery.result.TaskSetResult.itersubtasks method reference/celery.result.html
|
|
celery.backends.base.BaseBackend.cleanup method reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.cleanup method reference/celery.backends.base.html
|
|
celery.task.discard_all function reference/celery.task.html
|
|
celery.task.discard_all function reference/celery.task.html
|
|
celery.backends.database.Backend.get_status method reference/celery.backends.database.html
|
|
celery.backends.database.Backend.get_status method reference/celery.backends.database.html
|
|
@@ -96,6 +100,7 @@ celery.registry.TaskRegistry.NotRegistered exception reference/celery.registry.h
|
|
celery.datastructures.PositionQueue.length attribute reference/celery.datastructures.html
|
|
celery.datastructures.PositionQueue.length attribute reference/celery.datastructures.html
|
|
celery.datastructures.PositionQueue class reference/celery.datastructures.html
|
|
celery.datastructures.PositionQueue class reference/celery.datastructures.html
|
|
celery.backends.base.BaseBackend.prepare_result method reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.prepare_result method reference/celery.backends.base.html
|
|
|
|
+celery.result.TaskSetResult class reference/celery.result.html
|
|
celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_module attribute reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_module attribute reference/celery.backends.base.html
|
|
celery.task.ExecuteRemoteTask class reference/celery.task.html
|
|
celery.task.ExecuteRemoteTask class reference/celery.task.html
|
|
celery.task.dmap_async function reference/celery.task.html
|
|
celery.task.dmap_async function reference/celery.task.html
|
|
@@ -104,14 +109,17 @@ celery.managers.TaskManager class reference/celery.managers.html
|
|
celery.backends.base.BaseBackend.store_result method reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.store_result method reference/celery.backends.base.html
|
|
celery.worker.jail function reference/celery.worker.html
|
|
celery.worker.jail function reference/celery.worker.html
|
|
celery.task.TaskSet.remote_execute classmethod reference/celery.task.html
|
|
celery.task.TaskSet.remote_execute classmethod reference/celery.task.html
|
|
|
|
+celery.result.TaskSetResult.waiting method reference/celery.result.html
|
|
celery.result.AsyncResult.task_id attribute reference/celery.result.html
|
|
celery.result.AsyncResult.task_id attribute reference/celery.result.html
|
|
celery.timer.EventTimer.interval attribute reference/celery.timer.html
|
|
celery.timer.EventTimer.interval attribute reference/celery.timer.html
|
|
celery.result.BaseAsyncResult.successful method reference/celery.result.html
|
|
celery.result.BaseAsyncResult.successful method reference/celery.result.html
|
|
|
|
+celery.timer.TimeoutError exception reference/celery.timer.html
|
|
celery.backends.tyrant.Backend.get_server method reference/celery.backends.tyrant.html
|
|
celery.backends.tyrant.Backend.get_server method reference/celery.backends.tyrant.html
|
|
celery.conf.LOG_FORMAT data reference/celery.conf.html
|
|
celery.conf.LOG_FORMAT data reference/celery.conf.html
|
|
TASK_STATUSES data reference/celery.models.html
|
|
TASK_STATUSES data reference/celery.models.html
|
|
celery.managers.TaskManager.get_task method reference/celery.managers.html
|
|
celery.managers.TaskManager.get_task method reference/celery.managers.html
|
|
celery.conf.AMQP_EXCHANGE data reference/celery.conf.html
|
|
celery.conf.AMQP_EXCHANGE data reference/celery.conf.html
|
|
|
|
+celery.result.TaskSetResult.subtask_ids attribute reference/celery.result.html
|
|
PeriodicTaskMeta.delay method reference/celery.models.html
|
|
PeriodicTaskMeta.delay method reference/celery.models.html
|
|
celery.timer.TimeoutTimer.timeout attribute reference/celery.timer.html
|
|
celery.timer.TimeoutTimer.timeout attribute reference/celery.timer.html
|
|
celery.backends.database.Backend.cleanup method reference/celery.backends.database.html
|
|
celery.backends.database.Backend.cleanup method reference/celery.backends.database.html
|
|
@@ -122,6 +130,7 @@ celery.result.BaseAsyncResult.status attribute reference/celery.result.html
|
|
celery.worker.TaskWrapper.kwargs attribute reference/celery.worker.html
|
|
celery.worker.TaskWrapper.kwargs attribute reference/celery.worker.html
|
|
celery.conf.QUEUE_WAKEUP_AFTER data reference/celery.conf.html
|
|
celery.conf.QUEUE_WAKEUP_AFTER data reference/celery.conf.html
|
|
celery.backends.database.Backend.get_result method reference/celery.backends.database.html
|
|
celery.backends.database.Backend.get_result method reference/celery.backends.database.html
|
|
|
|
+celery.worker.TaskWrapper.on_success method reference/celery.worker.html
|
|
celery.backends.get_backend_cls function reference/celery.backends.html
|
|
celery.backends.get_backend_cls function reference/celery.backends.html
|
|
celery.registry.TaskRegistry.register method reference/celery.registry.html
|
|
celery.registry.TaskRegistry.register method reference/celery.registry.html
|
|
celery.worker.TaskWrapper.args attribute reference/celery.worker.html
|
|
celery.worker.TaskWrapper.args attribute reference/celery.worker.html
|
|
@@ -165,12 +174,15 @@ celery.worker.UnknownTask exception reference/celery.worker.html
|
|
celery.timer.TimeoutTimer class reference/celery.timer.html
|
|
celery.timer.TimeoutTimer class reference/celery.timer.html
|
|
celery.backends.get_default_periodicstatus_backend_cls function reference/celery.backends.html
|
|
celery.backends.get_default_periodicstatus_backend_cls function reference/celery.backends.html
|
|
celery.result.BaseAsyncResult.wait method reference/celery.result.html
|
|
celery.result.BaseAsyncResult.wait method reference/celery.result.html
|
|
|
|
+celery.result.TaskSetResult.join method reference/celery.result.html
|
|
celery.task.TaskSet.run method reference/celery.task.html
|
|
celery.task.TaskSet.run method reference/celery.task.html
|
|
|
|
+celery.task.ExecuteRemoteTask.run method reference/celery.task.html
|
|
celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_cls_name attribute reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_cls_name attribute reference/celery.backends.base.html
|
|
celery.result.AsyncResult.backend attribute reference/celery.result.html
|
|
celery.result.AsyncResult.backend attribute reference/celery.result.html
|
|
celery.task.apply_async function reference/celery.task.html
|
|
celery.task.apply_async function reference/celery.task.html
|
|
celery.result.BaseAsyncResult.result attribute reference/celery.result.html
|
|
celery.result.BaseAsyncResult.result attribute reference/celery.result.html
|
|
celery.backends.cache.Backend.store_result method reference/celery.backends.cache.html
|
|
celery.backends.cache.Backend.store_result method reference/celery.backends.cache.html
|
|
|
|
+celery.result.TaskSetResult.failed method reference/celery.result.html
|
|
TaskMeta.status attribute reference/celery.models.html
|
|
TaskMeta.status attribute reference/celery.models.html
|
|
celery.worker.WorkController.concurrency attribute reference/celery.worker.html
|
|
celery.worker.WorkController.concurrency attribute reference/celery.worker.html
|
|
celery.backends.database.Backend.is_done method reference/celery.backends.database.html
|
|
celery.backends.database.Backend.is_done method reference/celery.backends.database.html
|
|
@@ -178,7 +190,6 @@ celery.backends.tyrant.Backend.tyrant_host attribute reference/celery.backends.t
|
|
celery.worker.WorkController.reset_connection method reference/celery.worker.html
|
|
celery.worker.WorkController.reset_connection method reference/celery.worker.html
|
|
celery.conf.AMQP_CONSUMER_QUEUE data reference/celery.conf.html
|
|
celery.conf.AMQP_CONSUMER_QUEUE data reference/celery.conf.html
|
|
TASK_STATUSES_CHOICES data reference/celery.models.html
|
|
TASK_STATUSES_CHOICES data reference/celery.models.html
|
|
-celery.worker.WorkController.fetch_next_task method reference/celery.worker.html
|
|
|
|
celery.backends.base.BaseBackend.mark_as_retry method reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.mark_as_retry method reference/celery.backends.base.html
|
|
celery.timer.EventTimer.last_triggered attribute reference/celery.timer.html
|
|
celery.timer.EventTimer.last_triggered attribute reference/celery.timer.html
|
|
celery.datastructures.PositionQueue.filled attribute reference/celery.datastructures.html
|
|
celery.datastructures.PositionQueue.filled attribute reference/celery.datastructures.html
|
|
@@ -189,6 +200,7 @@ celery.conf.AMQP_PUBLISHER_ROUTING_KEY data reference/celery.conf.html
|
|
celery.backends.cache.Backend class reference/celery.backends.cache.html
|
|
celery.backends.cache.Backend class reference/celery.backends.cache.html
|
|
celery.task.is_done function reference/celery.task.html
|
|
celery.task.is_done function reference/celery.task.html
|
|
celery.task.PeriodicTask.run_every attribute reference/celery.task.html
|
|
celery.task.PeriodicTask.run_every attribute reference/celery.task.html
|
|
|
|
+celery.worker.TaskWrapper.on_failure method reference/celery.worker.html
|
|
celery.conf.LOG_LEVELS data reference/celery.conf.html
|
|
celery.conf.LOG_LEVELS data reference/celery.conf.html
|
|
celery.managers.TaskManager.is_done method reference/celery.managers.html
|
|
celery.managers.TaskManager.is_done method reference/celery.managers.html
|
|
celery.timer.EventTimer.tick method reference/celery.timer.html
|
|
celery.timer.EventTimer.tick method reference/celery.timer.html
|
|
@@ -214,11 +226,12 @@ celery.task.Task.type attribute reference/celery.task.html
|
|
celery.task.TaskSet.iterate method reference/celery.task.html
|
|
celery.task.TaskSet.iterate method reference/celery.task.html
|
|
PeriodicTaskMeta.total_run_count attribute reference/celery.models.html
|
|
PeriodicTaskMeta.total_run_count attribute reference/celery.models.html
|
|
celery.datastructures.PositionQueue.UnfilledPosition class reference/celery.datastructures.html
|
|
celery.datastructures.PositionQueue.UnfilledPosition class reference/celery.datastructures.html
|
|
-celery.task.ExecuteRemoteTask.run method reference/celery.task.html
|
|
|
|
|
|
+celery.result.TaskSetResult.completed_count method reference/celery.result.html
|
|
celery.timer.EventTimer class reference/celery.timer.html
|
|
celery.timer.EventTimer class reference/celery.timer.html
|
|
celery.messaging.TaskConsumer class reference/celery.messaging.html
|
|
celery.messaging.TaskConsumer class reference/celery.messaging.html
|
|
celery.platform.daemonize function reference/celery.platform.html
|
|
celery.platform.daemonize function reference/celery.platform.html
|
|
celery.managers.TaskManager.store_result method reference/celery.managers.html
|
|
celery.managers.TaskManager.store_result method reference/celery.managers.html
|
|
|
|
+celery.result.TaskSetResult.taskset_id attribute reference/celery.result.html
|
|
TaskMeta.result attribute reference/celery.models.html
|
|
TaskMeta.result attribute reference/celery.models.html
|
|
celery.timer.TimeoutTimer.time_start attribute reference/celery.timer.html
|
|
celery.timer.TimeoutTimer.time_start attribute reference/celery.timer.html
|
|
celery.task.TaskSet.arguments attribute reference/celery.task.html
|
|
celery.task.TaskSet.arguments attribute reference/celery.task.html
|