|
@@ -2,6 +2,7 @@
|
|
|
# Project: Celery
|
|
|
# Version: 0.7
|
|
|
celery.backends.base mod reference/celery.backends.base.html
|
|
|
+celery.exceptions mod reference/celery.exceptions.html
|
|
|
celery.execute mod reference/celery.execute.html
|
|
|
celery.task.strategy mod reference/celery.task.strategy.html
|
|
|
celery.loaders.djangoapp mod reference/celery.loaders.djangoapp.html
|
|
@@ -20,10 +21,11 @@ celery.supervisor mod reference/celery.supervisor.html
|
|
|
celery.backends mod reference/celery.backends.html
|
|
|
celery.loaders.base mod reference/celery.loaders.base.html
|
|
|
celery.worker mod reference/celery.worker.html
|
|
|
-celery.worker.controllers mod reference/celery.worker.controllers.html
|
|
|
+celery.bin.celeryinit mod reference/celery.bin.celeryinit.html
|
|
|
celery.backends.cache mod reference/celery.backends.cache.html
|
|
|
celery.datastructures mod reference/celery.datastructures.html
|
|
|
celery.messaging mod reference/celery.messaging.html
|
|
|
+celery.backends.amqp mod reference/celery.backends.amqp.html
|
|
|
celery.task.base mod reference/celery.task.base.html
|
|
|
celery.loaders mod reference/celery.loaders.html
|
|
|
celery.loaders.default mod reference/celery.loaders.default.html
|
|
@@ -34,15 +36,16 @@ celery.conf mod reference/celery.conf.html
|
|
|
celery.registry mod reference/celery.registry.html
|
|
|
celery.result mod reference/celery.result.html
|
|
|
celery.fields mod reference/celery.fields.html
|
|
|
+celery.worker.controllers mod reference/celery.worker.controllers.html
|
|
|
celery.supervisor.OFASupervisor.Process.exitcode attribute reference/celery.supervisor.html
|
|
|
-celery.backends.tyrant.Backend.tyrant_port attribute reference/celery.backends.tyrant.html
|
|
|
+celery.backends.base.BaseBackend.mark_as_done method reference/celery.backends.base.html
|
|
|
celery.worker.controllers.BackgroundThread.on_stop method reference/celery.worker.controllers.html
|
|
|
celery.result.TaskSetResult.iterate method reference/celery.result.html
|
|
|
celery.supervisor.OFASupervisor.Process.run method reference/celery.supervisor.html
|
|
|
-celery.registry.AlreadyRegistered exception reference/celery.registry.html
|
|
|
celery.task.base.AsynchronousMapTask class reference/celery.task.base.html
|
|
|
celery.result.BaseAsyncResult.backend attribute reference/celery.result.html
|
|
|
celery.fields.PickledObjectField.get_internal_type method reference/celery.fields.html
|
|
|
+celery.worker.WorkController class reference/celery.worker.html
|
|
|
celery.worker.WorkController.logfile attribute reference/celery.worker.html
|
|
|
celery.result.BaseAsyncResult.ready method reference/celery.result.html
|
|
|
celery.managers.TaskManager.delete_expired method reference/celery.managers.html
|
|
@@ -50,7 +53,7 @@ celery.datastructures.ExceptionInfo.traceback attribute reference/celery.datastr
|
|
|
celery.managers.TaskManager.get_all_expired method reference/celery.managers.html
|
|
|
celery.managers.table_lock attribute reference/celery.managers.html
|
|
|
celery.task.strategy.even_time_distribution function reference/celery.task.strategy.html
|
|
|
-celery.worker.controllers.PeriodicWorkController.process_hold_queue method reference/celery.worker.controllers.html
|
|
|
+celery.execute.ExecuteWrapper.handle_success method reference/celery.execute.html
|
|
|
celery.task.base.ExecuteRemoteTask.run method reference/celery.task.base.html
|
|
|
celery.task.base.Task.retry method reference/celery.task.base.html
|
|
|
celery.supervisor.OFASupervisor.start method reference/celery.supervisor.html
|
|
@@ -82,19 +85,18 @@ celery.task.base.PeriodicTask class reference/celery.task.base.html
|
|
|
celery.managers.TaskManager.get_task method reference/celery.managers.html
|
|
|
celery.loaders.djangoapp.Loader.read_configuration method reference/celery.loaders.djangoapp.html
|
|
|
celery.conf.DAEMON_LOG_LEVEL data reference/celery.conf.html
|
|
|
-celery.task.base.MaxRetriesExceededError exception reference/celery.task.base.html
|
|
|
celery.task.builtins.PingTask.run method reference/celery.task.builtins.html
|
|
|
celery.result.BaseAsyncResult.status attribute reference/celery.result.html
|
|
|
celery.conf.DEFAULT_AMQP_CONNECTION_MAX_RETRIES data reference/celery.conf.html
|
|
|
celery.monitoring.StatsCollector.total_task_time_running attribute reference/celery.monitoring.html
|
|
|
-celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
|
|
|
TaskMeta.date_done attribute reference/celery.models.html
|
|
|
celery.monitoring.StatsCollector.collect method reference/celery.monitoring.html
|
|
|
celery.monitoring.StatsCollector.total_task_time_running_by_type attribute reference/celery.monitoring.html
|
|
|
celery.backends.base.BaseBackend.is_done method reference/celery.backends.base.html
|
|
|
celery.loaders.base.BaseLoader.on_task_init method reference/celery.loaders.base.html
|
|
|
celery.task.base.TaskSet.map classmethod reference/celery.task.base.html
|
|
|
-celery.backends.base.BaseBackend.UnpickleableExceptionWrapper exception reference/celery.backends.base.html
|
|
|
+celery.exceptions.MaxRetriesExceededError exception reference/celery.exceptions.html
|
|
|
+celery.backends.amqp.Backend.store_result method reference/celery.backends.amqp.html
|
|
|
celery.worker.job.TaskWrapper.kwargs attribute reference/celery.worker.job.html
|
|
|
celery.messaging.TaskPublisher.delay_task method reference/celery.messaging.html
|
|
|
celery.worker.WorkController.is_detached attribute reference/celery.worker.html
|
|
@@ -102,8 +104,8 @@ celery.result.BaseAsyncResult.traceback attribute reference/celery.result.html
|
|
|
celery.task.base.TaskSet.map_async classmethod reference/celery.task.base.html
|
|
|
celery.worker.AMQPListener.reset_connection method reference/celery.worker.html
|
|
|
celery.loaders.djangoapp.Loader.on_task_init method reference/celery.loaders.djangoapp.html
|
|
|
+celery.execute.ExecuteWrapper.handle_retry method reference/celery.execute.html
|
|
|
celery.fields.PickledObjectField.get_db_prep_save method reference/celery.fields.html
|
|
|
-celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_cls_name attribute reference/celery.backends.base.html
|
|
|
celery.task.base.Task.exchange attribute reference/celery.task.base.html
|
|
|
celery.worker.job.TaskWrapper class reference/celery.worker.job.html
|
|
|
celery.worker.WorkController.concurrency attribute reference/celery.worker.html
|
|
@@ -134,24 +136,25 @@ celery.result.EagerResult.wait method reference/celery.result.html
|
|
|
celery.result.BaseAsyncResult.is_done method reference/celery.result.html
|
|
|
celery.conf.LOG_LEVELS data reference/celery.conf.html
|
|
|
celery.result.TaskSetResult.successful method reference/celery.result.html
|
|
|
-celery.backends.base.UnpickleableExceptionWrapper exception reference/celery.backends.base.html
|
|
|
+celery.result.TaskSetResult class reference/celery.result.html
|
|
|
celery.result.EagerResult.is_done method reference/celery.result.html
|
|
|
celery.monitoring.TimerStats.time_start attribute reference/celery.monitoring.html
|
|
|
celery.worker.job.TaskWrapper.task_func attribute reference/celery.worker.job.html
|
|
|
-celery.backends.base.BaseBackend.mark_as_done method reference/celery.backends.base.html
|
|
|
celery.pool.TaskPool class reference/celery.pool.html
|
|
|
celery.discovery.autodiscover function reference/celery.discovery.html
|
|
|
+celery.backends.amqp.Backend.is_done method reference/celery.backends.amqp.html
|
|
|
celery.result.EagerResult class reference/celery.result.html
|
|
|
+celery.worker.controllers.PeriodicWorkController.process_hold_queue method reference/celery.worker.controllers.html
|
|
|
celery.result.TaskSetResult.total attribute reference/celery.result.html
|
|
|
celery.task.ping function reference/celery.task.html
|
|
|
celery.supervisor.OFASupervisor.target attribute reference/celery.supervisor.html
|
|
|
celery.fields.PickledObject class reference/celery.fields.html
|
|
|
celery.utils.mitemgetter function reference/celery.utils.html
|
|
|
-celery.pool.TaskPool.on_return method reference/celery.pool.html
|
|
|
celery.worker.WorkController.process_task method reference/celery.worker.html
|
|
|
celery.monitoring.StatsCollector class reference/celery.monitoring.html
|
|
|
celery.supervisor.OFASupervisor.Process class reference/celery.supervisor.html
|
|
|
celery.registry.TaskRegistry.get_all_periodic method reference/celery.registry.html
|
|
|
+celery.task.base.Task.on_success method reference/celery.task.base.html
|
|
|
celery.utils.repeatlast function reference/celery.utils.html
|
|
|
celery.loaders.default.Loader.on_worker_init method reference/celery.loaders.default.html
|
|
|
celery.worker.job.TaskWrapper.on_success method reference/celery.worker.job.html
|
|
@@ -160,10 +163,10 @@ celery.task.base.AsynchronousMapTask.run method reference/celery.task.base.html
|
|
|
celery.pool.DynamicPool.grow method reference/celery.pool.html
|
|
|
celery.backends.base.BaseBackend class reference/celery.backends.base.html
|
|
|
celery.conf.AMQP_EXCHANGE_TYPE data reference/celery.conf.html
|
|
|
-celery.worker.WorkController class reference/celery.worker.html
|
|
|
+celery.exceptions.AlreadyRegistered exception reference/celery.exceptions.html
|
|
|
celery.backends.base.BaseBackend.prepare_exception method reference/celery.backends.base.html
|
|
|
celery.task.base.Task.run method reference/celery.task.base.html
|
|
|
-celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_module attribute reference/celery.backends.base.html
|
|
|
+celery.backends.amqp.Backend class reference/celery.backends.amqp.html
|
|
|
celery.managers.TaskManager class reference/celery.managers.html
|
|
|
celery.worker.job.TaskWrapper.task_id attribute reference/celery.worker.job.html
|
|
|
celery.utils.chunks function reference/celery.utils.html
|
|
@@ -175,22 +178,20 @@ celery.backends.database.Backend class reference/celery.backends.database.html
|
|
|
celery.task.builtins.PingTask class reference/celery.task.builtins.html
|
|
|
celery.bin.celeryd.install_restart_signal_handler function reference/celery.bin.celeryd.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.worker.AMQPListener.consume_messages method reference/celery.worker.html
|
|
|
celery.worker.job.TaskWrapper.message attribute reference/celery.worker.job.html
|
|
|
-celery.backends.base.TimeoutError exception reference/celery.backends.base.html
|
|
|
celery.managers.TableLock.lock_table method reference/celery.managers.html
|
|
|
celery.worker.controllers.BackgroundThread.run method reference/celery.worker.controllers.html
|
|
|
celery.conf.STATISTICS_COLLECT_INTERVAL data reference/celery.conf.html
|
|
|
+celery.backends.tyrant.Backend.tyrant_port attribute reference/celery.backends.tyrant.html
|
|
|
celery.result.BaseAsyncResult.task_id attribute reference/celery.result.html
|
|
|
celery.fields.PickledObjectField class reference/celery.fields.html
|
|
|
celery.pool.TaskPool.logger attribute reference/celery.pool.html
|
|
|
celery.worker.AMQPListener.start method reference/celery.worker.html
|
|
|
-celery.loaders.default.Loader.read_configuration method reference/celery.loaders.default.html
|
|
|
celery.worker.AMQPListener.close_connection method reference/celery.worker.html
|
|
|
celery.worker.AMQPListener.receive_message method reference/celery.worker.html
|
|
|
celery.task.base.Task.type attribute reference/celery.task.base.html
|
|
|
-celery.backends.get_default_periodicstatus_backend_cls function reference/celery.backends.html
|
|
|
+celery.exceptions.RetryTaskError exception reference/celery.exceptions.html
|
|
|
celery.worker.WorkController.bucket_queue attribute reference/celery.worker.html
|
|
|
celery.task.base.Task class reference/celery.task.base.html
|
|
|
TaskMeta.status attribute reference/celery.models.html
|
|
@@ -200,12 +201,11 @@ celery.result.EagerResult.is_ready method reference/celery.result.html
|
|
|
celery.backends.base.BaseBackend.mark_as_retry method reference/celery.backends.base.html
|
|
|
celery.datastructures.PositionQueue.filled attribute reference/celery.datastructures.html
|
|
|
TASK_STATUS_DONE data reference/celery.models.html
|
|
|
-celery.backends.base.UnpickleableExceptionWrapper.exc_cls_name attribute reference/celery.backends.base.html
|
|
|
celery.conf.AMQP_PUBLISHER_ROUTING_KEY data reference/celery.conf.html
|
|
|
celery.backends.cache.Backend class reference/celery.backends.cache.html
|
|
|
celery.worker.controllers.PeriodicWorkController class reference/celery.worker.controllers.html
|
|
|
+celery.execute.ExecuteWrapper.handle_failure method reference/celery.execute.html
|
|
|
celery.supervisor.OFASupervisor.Process.daemon attribute reference/celery.supervisor.html
|
|
|
-celery.registry.NotRegistered exception reference/celery.registry.html
|
|
|
celery.conf.DAEMON_CONCURRENCY data reference/celery.conf.html
|
|
|
celery.registry.TaskRegistry.get_all method reference/celery.registry.html
|
|
|
celery.managers.MySQLTableLock class reference/celery.managers.html
|
|
@@ -226,7 +226,6 @@ celery.messaging.TaskPublisher.encoder method reference/celery.messaging.html
|
|
|
celery.task.base.TaskSet.join method reference/celery.task.base.html
|
|
|
celery.datastructures.PositionQueue.full method reference/celery.datastructures.html
|
|
|
celery.registry.TaskRegistry.AlreadyRegistered exception reference/celery.registry.html
|
|
|
-celery.backends.base.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
|
|
|
celery.conf.AMQP_CONSUMER_QUEUE data reference/celery.conf.html
|
|
|
celery.monitoring.StatsCollector.task_time_running method reference/celery.monitoring.html
|
|
|
PeriodicTaskMeta.total_run_count attribute reference/celery.models.html
|
|
@@ -234,7 +233,7 @@ celery.result.TaskSetResult.ready method reference/celery.result.html
|
|
|
celery.backends.get_default_backend_cls data reference/celery.backends.html
|
|
|
celery.worker.job.TaskWrapper.args attribute reference/celery.worker.job.html
|
|
|
celery.conf.AMQP_CONSUMER_QUEUES data reference/celery.conf.html
|
|
|
-celery.result.TimeoutError exception reference/celery.result.html
|
|
|
+celery.backends.get_default_periodicstatus_backend_cls function reference/celery.backends.html
|
|
|
celery.backends.database.Backend.store_result method reference/celery.backends.database.html
|
|
|
celery.monitoring.TaskTimerStats class reference/celery.monitoring.html
|
|
|
PeriodicTaskMeta.task attribute reference/celery.models.html
|
|
@@ -244,7 +243,6 @@ PeriodicTaskMeta class reference/celery.models.html
|
|
|
celery.utils.get_full_cls_name function reference/celery.utils.html
|
|
|
celery.worker.job.TaskWrapper.extend_with_default_kwargs method reference/celery.worker.job.html
|
|
|
celery.result.AsyncResult class reference/celery.result.html
|
|
|
-celery.result.TaskSetResult class reference/celery.result.html
|
|
|
celery.datastructures.SharedCounter class reference/celery.datastructures.html
|
|
|
celery.task.dmap_async function reference/celery.task.html
|
|
|
celery.result.TaskSetResult.waiting method reference/celery.result.html
|
|
@@ -261,20 +259,18 @@ celery.backends.database.Backend.get_result method reference/celery.backends.dat
|
|
|
celery.supervisor.OFASupervisor.max_restart_freq_time attribute reference/celery.supervisor.html
|
|
|
celery.backends.get_backend_cls function reference/celery.backends.html
|
|
|
celery.conf.AMQP_CONNECTION_MAX_RETRIES data reference/celery.conf.html
|
|
|
-celery.backends.base.BaseBackend.create_exception_cls method reference/celery.backends.base.html
|
|
|
celery.monitoring.Statistics.stop method reference/celery.monitoring.html
|
|
|
celery.registry.TaskRegistry.unregister method reference/celery.registry.html
|
|
|
celery.pool.TaskPool.stop method reference/celery.pool.html
|
|
|
celery.result.TaskSetResult.failed method reference/celery.result.html
|
|
|
celery.worker.job.TaskWrapper.execute method reference/celery.worker.job.html
|
|
|
-celery.worker.job.jail function reference/celery.worker.job.html
|
|
|
celery.monitoring.Statistics.start classmethod reference/celery.monitoring.html
|
|
|
celery.backends.base.BaseBackend.TimeoutError exception reference/celery.backends.base.html
|
|
|
celery.managers.MySQLTableLock.unlock_table method reference/celery.managers.html
|
|
|
celery.loaders.base.BaseLoader.on_worker_init method reference/celery.loaders.base.html
|
|
|
celery.managers.PeriodicTaskManager.get_waiting_tasks method reference/celery.managers.html
|
|
|
celery.pool.DynamicPool.replace_dead_workers method reference/celery.pool.html
|
|
|
-celery.result.TaskSetResult.itersubtasks method reference/celery.result.html
|
|
|
+celery.registry.TaskRegistry.register method reference/celery.registry.html
|
|
|
celery.registry.TaskRegistry class reference/celery.registry.html
|
|
|
celery.backends.DefaultBackend class reference/celery.backends.html
|
|
|
celery.task.base.Task.MaxRetriesExceededError exception reference/celery.task.base.html
|
|
@@ -284,8 +280,8 @@ celery.monitoring.Statistics.type attribute reference/celery.monitoring.html
|
|
|
celery.bin.celeryd.run_worker function reference/celery.bin.celeryd.html
|
|
|
celery.result.AsyncResult.backend attribute reference/celery.result.html
|
|
|
celery.result.BaseAsyncResult.result attribute reference/celery.result.html
|
|
|
+celery.task.base.Task.on_failure method reference/celery.task.base.html
|
|
|
celery.backends.tyrant.Backend.tyrant_host attribute reference/celery.backends.tyrant.html
|
|
|
-celery.backends.base.UnpickleableExceptionWrapper.exc_module attribute reference/celery.backends.base.html
|
|
|
celery.pool.TaskPool.start method reference/celery.pool.html
|
|
|
celery.monitoring.TimerStats.on_start method reference/celery.monitoring.html
|
|
|
celery.task.is_done function reference/celery.task.html
|
|
@@ -300,20 +296,22 @@ celery.fields.PickledObjectField.get_db_prep_lookup method reference/celery.fiel
|
|
|
TASK_STATUS_PENDING data reference/celery.models.html
|
|
|
celery.result.EagerResult.TimeoutError exception reference/celery.result.html
|
|
|
celery.managers.TableLock.unlock_table method reference/celery.managers.html
|
|
|
-celery.task.base.RetryTaskError exception reference/celery.task.base.html
|
|
|
+celery.loaders.default.Loader.read_configuration method reference/celery.loaders.default.html
|
|
|
celery.result.TaskSetResult.completed_count method reference/celery.result.html
|
|
|
+celery.exceptions.TimeoutError exception reference/celery.exceptions.html
|
|
|
celery.messaging.TaskConsumer class reference/celery.messaging.html
|
|
|
celery.worker.WorkController.safe_process_task method reference/celery.worker.html
|
|
|
celery.result.TaskSetResult.taskset_id attribute reference/celery.result.html
|
|
|
celery.supervisor.OFASupervisor.Process.join method reference/celery.supervisor.html
|
|
|
+celery.backends.amqp.Backend.get_traceback method reference/celery.backends.amqp.html
|
|
|
celery.log.emergency_error function reference/celery.log.html
|
|
|
celery.monitoring.Statistics.on_start method reference/celery.monitoring.html
|
|
|
celery.supervisor.OFASupervisor.args attribute reference/celery.supervisor.html
|
|
|
celery.task.base.Task.routing_key attribute reference/celery.task.base.html
|
|
|
-celery.registry.TaskRegistry.register method reference/celery.registry.html
|
|
|
celery.task.base.PeriodicTask.run_every attribute reference/celery.task.base.html
|
|
|
celery.managers.TaskManager.is_done method reference/celery.managers.html
|
|
|
celery.task.base.Task.get_consumer method reference/celery.task.base.html
|
|
|
+celery.execute.ExecuteWrapper class reference/celery.execute.html
|
|
|
celery.discovery.find_related_module function reference/celery.discovery.html
|
|
|
celery.registry.TaskRegistry.filter_types method reference/celery.registry.html
|
|
|
celery.worker.controllers.Mediator class reference/celery.worker.controllers.html
|
|
@@ -324,6 +322,7 @@ TaskMeta.task_id attribute reference/celery.models.html
|
|
|
celery.task.base.TaskSet.task_name attribute reference/celery.task.base.html
|
|
|
celery.supervisor.OFASupervisor.Process.ident attribute reference/celery.supervisor.html
|
|
|
celery.datastructures.ExceptionInfo class reference/celery.datastructures.html
|
|
|
+celery.backends.amqp.Backend.get_result method reference/celery.backends.amqp.html
|
|
|
celery.task.base.Task.ignore_result attribute reference/celery.task.base.html
|
|
|
celery.managers.PeriodicTaskManager class reference/celery.managers.html
|
|
|
TaskMeta class reference/celery.models.html
|
|
@@ -333,6 +332,8 @@ celery.pool.DynamicPool class reference/celery.pool.html
|
|
|
celery.backends.tyrant.Backend.close method reference/celery.backends.tyrant.html
|
|
|
celery.backends.base.BaseBackend.wait_for method reference/celery.backends.base.html
|
|
|
PeriodicTaskMeta.last_run_at attribute reference/celery.models.html
|
|
|
+celery.exceptions.NotRegistered exception reference/celery.exceptions.html
|
|
|
+celery.result.TaskSetResult.itersubtasks method reference/celery.result.html
|
|
|
celery.bin.celeryd.acquire_pidlock function reference/celery.bin.celeryd.html
|
|
|
celery.task.base.TaskSet.remote_execute classmethod reference/celery.task.base.html
|
|
|
celery.backends.database.Backend.get_status method reference/celery.backends.database.html
|
|
@@ -357,6 +358,7 @@ celery.task.builtins.DeleteExpiredTaskMetaTask.run method reference/celery.task.
|
|
|
celery.task.base.Task.delay classmethod reference/celery.task.base.html
|
|
|
celery.pool.TaskPool.apply_async method reference/celery.pool.html
|
|
|
PeriodicTaskMeta.name attribute reference/celery.models.html
|
|
|
+celery.task.base.Task.on_retry method reference/celery.task.base.html
|
|
|
celery.monitoring.Statistics.run method reference/celery.monitoring.html
|
|
|
celery.task.base.Task.apply classmethod reference/celery.task.base.html
|
|
|
celery.registry.TaskRegistry.get_task method reference/celery.registry.html
|
|
@@ -370,6 +372,7 @@ celery.result.TaskSetResult.join method reference/celery.result.html
|
|
|
celery.task.builtins.DeleteExpiredTaskMetaTask class reference/celery.task.builtins.html
|
|
|
celery.worker.job.TaskWrapper.task_name attribute reference/celery.worker.job.html
|
|
|
celery.pool.process_is_dead function reference/celery.pool.html
|
|
|
+celery.backends.amqp.Backend.get_status method reference/celery.backends.amqp.html
|
|
|
celery.worker.WorkController.amqp_listener attribute reference/celery.worker.html
|
|
|
celery.backends.database.Backend.is_done method reference/celery.backends.database.html
|
|
|
TASK_STATUSES_CHOICES data reference/celery.models.html
|