|
@@ -36,15 +36,15 @@ TASK_STATUS_FAILURE data reference/celery.models.html
|
|
celery.task.execute_remote function reference/celery.task.html
|
|
celery.task.execute_remote function reference/celery.task.html
|
|
celery.result.BaseAsyncResult.backend attribute reference/celery.result.html
|
|
celery.result.BaseAsyncResult.backend attribute reference/celery.result.html
|
|
celery.worker.TaskWrapper class reference/celery.worker.html
|
|
celery.worker.TaskWrapper class reference/celery.worker.html
|
|
|
|
+celery.messaging.TaskPublisher.encoder method reference/celery.messaging.html
|
|
celery.datastructures.PositionQueue.full method reference/celery.datastructures.html
|
|
celery.datastructures.PositionQueue.full method reference/celery.datastructures.html
|
|
celery.discovery.find_related_module function reference/celery.discovery.html
|
|
celery.discovery.find_related_module function reference/celery.discovery.html
|
|
-celery.task.TaskSet.join method reference/celery.task.html
|
|
|
|
|
|
+celery.worker.WorkController.logfile attribute reference/celery.worker.html
|
|
celery.result.BaseAsyncResult.ready method reference/celery.result.html
|
|
celery.result.BaseAsyncResult.ready method reference/celery.result.html
|
|
celery.worker.EmptyQueue exception reference/celery.worker.html
|
|
celery.worker.EmptyQueue exception reference/celery.worker.html
|
|
celery.registry.TaskRegistry.AlreadyRegistered exception reference/celery.registry.html
|
|
celery.registry.TaskRegistry.AlreadyRegistered exception reference/celery.registry.html
|
|
celery.managers.TaskManager.delete_expired method reference/celery.managers.html
|
|
celery.managers.TaskManager.delete_expired method reference/celery.managers.html
|
|
celery.registry.TaskRegistry.filter_types method reference/celery.registry.html
|
|
celery.registry.TaskRegistry.filter_types method reference/celery.registry.html
|
|
-celery.worker.jail function reference/celery.worker.html
|
|
|
|
celery.backends.base.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
|
|
celery.backends.base.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
|
|
celery.backends.tyrant.Backend class reference/celery.backends.tyrant.html
|
|
celery.backends.tyrant.Backend class reference/celery.backends.tyrant.html
|
|
celery.worker.WorkController.pool attribute reference/celery.worker.html
|
|
celery.worker.WorkController.pool attribute reference/celery.worker.html
|
|
@@ -66,7 +66,7 @@ celery.platform.PIDFile.get_pid method reference/celery.platform.html
|
|
celery.task.Task.run method reference/celery.task.html
|
|
celery.task.Task.run method reference/celery.task.html
|
|
celery.result.BaseAsyncResult class reference/celery.result.html
|
|
celery.result.BaseAsyncResult class reference/celery.result.html
|
|
celery.platform.PIDFile.check method reference/celery.platform.html
|
|
celery.platform.PIDFile.check method reference/celery.platform.html
|
|
-celery.conf.LOG_FORMAT data reference/celery.conf.html
|
|
|
|
|
|
+TASK_STATUS_RETRY data reference/celery.models.html
|
|
celery.backends.database.Backend.store_result method reference/celery.backends.database.html
|
|
celery.backends.database.Backend.store_result method reference/celery.backends.database.html
|
|
celery.task.TaskSet.map_async classmethod reference/celery.task.html
|
|
celery.task.TaskSet.map_async classmethod reference/celery.task.html
|
|
celery.platform.PIDFile.remove method reference/celery.platform.html
|
|
celery.platform.PIDFile.remove method reference/celery.platform.html
|
|
@@ -76,6 +76,7 @@ celery.conf.EMPTY_MSG_EMIT_EVERY data reference/celery.conf.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
|
|
|
|
+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
|
|
@@ -89,26 +90,25 @@ celery.conf.AMQP_CONSUMER_ROUTING_KEY data reference/celery.conf.html
|
|
celery.backends.base.BaseBackend class reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend class reference/celery.backends.base.html
|
|
celery.conf.AMQP_EXCHANGE_TYPE data reference/celery.conf.html
|
|
celery.conf.AMQP_EXCHANGE_TYPE data reference/celery.conf.html
|
|
celery.worker.WorkController class reference/celery.worker.html
|
|
celery.worker.WorkController class reference/celery.worker.html
|
|
-celery.task.TaskSet.remote_execute classmethod reference/celery.task.html
|
|
|
|
|
|
+celery.backends.base.BaseBackend.mark_as_failure method reference/celery.backends.base.html
|
|
celery.backends.tyrant.Backend.get_status method reference/celery.backends.tyrant.html
|
|
celery.backends.tyrant.Backend.get_status method reference/celery.backends.tyrant.html
|
|
celery.registry.TaskRegistry.NotRegistered exception reference/celery.registry.html
|
|
celery.registry.TaskRegistry.NotRegistered exception reference/celery.registry.html
|
|
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.datastructures.TaskProcessQueue.wait_for_result method 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.datastructures.TaskProcessQueue class reference/celery.datastructures.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
|
|
celery.worker.WorkController.connection_diagnostics method reference/celery.worker.html
|
|
celery.worker.WorkController.connection_diagnostics method reference/celery.worker.html
|
|
celery.managers.TaskManager class reference/celery.managers.html
|
|
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.datastructures.TaskProcessQueue.logger attribute reference/celery.datastructures.html
|
|
|
|
|
|
+celery.worker.jail function reference/celery.worker.html
|
|
|
|
+celery.task.TaskSet.remote_execute classmethod reference/celery.task.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.backends.tyrant.Backend.get_server method reference/celery.backends.tyrant.html
|
|
celery.backends.tyrant.Backend.get_server method reference/celery.backends.tyrant.html
|
|
-TASK_STATUS_RETRY data reference/celery.models.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
|
|
@@ -120,7 +120,6 @@ celery.conf.DAEMON_LOG_LEVEL data reference/celery.conf.html
|
|
celery.backends.database.Backend class reference/celery.backends.database.html
|
|
celery.backends.database.Backend class reference/celery.backends.database.html
|
|
celery.result.BaseAsyncResult.status attribute reference/celery.result.html
|
|
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.datastructures.TaskProcessQueue.limit attribute reference/celery.datastructures.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.backends.get_backend_cls function reference/celery.backends.html
|
|
celery.backends.get_backend_cls function reference/celery.backends.html
|
|
@@ -132,7 +131,6 @@ celery.backends.cache.Backend.get_result method reference/celery.backends.cache.
|
|
celery.task.Task.get_logger method reference/celery.task.html
|
|
celery.task.Task.get_logger method reference/celery.task.html
|
|
celery.conf.DAEMON_LOG_FILE data reference/celery.conf.html
|
|
celery.conf.DAEMON_LOG_FILE data reference/celery.conf.html
|
|
celery.backends.base.find_nearest_pickleable_exception function reference/celery.backends.base.html
|
|
celery.backends.base.find_nearest_pickleable_exception function reference/celery.backends.base.html
|
|
-celery.datastructures.TaskProcessQueue.add method reference/celery.datastructures.html
|
|
|
|
celery.task.PeriodicTask class reference/celery.task.html
|
|
celery.task.PeriodicTask class reference/celery.task.html
|
|
celery.registry.TaskRegistry.unregister method reference/celery.registry.html
|
|
celery.registry.TaskRegistry.unregister method reference/celery.registry.html
|
|
celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
|
|
@@ -147,7 +145,6 @@ celery.worker.TaskWrapper.extend_with_default_kwargs method reference/celery.wor
|
|
celery.worker.WorkController.execute_next_task method reference/celery.worker.html
|
|
celery.worker.WorkController.execute_next_task method reference/celery.worker.html
|
|
celery.result.BaseAsyncResult.task_id attribute reference/celery.result.html
|
|
celery.result.BaseAsyncResult.task_id attribute reference/celery.result.html
|
|
celery.backends.cache.Backend.is_done method reference/celery.backends.cache.html
|
|
celery.backends.cache.Backend.is_done method reference/celery.backends.cache.html
|
|
-celery.worker.WorkController.logfile attribute reference/celery.worker.html
|
|
|
|
celery.task.Task.get_consumer method reference/celery.task.html
|
|
celery.task.Task.get_consumer method reference/celery.task.html
|
|
celery.messaging.TaskPublisher.delay_task_in_set method reference/celery.messaging.html
|
|
celery.messaging.TaskPublisher.delay_task_in_set method reference/celery.messaging.html
|
|
celery.backends.base.BaseBackend.UnpickleableExceptionWrapper exception reference/celery.backends.base.html
|
|
celery.backends.base.BaseBackend.UnpickleableExceptionWrapper exception reference/celery.backends.base.html
|
|
@@ -156,9 +153,9 @@ celery.platform.remove_pidfile function reference/celery.platform.html
|
|
celery.platform.PIDFile class reference/celery.platform.html
|
|
celery.platform.PIDFile class reference/celery.platform.html
|
|
celery.worker.TaskWrapper.task_id attribute reference/celery.worker.html
|
|
celery.worker.TaskWrapper.task_id attribute reference/celery.worker.html
|
|
celery.managers.PeriodicTaskManager.get_waiting_tasks method reference/celery.managers.html
|
|
celery.managers.PeriodicTaskManager.get_waiting_tasks method reference/celery.managers.html
|
|
-celery.backends.base.BaseBackend.mark_as_failure method reference/celery.backends.base.html
|
|
|
|
|
|
+celery.messaging.TaskPublisher.delay_task method reference/celery.messaging.html
|
|
celery.worker.WorkController.loglevel attribute reference/celery.worker.html
|
|
celery.worker.WorkController.loglevel attribute reference/celery.worker.html
|
|
-celery.datastructures.TaskProcessQueue.done_msg attribute reference/celery.datastructures.html
|
|
|
|
|
|
+celery.task.TaskSet.join method reference/celery.task.html
|
|
celery.worker.WorkController.queue_wakeup_after attribute reference/celery.worker.html
|
|
celery.worker.WorkController.queue_wakeup_after attribute reference/celery.worker.html
|
|
celery.registry.TaskRegistry.get_all_regular method reference/celery.registry.html
|
|
celery.registry.TaskRegistry.get_all_regular method reference/celery.registry.html
|
|
celery.worker.WorkController.run method reference/celery.worker.html
|
|
celery.worker.WorkController.run method reference/celery.worker.html
|
|
@@ -168,9 +165,7 @@ 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.datastructures.TaskProcessQueue.on_ready method reference/celery.datastructures.html
|
|
|
|
celery.task.TaskSet.run method reference/celery.task.html
|
|
celery.task.TaskSet.run method reference/celery.task.html
|
|
-celery.messaging.TaskPublisher.delay_task method reference/celery.messaging.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
|
|
@@ -197,7 +192,7 @@ celery.task.PeriodicTask.run_every attribute reference/celery.task.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
|
|
-celery.conf.DEFAULT_REAP_TIMEOUT data reference/celery.conf.html
|
|
|
|
|
|
+celery.messaging.TaskConsumer.decoder method reference/celery.messaging.html
|
|
celery.task.Task.delay classmethod reference/celery.task.html
|
|
celery.task.Task.delay classmethod reference/celery.task.html
|
|
celery.backends.cache.Backend.get_status method reference/celery.backends.cache.html
|
|
celery.backends.cache.Backend.get_status method reference/celery.backends.cache.html
|
|
celery.log.setup_logger function reference/celery.log.html
|
|
celery.log.setup_logger function reference/celery.log.html
|
|
@@ -206,7 +201,6 @@ celery.conf.DAEMON_CONCURRENCY data reference/celery.conf.html
|
|
celery.worker.WorkController.logger attribute reference/celery.worker.html
|
|
celery.worker.WorkController.logger attribute reference/celery.worker.html
|
|
celery.registry.TaskRegistry.get_all method reference/celery.registry.html
|
|
celery.registry.TaskRegistry.get_all method reference/celery.registry.html
|
|
celery.backends.tyrant.Backend.store_result method reference/celery.backends.tyrant.html
|
|
celery.backends.tyrant.Backend.store_result method reference/celery.backends.tyrant.html
|
|
-celery.datastructures.TaskProcessQueue.get_worker_pids method reference/celery.datastructures.html
|
|
|
|
celery.timer.TimeoutTimer.tick method reference/celery.timer.html
|
|
celery.timer.TimeoutTimer.tick method reference/celery.timer.html
|
|
TASK_STATUS_PENDING data reference/celery.models.html
|
|
TASK_STATUS_PENDING data reference/celery.models.html
|
|
celery.registry.TaskRegistry.get_task method reference/celery.registry.html
|
|
celery.registry.TaskRegistry.get_task method reference/celery.registry.html
|
|
@@ -227,5 +221,6 @@ 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
|
|
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.worker.TaskWrapper.task_name attribute reference/celery.worker.html
|
|
|
|
celery.task.TaskSet.arguments attribute reference/celery.task.html
|
|
celery.task.TaskSet.arguments attribute reference/celery.task.html
|
|
|
|
+celery.worker.TaskWrapper.task_name attribute reference/celery.worker.html
|
|
|
|
+celery.conf.SEND_CELERY_TASK_ERROR_EMAILS data reference/celery.conf.html
|