|
@@ -24,7 +24,7 @@ celery.messaging.NoProcessConsumer class reference/celery.messaging.html
|
|
|
celery.task.mark_as_done function reference/celery.task.html
|
|
|
celery.result.BaseAsyncResult.is_done method reference/celery.result.html
|
|
|
celery.worker.TaskWrapper.execute method reference/celery.worker.html
|
|
|
-celery.backends.base.BaseBackend.mark_as_done method reference/celery.backends.base.html
|
|
|
+celery.backends.tyrant.Backend.tyrant_port attribute reference/celery.backends.tyrant.html
|
|
|
celery.task.delay_task function reference/celery.task.html
|
|
|
celery.registry.AlreadyRegistered exception reference/celery.registry.html
|
|
|
TASK_STATUS_FAILURE data reference/celery.models.html
|
|
@@ -34,11 +34,14 @@ celery.discovery.find_related_module function reference/celery.discovery.html
|
|
|
celery.backends.tyrant.TT_PORT data reference/celery.backends.tyrant.html
|
|
|
celery.result.BaseAsyncResult.ready method reference/celery.result.html
|
|
|
celery.worker.EmptyQueue exception reference/celery.worker.html
|
|
|
+celery.worker.TaskDaemon.fetch_next_task method reference/celery.worker.html
|
|
|
celery.registry.TaskRegistry.AlreadyRegistered exception reference/celery.registry.html
|
|
|
celery.managers.TaskManager.delete_expired method reference/celery.managers.html
|
|
|
celery.registry.TaskRegistry.filter_types method reference/celery.registry.html
|
|
|
+celery.worker.TaskDaemon.receive_message method reference/celery.worker.html
|
|
|
celery.conf.AMQP_CONSUMER_QUEUE data reference/celery.conf.html
|
|
|
celery.task.DeleteExpiredTaskMetaTask class reference/celery.task.html
|
|
|
+celery.worker.TaskDaemon.connection_diagnostics method reference/celery.worker.html
|
|
|
celery.managers.TaskManager.get_all_expired method reference/celery.managers.html
|
|
|
TaskMeta.task_id attribute reference/celery.models.html
|
|
|
celery.platform.PIDFile.get_pid method reference/celery.platform.html
|
|
@@ -46,8 +49,10 @@ celery.worker.TaskDaemon class reference/celery.worker.html
|
|
|
celery.backends.get_default_backend_cls function reference/celery.backends.html
|
|
|
celery.backends.tyrant.Backend.get_result method reference/celery.backends.tyrant.html
|
|
|
celery.task.TaskSet class reference/celery.task.html
|
|
|
+celery.worker.TaskDaemon.loglevel attribute reference/celery.worker.html
|
|
|
celery.task.AsynchronousMapTask class reference/celery.task.html
|
|
|
celery.managers.PeriodicTaskManager class reference/celery.managers.html
|
|
|
+celery.timer.EventTimer.event attribute reference/celery.timer.html
|
|
|
TaskMeta class reference/celery.models.html
|
|
|
celery.worker.TaskWrapper.from_message classmethod reference/celery.worker.html
|
|
|
celery.timer.TimeoutError exception reference/celery.timer.html
|
|
@@ -60,7 +65,7 @@ celery.platform.PIDFile.remove method reference/celery.platform.html
|
|
|
PeriodicTaskMeta.task attribute reference/celery.models.html
|
|
|
celery.log.setup_logger function reference/celery.log.html
|
|
|
celery.backends.base.BaseBackend.wait_for method reference/celery.backends.base.html
|
|
|
-celery.result.AsyncResult class reference/celery.result.html
|
|
|
+celery.backends.base.BaseBackend.mark_as_done method reference/celery.backends.base.html
|
|
|
celery.registry.TaskRegistry.get_all_periodic method reference/celery.registry.html
|
|
|
celery.worker.TaskWrapper.extend_kwargs_with_logging method reference/celery.worker.html
|
|
|
PeriodicTaskMeta.last_run_at attribute reference/celery.models.html
|
|
@@ -81,17 +86,22 @@ celery.backends.base.BaseBackend.prepare_result method reference/celery.backends
|
|
|
celery.task.execute_remote function reference/celery.task.html
|
|
|
celery.task.ExecuteRemoteTask class reference/celery.task.html
|
|
|
celery.task.dmap_async function reference/celery.task.html
|
|
|
+celery.worker.TaskDaemon.receive_message_cc method reference/celery.worker.html
|
|
|
celery.managers.TaskManager class reference/celery.managers.html
|
|
|
celery.backends.base.BaseBackend.store_result method reference/celery.backends.base.html
|
|
|
celery.worker.jail function reference/celery.worker.html
|
|
|
celery.result.AsyncResult.task_id attribute reference/celery.result.html
|
|
|
+celery.timer.EventTimer.interval attribute reference/celery.timer.html
|
|
|
celery.result.BaseAsyncResult.successful method reference/celery.result.html
|
|
|
+celery.backends.tyrant.Backend.get_server method reference/celery.backends.tyrant.html
|
|
|
celery.conf.LOG_FORMAT data reference/celery.conf.html
|
|
|
TASK_STATUSES data reference/celery.models.html
|
|
|
celery.managers.TaskManager.get_task method reference/celery.managers.html
|
|
|
celery.conf.AMQP_EXCHANGE data reference/celery.conf.html
|
|
|
celery.registry.tasks data reference/celery.registry.html
|
|
|
+celery.worker.TaskDaemon.task_consumer attribute reference/celery.worker.html
|
|
|
celery.conf.AMQP_ROUTING_KEY data reference/celery.conf.html
|
|
|
+celery.timer.TimeoutTimer.timeout attribute reference/celery.timer.html
|
|
|
celery.result.AsyncResult.backend attribute reference/celery.result.html
|
|
|
celery.backends.database.Backend.cleanup method reference/celery.backends.database.html
|
|
|
celery.conf.DAEMON_LOG_LEVEL data reference/celery.conf.html
|
|
@@ -111,10 +121,13 @@ celery.task.PeriodicTask class reference/celery.task.html
|
|
|
celery.registry.TaskRegistry.unregister method reference/celery.registry.html
|
|
|
celery.task.TaskSet.remote_execute classmethod reference/celery.task.html
|
|
|
TaskMeta.date_done attribute reference/celery.models.html
|
|
|
+celery.worker.TaskDaemon.execute_next_task method reference/celery.worker.html
|
|
|
+celery.result.AsyncResult class reference/celery.result.html
|
|
|
PeriodicTaskMeta.name attribute reference/celery.models.html
|
|
|
celery.task.mark_as_failure function reference/celery.task.html
|
|
|
celery.worker.TaskWrapper.execute_using_pool method reference/celery.worker.html
|
|
|
celery.backends.base.BaseBackend.is_done method reference/celery.backends.base.html
|
|
|
+celery.worker.TaskDaemon.pool attribute reference/celery.worker.html
|
|
|
celery.backends.tyrant.Backend.is_done method reference/celery.backends.tyrant.html
|
|
|
celery.result.BaseAsyncResult.task_id attribute reference/celery.result.html
|
|
|
celery.backends.cache.Backend.is_done method reference/celery.backends.cache.html
|
|
@@ -128,6 +141,7 @@ celery.managers.PeriodicTaskManager.get_waiting_tasks method reference/celery.ma
|
|
|
celery.messaging.TaskPublisher.delay_task method reference/celery.messaging.html
|
|
|
celery.task.TaskSet.join method reference/celery.task.html
|
|
|
celery.registry.TaskRegistry.get_all_regular method reference/celery.registry.html
|
|
|
+celery.worker.TaskDaemon.logger attribute reference/celery.worker.html
|
|
|
celery.registry.TaskRegistry class reference/celery.registry.html
|
|
|
celery.backends.DefaultBackend class reference/celery.backends.html
|
|
|
PeriodicTaskMeta.total_run_count attribute reference/celery.models.html
|
|
@@ -135,16 +149,21 @@ celery.timer.TimeoutTimer class reference/celery.timer.html
|
|
|
celery.task.Task.run method reference/celery.task.html
|
|
|
celery.result.BaseAsyncResult.wait method reference/celery.result.html
|
|
|
celery.task.TaskSet.run method reference/celery.task.html
|
|
|
+celery.worker.TaskDaemon.reset_connection method reference/celery.worker.html
|
|
|
PeriodicTaskMeta.delay method reference/celery.models.html
|
|
|
celery.worker.TaskDaemon.run_periodic_tasks method reference/celery.worker.html
|
|
|
celery.result.BaseAsyncResult.result attribute reference/celery.result.html
|
|
|
+celery.worker.TaskDaemon.queue_wakeup_after attribute reference/celery.worker.html
|
|
|
celery.backends.cache.Backend.store_result method reference/celery.backends.cache.html
|
|
|
TaskMeta.status attribute reference/celery.models.html
|
|
|
celery.backends.database.Backend.is_done method reference/celery.backends.database.html
|
|
|
+celery.backends.tyrant.Backend.tyrant_host attribute reference/celery.backends.tyrant.html
|
|
|
celery.backends.tyrant.Backend class reference/celery.backends.tyrant.html
|
|
|
TASK_STATUSES_CHOICES data reference/celery.models.html
|
|
|
celery.backends.base.BaseBackend.mark_as_retry method reference/celery.backends.base.html
|
|
|
+celery.timer.EventTimer.last_triggered attribute reference/celery.timer.html
|
|
|
TASK_STATUS_DONE data reference/celery.models.html
|
|
|
+celery.worker.TaskDaemon.concurrency attribute reference/celery.worker.html
|
|
|
celery.backends.cache.Backend class reference/celery.backends.cache.html
|
|
|
celery.task.is_done function reference/celery.task.html
|
|
|
celery.conf.LOG_LEVELS data reference/celery.conf.html
|
|
@@ -155,11 +174,13 @@ celery.backends.cache.Backend.get_status method reference/celery.backends.cache.
|
|
|
celery.conf.EMPTY_MSG_EMIT_EVERY data reference/celery.conf.html
|
|
|
celery.registry.NotRegistered exception reference/celery.registry.html
|
|
|
celery.conf.DAEMON_CONCURRENCY data reference/celery.conf.html
|
|
|
+celery.worker.TaskDaemon.empty_msg_emit_every attribute reference/celery.worker.html
|
|
|
celery.registry.TaskRegistry.get_all method reference/celery.registry.html
|
|
|
celery.backends.tyrant.Backend.store_result method reference/celery.backends.tyrant.html
|
|
|
celery.timer.TimeoutTimer.tick method reference/celery.timer.html
|
|
|
TASK_STATUS_PENDING data reference/celery.models.html
|
|
|
celery.result.BaseAsyncResult.get method reference/celery.result.html
|
|
|
+celery.worker.TaskDaemon.logfile attribute reference/celery.worker.html
|
|
|
celery.conf.DAEMON_PID_FILE data reference/celery.conf.html
|
|
|
celery.task.Task class reference/celery.task.html
|
|
|
celery.backends.base.BaseBackend.get_status method reference/celery.backends.base.html
|
|
@@ -173,3 +194,4 @@ celery.messaging.TaskConsumer class reference/celery.messaging.html
|
|
|
celery.platform.daemonize function reference/celery.platform.html
|
|
|
celery.managers.TaskManager.store_result method reference/celery.managers.html
|
|
|
TaskMeta.result attribute reference/celery.models.html
|
|
|
+celery.timer.TimeoutTimer.time_start attribute reference/celery.timer.html
|