|
@@ -3,7 +3,7 @@
|
|
|
# Version: 0.3
|
|
|
celery.backends mod reference/celery.backends.html
|
|
|
celery.task mod reference/celery.task.html
|
|
|
-celery.worker mod reference/celery.worker.html
|
|
|
+celery.monitoring mod reference/celery.monitoring.html
|
|
|
celery.pool mod reference/celery.pool.html
|
|
|
celery.backends.cache mod reference/celery.backends.cache.html
|
|
|
celery.datastructures mod reference/celery.datastructures.html
|
|
@@ -14,6 +14,7 @@ celery.conf mod reference/celery.conf.html
|
|
|
celery.registry mod reference/celery.registry.html
|
|
|
celery.log mod reference/celery.log.html
|
|
|
celery.result mod reference/celery.result.html
|
|
|
+celery.worker mod reference/celery.worker.html
|
|
|
celery.backends.database mod reference/celery.backends.database.html
|
|
|
celery.bin.celeryd mod reference/celery.bin.celeryd.html
|
|
|
celery.discovery mod reference/celery.discovery.html
|
|
@@ -21,8 +22,10 @@ celery.timer mod reference/celery.timer.html
|
|
|
celery.backends.tyrant mod reference/celery.backends.tyrant.html
|
|
|
celery.task.TaskSet.task_name attribute reference/celery.task.html
|
|
|
celery.log.emergency_error function reference/celery.log.html
|
|
|
+celery.pool.TaskPool.add method reference/celery.pool.html
|
|
|
celery.backends.base.BaseBackend.get_result method reference/celery.backends.base.html
|
|
|
celery.task.dmap function reference/celery.task.html
|
|
|
+celery.monitoring.Statistics.on_start method reference/celery.monitoring.html
|
|
|
celery.result.BaseAsyncResult.is_done method reference/celery.result.html
|
|
|
celery.worker.TaskWrapper.execute method reference/celery.worker.html
|
|
|
celery.backends.database.Backend.run_periodic_tasks method reference/celery.backends.database.html
|
|
@@ -55,11 +58,12 @@ celery.datastructures.ExceptionInfo.traceback attribute reference/celery.datastr
|
|
|
celery.managers.TaskManager.get_all_expired method reference/celery.managers.html
|
|
|
TaskMeta.task_id attribute reference/celery.models.html
|
|
|
celery.discovery.autodiscover function reference/celery.discovery.html
|
|
|
+celery.task.Task.apply_async classmethod reference/celery.task.html
|
|
|
celery.pool.TaskPool.run method reference/celery.pool.html
|
|
|
celery.result.TaskSetResult.ready method reference/celery.result.html
|
|
|
celery.datastructures.ExceptionInfo class reference/celery.datastructures.html
|
|
|
celery.backends.get_default_backend_cls data reference/celery.backends.html
|
|
|
-celery.task.Task.apply_async classmethod reference/celery.task.html
|
|
|
+celery.monitoring.StatsCollector.dump_to_cache method reference/celery.monitoring.html
|
|
|
celery.backends.tyrant.Backend.get_result method reference/celery.backends.tyrant.html
|
|
|
celery.result.TaskSetResult.total attribute reference/celery.result.html
|
|
|
celery.backends.base.find_nearest_pickleable_exception function reference/celery.backends.base.html
|
|
@@ -73,20 +77,21 @@ celery.task.Task.run method reference/celery.task.html
|
|
|
celery.result.BaseAsyncResult class reference/celery.result.html
|
|
|
celery.result.BaseAsyncResult.successful method reference/celery.result.html
|
|
|
celery.conf.LOG_FORMAT data reference/celery.conf.html
|
|
|
+celery.conf.DEFAULT_STATISTICS_COLLECT_INTERVAL data reference/celery.conf.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.ping function reference/celery.task.html
|
|
|
+celery.monitoring.TaskTimerStats class reference/celery.monitoring.html
|
|
|
PeriodicTaskMeta.task attribute reference/celery.models.html
|
|
|
celery.worker.WorkController.process_task method reference/celery.worker.html
|
|
|
celery.result.TaskSetResult.successful method reference/celery.result.html
|
|
|
celery.backends.base.BaseBackend.wait_for method reference/celery.backends.base.html
|
|
|
-celery.pool.TaskPool.add method reference/celery.pool.html
|
|
|
+celery.monitoring.StatsCollector class reference/celery.monitoring.html
|
|
|
celery.backends.base.BaseBackend.mark_as_done method reference/celery.backends.base.html
|
|
|
celery.task.PingTask class reference/celery.task.html
|
|
|
celery.registry.TaskRegistry.get_all_periodic method reference/celery.registry.html
|
|
|
PeriodicTaskMeta.last_run_at attribute reference/celery.models.html
|
|
|
celery.task.Task.get_publisher method reference/celery.task.html
|
|
|
-celery.timer.EventTimer class reference/celery.timer.html
|
|
|
+celery.registry.TaskRegistry.unregister method reference/celery.registry.html
|
|
|
celery.result.TaskSetResult.itersubtasks method reference/celery.result.html
|
|
|
celery.bin.celeryd.acquire_pidlock function reference/celery.bin.celeryd.html
|
|
|
celery.backends.base.BaseBackend.cleanup method reference/celery.backends.base.html
|
|
@@ -99,6 +104,7 @@ celery.messaging.TaskPublisher class reference/celery.messaging.html
|
|
|
celery.conf.AMQP_CONSUMER_ROUTING_KEY data reference/celery.conf.html
|
|
|
celery.backends.base.BaseBackend class reference/celery.backends.base.html
|
|
|
celery.conf.AMQP_EXCHANGE_TYPE data reference/celery.conf.html
|
|
|
+celery.task.TaskSet.run method reference/celery.task.html
|
|
|
celery.worker.WorkController class reference/celery.worker.html
|
|
|
celery.backends.base.BaseBackend.prepare_exception method reference/celery.backends.base.html
|
|
|
celery.task.TaskSet.remote_execute classmethod reference/celery.task.html
|
|
@@ -117,11 +123,13 @@ celery.worker.WorkController.connection_diagnostics method reference/celery.work
|
|
|
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.monitoring.TimerStats.on_finish method reference/celery.monitoring.html
|
|
|
celery.pool.TaskPool.on_ready method reference/celery.pool.html
|
|
|
celery.result.AsyncResult.task_id attribute reference/celery.result.html
|
|
|
celery.timer.EventTimer.interval attribute reference/celery.timer.html
|
|
|
celery.task.TaskSet.map classmethod reference/celery.task.html
|
|
|
celery.timer.TimeoutError exception reference/celery.timer.html
|
|
|
+celery.monitoring.StatsCollector.total_tasks_processed_by_type attribute reference/celery.monitoring.html
|
|
|
celery.task.TaskSet class reference/celery.task.html
|
|
|
TASK_STATUS_RETRY data reference/celery.models.html
|
|
|
TASK_STATUSES data reference/celery.models.html
|
|
@@ -153,17 +161,25 @@ celery.conf.DAEMON_LOG_FILE data reference/celery.conf.html
|
|
|
celery.pool.TaskPool.reap method reference/celery.pool.html
|
|
|
celery.backends.base.BaseBackend.create_exception_cls method reference/celery.backends.base.html
|
|
|
celery.task.PeriodicTask class reference/celery.task.html
|
|
|
-celery.registry.TaskRegistry.unregister method reference/celery.registry.html
|
|
|
+celery.monitoring.Statistics.stop method reference/celery.monitoring.html
|
|
|
+celery.monitoring.StatsCollector.total_task_time_running attribute reference/celery.monitoring.html
|
|
|
+celery.monitoring.TimerStats.time_start 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.task.PingTask.run method reference/celery.task.html
|
|
|
celery.pool.TaskPool.apply_async method reference/celery.pool.html
|
|
|
+celery.task.ping function reference/celery.task.html
|
|
|
celery.result.AsyncResult class reference/celery.result.html
|
|
|
PeriodicTaskMeta.name attribute reference/celery.models.html
|
|
|
+celery.monitoring.StatsCollector.collect method reference/celery.monitoring.html
|
|
|
+celery.monitoring.Statistics class reference/celery.monitoring.html
|
|
|
+celery.monitoring.Statistics.run 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.backends.tyrant.Backend.is_done method reference/celery.backends.tyrant.html
|
|
|
celery.worker.TaskWrapper.extend_with_default_kwargs method reference/celery.worker.html
|
|
|
celery.result.BaseAsyncResult.task_id attribute reference/celery.result.html
|
|
|
+celery.task.Task.type attribute reference/celery.task.html
|
|
|
celery.backends.cache.Backend.is_done method reference/celery.backends.cache.html
|
|
|
celery.task.Task.get_consumer method reference/celery.task.html
|
|
|
celery.pool.TaskPool.logger attribute reference/celery.pool.html
|
|
@@ -187,7 +203,9 @@ celery.backends.get_default_periodicstatus_backend_cls function reference/celery
|
|
|
celery.result.BaseAsyncResult.wait method reference/celery.result.html
|
|
|
celery.result.TaskSetResult.join method reference/celery.result.html
|
|
|
celery.worker.PeriodicWorkController class reference/celery.worker.html
|
|
|
-celery.task.TaskSet.run method reference/celery.task.html
|
|
|
+celery.monitoring.Statistics.start classmethod reference/celery.monitoring.html
|
|
|
+celery.registry.TaskRegistry.get_all method reference/celery.registry.html
|
|
|
+celery.monitoring.Statistics.type attribute reference/celery.monitoring.html
|
|
|
celery.task.ExecuteRemoteTask.run method reference/celery.task.html
|
|
|
celery.bin.celeryd.run_worker function reference/celery.bin.celeryd.html
|
|
|
celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_cls_name attribute reference/celery.backends.base.html
|
|
@@ -197,6 +215,7 @@ celery.result.BaseAsyncResult.result attribute reference/celery.result.html
|
|
|
celery.backends.cache.Backend.store_result method reference/celery.backends.cache.html
|
|
|
celery.result.TaskSetResult.failed method reference/celery.result.html
|
|
|
celery.pool.TaskPool class reference/celery.pool.html
|
|
|
+celery.timer.EventTimer class reference/celery.timer.html
|
|
|
TaskMeta.status attribute reference/celery.models.html
|
|
|
celery.worker.WorkController.concurrency attribute reference/celery.worker.html
|
|
|
celery.backends.database.Backend.is_done method reference/celery.backends.database.html
|
|
@@ -209,6 +228,7 @@ celery.backends.base.BaseBackend.mark_as_retry method reference/celery.backends.
|
|
|
celery.timer.EventTimer.last_triggered attribute reference/celery.timer.html
|
|
|
celery.datastructures.PositionQueue.filled attribute reference/celery.datastructures.html
|
|
|
celery.backends.base.UnpickleableExceptionWrapper.exc_module attribute reference/celery.backends.base.html
|
|
|
+celery.monitoring.Statistics.on_stop method reference/celery.monitoring.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
|
|
@@ -220,6 +240,7 @@ celery.worker.TaskWrapper.on_failure method reference/celery.worker.html
|
|
|
celery.conf.LOG_LEVELS data reference/celery.conf.html
|
|
|
celery.managers.TaskManager.is_done method reference/celery.managers.html
|
|
|
celery.timer.EventTimer.tick method reference/celery.timer.html
|
|
|
+celery.monitoring.Statistics.publish method reference/celery.monitoring.html
|
|
|
celery.messaging.TaskConsumer.decoder method reference/celery.messaging.html
|
|
|
celery.backends.base.BaseBackend.process_cleanup method reference/celery.backends.base.html
|
|
|
celery.task.Task.delay classmethod reference/celery.task.html
|
|
@@ -228,7 +249,7 @@ celery.log.setup_logger function reference/celery.log.html
|
|
|
celery.registry.NotRegistered exception reference/celery.registry.html
|
|
|
celery.conf.DAEMON_CONCURRENCY data reference/celery.conf.html
|
|
|
celery.worker.WorkController.logger attribute reference/celery.worker.html
|
|
|
-celery.registry.TaskRegistry.get_all method reference/celery.registry.html
|
|
|
+celery.monitoring.StatsCollector.report method reference/celery.monitoring.html
|
|
|
celery.worker.TaskWrapper.message attribute reference/celery.worker.html
|
|
|
celery.backends.tyrant.Backend.store_result method reference/celery.backends.tyrant.html
|
|
|
celery.pool.TaskPool.terminate method reference/celery.pool.html
|
|
@@ -238,10 +259,12 @@ celery.registry.TaskRegistry.get_task method reference/celery.registry.html
|
|
|
celery.result.BaseAsyncResult.get method reference/celery.result.html
|
|
|
celery.worker.TaskWrapper.kwargs attribute reference/celery.worker.html
|
|
|
celery.conf.DAEMON_PID_FILE data reference/celery.conf.html
|
|
|
+celery.monitoring.StatsCollector.total_tasks_processed attribute reference/celery.monitoring.html
|
|
|
+celery.monitoring.StatsCollector.task_time_running method reference/celery.monitoring.html
|
|
|
celery.task.Task class reference/celery.task.html
|
|
|
celery.backends.base.BaseBackend.get_status method reference/celery.backends.base.html
|
|
|
celery.registry.TaskRegistry.autodiscover method reference/celery.registry.html
|
|
|
-celery.task.Task.type attribute reference/celery.task.html
|
|
|
+celery.monitoring.TimerStats.on_start method reference/celery.monitoring.html
|
|
|
celery.task.TaskSet.iterate method reference/celery.task.html
|
|
|
celery.pool.TaskPool.get_worker_pids method reference/celery.pool.html
|
|
|
PeriodicTaskMeta.total_run_count attribute reference/celery.models.html
|
|
@@ -249,9 +272,9 @@ celery.datastructures.PositionQueue.UnfilledPosition class reference/celery.data
|
|
|
celery.result.TaskSetResult.completed_count method reference/celery.result.html
|
|
|
celery.pool.TaskPool.on_return method reference/celery.pool.html
|
|
|
celery.messaging.TaskConsumer class reference/celery.messaging.html
|
|
|
-celery.conf.DEFAULT_AMQP_CONNECTION_TIMEOUT data reference/celery.conf.html
|
|
|
celery.managers.TaskManager.store_result method reference/celery.managers.html
|
|
|
celery.result.TaskSetResult.taskset_id attribute reference/celery.result.html
|
|
|
+celery.monitoring.TimerStats class reference/celery.monitoring.html
|
|
|
TaskMeta.result attribute reference/celery.models.html
|
|
|
celery.timer.TimeoutTimer.time_start attribute reference/celery.timer.html
|
|
|
celery.task.TaskSet.arguments attribute reference/celery.task.html
|