objects.inv 23 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312
  1. # Sphinx inventory version 1
  2. # Project: Celery
  3. # Version: 0.3
  4. celery.backends.base mod reference/celery.backends.base.html
  5. celery.execute mod reference/celery.execute.html
  6. celery.bin.celeryd mod reference/celery.bin.celeryd.html
  7. celery.discovery mod reference/celery.discovery.html
  8. celery.task.builtins mod reference/celery.task.builtins.html
  9. celery.monitoring mod reference/celery.monitoring.html
  10. celery.pool mod reference/celery.pool.html
  11. celery.managers mod reference/celery.managers.html
  12. celery.log mod reference/celery.log.html
  13. celery.backends.database mod reference/celery.backends.database.html
  14. celery.utils mod reference/celery.utils.html
  15. celery.supervisor mod reference/celery.supervisor.html
  16. celery.backends mod reference/celery.backends.html
  17. celery.worker mod reference/celery.worker.html
  18. celery.worker.controllers mod reference/celery.worker.controllers.html
  19. celery.backends.cache mod reference/celery.backends.cache.html
  20. celery.datastructures mod reference/celery.datastructures.html
  21. celery.messaging mod reference/celery.messaging.html
  22. celery.task.base mod reference/celery.task.base.html
  23. celery.task mod reference/celery.task.html
  24. celery.worker.job mod reference/celery.worker.job.html
  25. celery.conf mod reference/celery.conf.html
  26. celery.registry mod reference/celery.registry.html
  27. celery.result mod reference/celery.result.html
  28. celery.fields mod reference/celery.fields.html
  29. celery.log.emergency_error function reference/celery.log.html
  30. celery.backends.base.BaseBackend.get_result method reference/celery.backends.base.html
  31. celery.task.dmap function reference/celery.task.html
  32. celery.monitoring.Statistics.on_start method reference/celery.monitoring.html
  33. celery.task.base.Task.ignore_result attribute reference/celery.task.base.html
  34. celery.worker.controllers.InfinityThread class reference/celery.worker.controllers.html
  35. celery.result.BaseAsyncResult.is_done method reference/celery.result.html
  36. celery.task.base.Task.routing_key attribute reference/celery.task.base.html
  37. celery.backends.database.Backend.run_periodic_tasks method reference/celery.backends.database.html
  38. celery.result.TaskSetResult.subtasks attribute reference/celery.result.html
  39. celery.backends.base.BaseBackend.mark_as_done method reference/celery.backends.base.html
  40. celery.result.TaskSetResult.iterate method reference/celery.result.html
  41. celery.registry.AlreadyRegistered exception reference/celery.registry.html
  42. celery.backends.base.UnpickleableExceptionWrapper exception reference/celery.backends.base.html
  43. TASK_STATUS_FAILURE data reference/celery.models.html
  44. celery.pool.TaskPool.full method reference/celery.pool.html
  45. celery.fields.PickledObjectField.to_python method reference/celery.fields.html
  46. celery.result.BaseAsyncResult.backend attribute reference/celery.result.html
  47. celery.fields.PickledObjectField.get_internal_type method reference/celery.fields.html
  48. celery.worker.controllers.InfinityThread.run method reference/celery.worker.controllers.html
  49. celery.worker.WorkController.start method reference/celery.worker.html
  50. celery.worker.job.TaskWrapper.execute_using_pool method reference/celery.worker.job.html
  51. celery.messaging.TaskPublisher.encoder method reference/celery.messaging.html
  52. celery.task.base.TaskSet.join method reference/celery.task.base.html
  53. celery.datastructures.PositionQueue.full method reference/celery.datastructures.html
  54. celery.discovery.find_related_module function reference/celery.discovery.html
  55. celery.worker.WorkController.logfile attribute reference/celery.worker.html
  56. celery.result.BaseAsyncResult.ready method reference/celery.result.html
  57. celery.registry.TaskRegistry.AlreadyRegistered exception reference/celery.registry.html
  58. celery.managers.TaskManager.delete_expired method reference/celery.managers.html
  59. celery.registry.TaskRegistry.filter_types method reference/celery.registry.html
  60. celery.backends.base.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
  61. celery.worker.controllers.Mediator class reference/celery.worker.controllers.html
  62. celery.conf.AMQP_CONSUMER_QUEUE data reference/celery.conf.html
  63. celery.worker.WorkController.pool attribute reference/celery.worker.html
  64. celery.worker.job.TaskWrapper.extend_with_default_kwargs method reference/celery.worker.job.html
  65. celery.datastructures.ExceptionInfo.traceback attribute reference/celery.datastructures.html
  66. celery.managers.TaskManager.get_all_expired method reference/celery.managers.html
  67. TaskMeta.task_id attribute reference/celery.models.html
  68. celery.supervisor.OFASupervisor.check_interval attribute reference/celery.supervisor.html
  69. celery.discovery.autodiscover function reference/celery.discovery.html
  70. celery.result.TaskSetResult.ready method reference/celery.result.html
  71. celery.task.base.Task.get_publisher method reference/celery.task.base.html
  72. celery.datastructures.ExceptionInfo class reference/celery.datastructures.html
  73. celery.task.base.TaskSet.map_async classmethod reference/celery.task.base.html
  74. celery.supervisor.OFASupervisor.args attribute reference/celery.supervisor.html
  75. celery.backends.get_default_backend_cls data reference/celery.backends.html
  76. celery.fields.PickledObjectField.get_db_prep_save method reference/celery.fields.html
  77. celery.monitoring.StatsCollector.dump_to_cache method reference/celery.monitoring.html
  78. celery.worker.controllers.PeriodicWorkController.process_hold_queue method reference/celery.worker.controllers.html
  79. celery.result.TaskSetResult.total attribute reference/celery.result.html
  80. celery.backends.base.find_nearest_pickleable_exception function reference/celery.backends.base.html
  81. celery.task.ping function reference/celery.task.html
  82. celery.managers.PeriodicTaskManager class reference/celery.managers.html
  83. celery.task.builtins.ExecuteRemoteTask.run method reference/celery.task.builtins.html
  84. celery.task.base.Task.run method reference/celery.task.base.html
  85. TaskMeta class reference/celery.models.html
  86. celery.supervisor.OFASupervisor.target attribute reference/celery.supervisor.html
  87. celery.backends.base.BaseBackend.exception_to_python method reference/celery.backends.base.html
  88. celery.fields.PickledObject class reference/celery.fields.html
  89. celery.task.base.Task.get_logger method reference/celery.task.base.html
  90. celery.result.BaseAsyncResult class reference/celery.result.html
  91. celery.result.BaseAsyncResult.successful method reference/celery.result.html
  92. celery.conf.LOG_FORMAT data reference/celery.conf.html
  93. celery.result.BaseAsyncResult.TimeoutError exception reference/celery.result.html
  94. celery.conf.DEFAULT_STATISTICS_COLLECT_INTERVAL data reference/celery.conf.html
  95. celery.backends.database.Backend.store_result method reference/celery.backends.database.html
  96. celery.worker.AMQPListener.bucket_queue attribute reference/celery.worker.html
  97. celery.monitoring.TaskTimerStats class reference/celery.monitoring.html
  98. celery.worker.job.TaskWrapper.message attribute reference/celery.worker.job.html
  99. PeriodicTaskMeta.task attribute reference/celery.models.html
  100. celery.worker.WorkController.process_task method reference/celery.worker.html
  101. celery.result.TaskSetResult.successful method reference/celery.result.html
  102. celery.backends.base.BaseBackend.wait_for method reference/celery.backends.base.html
  103. celery.monitoring.StatsCollector class reference/celery.monitoring.html
  104. celery.result.AsyncResult class reference/celery.result.html
  105. celery.registry.TaskRegistry.get_all_periodic method reference/celery.registry.html
  106. PeriodicTaskMeta.last_run_at attribute reference/celery.models.html
  107. celery.worker.job.TaskWrapper.execute method reference/celery.worker.job.html
  108. celery.worker.job.TaskWrapper.on_success method reference/celery.worker.job.html
  109. celery.registry.TaskRegistry.unregister method reference/celery.registry.html
  110. celery.result.TaskSetResult.itersubtasks method reference/celery.result.html
  111. celery.registry.NotRegistered exception reference/celery.registry.html
  112. celery.bin.celeryd.acquire_pidlock function reference/celery.bin.celeryd.html
  113. celery.backends.base.BaseBackend.cleanup method reference/celery.backends.base.html
  114. celery.task.base.TaskSet.remote_execute classmethod reference/celery.task.base.html
  115. celery.bin.celeryd.parse_options function reference/celery.bin.celeryd.html
  116. celery.task.discard_all function reference/celery.task.html
  117. celery.backends.database.Backend.get_status method reference/celery.backends.database.html
  118. PeriodicTaskMeta class reference/celery.models.html
  119. celery.messaging.TaskPublisher.requeue_task method reference/celery.messaging.html
  120. celery.messaging.TaskPublisher class reference/celery.messaging.html
  121. celery.conf.AMQP_CONSUMER_ROUTING_KEY data reference/celery.conf.html
  122. celery.backends.base.BaseBackend class reference/celery.backends.base.html
  123. celery.conf.AMQP_EXCHANGE_TYPE data reference/celery.conf.html
  124. celery.supervisor.OFASupervisor.start method reference/celery.supervisor.html
  125. celery.task.base.TaskSet.total attribute reference/celery.task.base.html
  126. celery.worker.WorkController class reference/celery.worker.html
  127. celery.backends.base.BaseBackend.prepare_exception method reference/celery.backends.base.html
  128. celery.backends.base.TimeoutError exception reference/celery.backends.base.html
  129. celery.worker.WorkController.periodic_work_controller attribute reference/celery.worker.html
  130. celery.registry.TaskRegistry.get_all method reference/celery.registry.html
  131. celery.registry.TaskRegistry.NotRegistered exception reference/celery.registry.html
  132. celery.datastructures.PositionQueue.length attribute reference/celery.datastructures.html
  133. celery.datastructures.PositionQueue class reference/celery.datastructures.html
  134. celery.messaging.TaskPublisher.delay_task method reference/celery.messaging.html
  135. celery.backends.base.BaseBackend.prepare_result method reference/celery.backends.base.html
  136. celery.pool.TaskPool.limit attribute reference/celery.pool.html
  137. celery.result.TaskSetResult class reference/celery.result.html
  138. celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_module attribute reference/celery.backends.base.html
  139. celery.task.dmap_async function reference/celery.task.html
  140. celery.supervisor.OFASupervisor class reference/celery.supervisor.html
  141. celery.worker.job.TaskWrapper.on_failure method reference/celery.worker.job.html
  142. celery.managers.TaskManager class reference/celery.managers.html
  143. celery.worker.controllers.InfinityThread.stop method reference/celery.worker.controllers.html
  144. celery.backends.base.BaseBackend.store_result method reference/celery.backends.base.html
  145. celery.worker.AMQPListener.logger attribute reference/celery.worker.html
  146. celery.worker.job.TaskWrapper.task_id attribute reference/celery.worker.job.html
  147. celery.task.base.TaskSet.run method reference/celery.task.base.html
  148. celery.monitoring.TimerStats.on_finish method reference/celery.monitoring.html
  149. celery.worker.WorkController.stop method reference/celery.worker.html
  150. celery.pool.TaskPool.on_ready method reference/celery.pool.html
  151. celery.result.AsyncResult.task_id attribute reference/celery.result.html
  152. celery.task.base.Task.disable_error_emails attribute reference/celery.task.base.html
  153. celery.monitoring.StatsCollector.total_tasks_processed_by_type attribute reference/celery.monitoring.html
  154. celery.supervisor.OFASupervisor.max_restart_freq attribute reference/celery.supervisor.html
  155. TASK_STATUS_RETRY data reference/celery.models.html
  156. celery.task.base.PeriodicTask class reference/celery.task.base.html
  157. TASK_STATUSES data reference/celery.models.html
  158. celery.backends.base.BaseBackend.mark_as_failure method reference/celery.backends.base.html
  159. celery.conf.AMQP_EXCHANGE data reference/celery.conf.html
  160. celery.datastructures.ExceptionInfo.exception attribute reference/celery.datastructures.html
  161. celery.task.builtins.AsynchronousMapTask.run method reference/celery.task.builtins.html
  162. PeriodicTaskMeta.delay method reference/celery.models.html
  163. celery.worker.AMQPListener.stop method reference/celery.worker.html
  164. celery.backends.database.Backend.cleanup method reference/celery.backends.database.html
  165. celery.task.base.Task.get_consumer method reference/celery.task.base.html
  166. celery.worker.WorkController.mediator attribute reference/celery.worker.html
  167. celery.result.TaskSetResult.waiting method reference/celery.result.html
  168. celery.conf.DAEMON_LOG_LEVEL data reference/celery.conf.html
  169. celery.backends.database.Backend class reference/celery.backends.database.html
  170. celery.worker.AMQPListener class reference/celery.worker.html
  171. celery.task.builtins.PingTask.run method reference/celery.task.builtins.html
  172. celery.result.BaseAsyncResult.status attribute reference/celery.result.html
  173. celery.conf.AMQP_CONNECTION_TIMEOUT data reference/celery.conf.html
  174. celery.task.builtins.AsynchronousMapTask class reference/celery.task.builtins.html
  175. celery.task.builtins.PingTask class reference/celery.task.builtins.html
  176. celery.backends.database.Backend.get_result method reference/celery.backends.database.html
  177. celery.supervisor.OFASupervisor.max_restart_freq_time attribute reference/celery.supervisor.html
  178. celery.backends.get_backend_cls function reference/celery.backends.html
  179. celery.registry.TaskRegistry.register method reference/celery.registry.html
  180. celery.task.base.TaskSet.iterate method reference/celery.task.base.html
  181. celery.backends.cache.Backend.get_result method reference/celery.backends.cache.html
  182. celery.conf.DAEMON_LOG_FILE data reference/celery.conf.html
  183. celery.pool.TaskPool.reap method reference/celery.pool.html
  184. celery.backends.base.BaseBackend.create_exception_cls method reference/celery.backends.base.html
  185. celery.worker.WorkController.amqp_listener attribute reference/celery.worker.html
  186. celery.monitoring.Statistics.stop method reference/celery.monitoring.html
  187. celery.worker.job.TaskWrapper.task_name attribute reference/celery.worker.job.html
  188. celery.worker.controllers.InfinityThread.on_iteration method reference/celery.worker.controllers.html
  189. celery.monitoring.StatsCollector.total_task_time_running attribute reference/celery.monitoring.html
  190. celery.monitoring.TimerStats.time_start attribute reference/celery.monitoring.html
  191. celery.task.base.Task.name attribute reference/celery.task.base.html
  192. celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
  193. TaskMeta.date_done attribute reference/celery.models.html
  194. celery.supervisor.OFASupervisor.join_timeout attribute reference/celery.supervisor.html
  195. celery.pool.TaskPool.stop method reference/celery.pool.html
  196. celery.task.base.TaskSet.arguments attribute reference/celery.task.base.html
  197. celery.task.base.Task.delay classmethod reference/celery.task.base.html
  198. celery.pool.TaskPool.apply_async method reference/celery.pool.html
  199. PeriodicTaskMeta.name attribute reference/celery.models.html
  200. celery.conf.STATISTICS_COLLECT_INTERVAL data reference/celery.conf.html
  201. celery.monitoring.StatsCollector.collect method reference/celery.monitoring.html
  202. celery.monitoring.Statistics class reference/celery.monitoring.html
  203. celery.monitoring.Statistics.run method reference/celery.monitoring.html
  204. celery.monitoring.StatsCollector.total_task_time_running_by_type attribute reference/celery.monitoring.html
  205. celery.backends.base.BaseBackend.is_done method reference/celery.backends.base.html
  206. celery.registry.TaskRegistry.get_task method reference/celery.registry.html
  207. celery.result.BaseAsyncResult.task_id attribute reference/celery.result.html
  208. celery.fields.PickledObjectField class reference/celery.fields.html
  209. celery.task.base.TaskSet.map classmethod reference/celery.task.base.html
  210. celery.backends.cache.Backend.is_done method reference/celery.backends.cache.html
  211. celery.backends.base.BaseBackend.TimeoutError exception reference/celery.backends.base.html
  212. celery.pool.TaskPool.logger attribute reference/celery.pool.html
  213. celery.messaging.TaskPublisher.delay_task_in_set method reference/celery.messaging.html
  214. celery.backends.base.BaseBackend.UnpickleableExceptionWrapper exception reference/celery.backends.base.html
  215. celery.worker.job.TaskWrapper.args attribute reference/celery.worker.job.html
  216. celery.worker.job.TaskWrapper.kwargs attribute reference/celery.worker.job.html
  217. celery.worker.AMQPListener.close_connection method reference/celery.worker.html
  218. celery.worker.AMQPListener.receive_message method reference/celery.worker.html
  219. celery.managers.PeriodicTaskManager.get_waiting_tasks method reference/celery.managers.html
  220. celery.managers.TaskManager.get_task method reference/celery.managers.html
  221. celery.worker.WorkController.loglevel attribute reference/celery.worker.html
  222. celery.task.base.Task.type attribute reference/celery.task.base.html
  223. celery.worker.WorkController.is_detached attribute reference/celery.worker.html
  224. celery.registry.TaskRegistry.get_all_regular method reference/celery.registry.html
  225. celery.registry.TaskRegistry class reference/celery.registry.html
  226. celery.backends.DefaultBackend class reference/celery.backends.html
  227. celery.worker.AMQPListener.reset_connection method reference/celery.worker.html
  228. celery.backends.get_default_periodicstatus_backend_cls function reference/celery.backends.html
  229. celery.result.BaseAsyncResult.wait method reference/celery.result.html
  230. celery.result.TaskSetResult.join method reference/celery.result.html
  231. celery.task.builtins.DeleteExpiredTaskMetaTask class reference/celery.task.builtins.html
  232. celery.worker.job.jail function reference/celery.worker.job.html
  233. celery.monitoring.Statistics.start classmethod reference/celery.monitoring.html
  234. celery.worker.WorkController.bucket_queue attribute reference/celery.worker.html
  235. celery.execute.apply_async function reference/celery.execute.html
  236. celery.worker.controllers.Mediator.bucket_queue attribute reference/celery.worker.controllers.html
  237. celery.monitoring.Statistics.type attribute reference/celery.monitoring.html
  238. celery.task.base.Task class reference/celery.task.base.html
  239. celery.bin.celeryd.run_worker function reference/celery.bin.celeryd.html
  240. celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_cls_name attribute reference/celery.backends.base.html
  241. celery.result.AsyncResult.backend attribute reference/celery.result.html
  242. celery.task.base.TaskSet class reference/celery.task.base.html
  243. celery.result.BaseAsyncResult.result attribute reference/celery.result.html
  244. celery.backends.cache.Backend.store_result method reference/celery.backends.cache.html
  245. celery.result.TaskSetResult.failed method reference/celery.result.html
  246. celery.task.builtins.DeleteExpiredTaskMetaTask.run method reference/celery.task.builtins.html
  247. celery.pool.TaskPool class reference/celery.pool.html
  248. celery.worker.job.TaskWrapper class reference/celery.worker.job.html
  249. TaskMeta.status attribute reference/celery.models.html
  250. celery.worker.WorkController.concurrency attribute reference/celery.worker.html
  251. celery.backends.database.Backend.is_done method reference/celery.backends.database.html
  252. celery.result.TimeoutError exception reference/celery.result.html
  253. celery.worker.AMQPListener.start method reference/celery.worker.html
  254. TASK_STATUSES_CHOICES data reference/celery.models.html
  255. celery.utils.chunks function reference/celery.utils.html
  256. celery.backends.base.BaseBackend.mark_as_retry method reference/celery.backends.base.html
  257. celery.supervisor.raise_ping_timeout function reference/celery.supervisor.html
  258. celery.task.base.Task.mandatory attribute reference/celery.task.base.html
  259. celery.datastructures.PositionQueue.filled attribute reference/celery.datastructures.html
  260. celery.task.builtins.ExecuteRemoteTask class reference/celery.task.builtins.html
  261. celery.backends.base.UnpickleableExceptionWrapper.exc_module attribute reference/celery.backends.base.html
  262. celery.monitoring.Statistics.on_stop method reference/celery.monitoring.html
  263. TASK_STATUS_DONE data reference/celery.models.html
  264. celery.backends.base.UnpickleableExceptionWrapper.exc_cls_name attribute reference/celery.backends.base.html
  265. celery.conf.AMQP_PUBLISHER_ROUTING_KEY data reference/celery.conf.html
  266. celery.pool.TaskPool.wait_for_result method reference/celery.pool.html
  267. celery.backends.cache.Backend class reference/celery.backends.cache.html
  268. celery.task.is_done function reference/celery.task.html
  269. celery.worker.controllers.PeriodicWorkController class reference/celery.worker.controllers.html
  270. celery.conf.LOG_LEVELS data reference/celery.conf.html
  271. celery.managers.TaskManager.is_done method reference/celery.managers.html
  272. celery.task.base.PeriodicTask.run_every attribute reference/celery.task.base.html
  273. celery.supervisor.OFASupervisor.kwargs attribute reference/celery.supervisor.html
  274. celery.worker.controllers.Mediator.callback attribute reference/celery.worker.controllers.html
  275. celery.monitoring.Statistics.publish method reference/celery.monitoring.html
  276. celery.messaging.TaskConsumer.decoder method reference/celery.messaging.html
  277. celery.execute.delay_task function reference/celery.execute.html
  278. celery.task.execute_remote function reference/celery.task.html
  279. celery.backends.base.BaseBackend.process_cleanup method reference/celery.backends.base.html
  280. celery.task.base.Task.apply_async classmethod reference/celery.task.base.html
  281. celery.backends.cache.Backend.get_status method reference/celery.backends.cache.html
  282. celery.log.setup_logger function reference/celery.log.html
  283. celery.worker.job.TaskWrapper.task_func attribute reference/celery.worker.job.html
  284. celery.fields.PickledObjectField.get_db_prep_lookup method reference/celery.fields.html
  285. celery.conf.DAEMON_CONCURRENCY data reference/celery.conf.html
  286. celery.pool.TaskPool.start method reference/celery.pool.html
  287. celery.worker.WorkController.logger attribute reference/celery.worker.html
  288. celery.monitoring.StatsCollector.report method reference/celery.monitoring.html
  289. TASK_STATUS_PENDING data reference/celery.models.html
  290. celery.worker.WorkController.hold_queue attribute reference/celery.worker.html
  291. celery.result.BaseAsyncResult.get method reference/celery.result.html
  292. celery.worker.AMQPListener.hold_queue attribute reference/celery.worker.html
  293. celery.conf.DAEMON_PID_FILE data reference/celery.conf.html
  294. celery.monitoring.StatsCollector.total_tasks_processed attribute reference/celery.monitoring.html
  295. celery.monitoring.StatsCollector.task_time_running method reference/celery.monitoring.html
  296. celery.backends.base.BaseBackend.get_status method reference/celery.backends.base.html
  297. celery.registry.TaskRegistry.autodiscover method reference/celery.registry.html
  298. celery.monitoring.TimerStats.on_start method reference/celery.monitoring.html
  299. celery.task.base.TaskSet.task_name attribute reference/celery.task.base.html
  300. celery.pool.TaskPool.get_worker_pids method reference/celery.pool.html
  301. PeriodicTaskMeta.total_run_count attribute reference/celery.models.html
  302. celery.datastructures.PositionQueue.UnfilledPosition class reference/celery.datastructures.html
  303. celery.result.TaskSetResult.completed_count method reference/celery.result.html
  304. celery.pool.TaskPool.on_return method reference/celery.pool.html
  305. celery.messaging.TaskConsumer class reference/celery.messaging.html
  306. celery.worker.WorkController.safe_process_task method reference/celery.worker.html
  307. celery.managers.TaskManager.store_result method reference/celery.managers.html
  308. celery.result.TaskSetResult.taskset_id attribute reference/celery.result.html
  309. celery.monitoring.TimerStats class reference/celery.monitoring.html
  310. TaskMeta.result attribute reference/celery.models.html
  311. celery.worker.job.TaskWrapper.from_message classmethod reference/celery.worker.job.html
  312. celery.conf.SEND_CELERY_TASK_ERROR_EMAILS data reference/celery.conf.html