123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252 |
- # Sphinx inventory version 1
- # Project: Celery
- # 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.backends.cache mod reference/celery.backends.cache.html
- celery.datastructures mod reference/celery.datastructures.html
- celery.backends.base mod reference/celery.backends.base.html
- celery.result mod reference/celery.result.html
- celery.managers mod reference/celery.managers.html
- celery.messaging mod reference/celery.messaging.html
- celery.conf mod reference/celery.conf.html
- celery.registry mod reference/celery.registry.html
- celery.log mod reference/celery.log.html
- celery.platform mod reference/celery.platform.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
- 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.backends.base.BaseBackend.get_result method reference/celery.backends.base.html
- celery.task.dmap 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.database.Backend.run_periodic_tasks method reference/celery.backends.database.html
- celery.result.TaskSetResult.subtasks attribute reference/celery.result.html
- celery.backends.tyrant.Backend.tyrant_port attribute reference/celery.backends.tyrant.html
- celery.worker.WorkController.task_consumer attribute reference/celery.worker.html
- celery.task.delay_task function reference/celery.task.html
- celery.result.TaskSetResult.iterate method reference/celery.result.html
- celery.registry.AlreadyRegistered exception reference/celery.registry.html
- celery.backends.base.UnpickleableExceptionWrapper exception reference/celery.backends.base.html
- TASK_STATUS_FAILURE data reference/celery.models.html
- celery.task.execute_remote function reference/celery.task.html
- celery.bin.celeryd.main function reference/celery.bin.celeryd.html
- celery.result.BaseAsyncResult.backend attribute reference/celery.result.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.discovery.find_related_module function reference/celery.discovery.html
- celery.worker.WorkController.logfile attribute reference/celery.worker.html
- celery.result.BaseAsyncResult.ready method reference/celery.result.html
- celery.worker.EmptyQueue exception 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.backends.base.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
- celery.backends.tyrant.Backend class reference/celery.backends.tyrant.html
- celery.worker.WorkController.pool attribute reference/celery.worker.html
- celery.task.DeleteExpiredTaskMetaTask class reference/celery.task.html
- celery.datastructures.ExceptionInfo.traceback attribute reference/celery.datastructures.html
- 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.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.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
- 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.backends.base.BaseBackend.exception_to_python method reference/celery.backends.base.html
- celery.platform.PIDFile.get_pid method reference/celery.platform.html
- celery.task.Task.run method reference/celery.task.html
- celery.result.BaseAsyncResult class reference/celery.result.html
- celery.platform.PIDFile.check method reference/celery.platform.html
- celery.conf.LOG_FORMAT 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.platform.PIDFile.remove method reference/celery.platform.html
- celery.worker.WorkController.schedule_retry_tasks method reference/celery.worker.html
- PeriodicTaskMeta.task attribute reference/celery.models.html
- celery.conf.EMPTY_MSG_EMIT_EVERY data reference/celery.conf.html
- celery.result.TaskSetResult.successful method reference/celery.result.html
- celery.backends.base.BaseBackend.wait_for method reference/celery.backends.base.html
- celery.task.Task.name attribute reference/celery.task.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
- PeriodicTaskMeta.last_run_at attribute reference/celery.models.html
- celery.task.Task.get_publisher method reference/celery.task.html
- celery.result.TaskSetResult.itersubtasks method reference/celery.result.html
- celery.backends.base.BaseBackend.cleanup method reference/celery.backends.base.html
- celery.bin.celeryd.parse_options function reference/celery.bin.celeryd.html
- celery.task.discard_all function reference/celery.task.html
- celery.backends.database.Backend.get_status method reference/celery.backends.database.html
- PeriodicTaskMeta class reference/celery.models.html
- celery.messaging.TaskPublisher.requeue_task method reference/celery.messaging.html
- 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.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
- celery.backends.tyrant.Backend.get_status method reference/celery.backends.tyrant.html
- celery.registry.TaskRegistry.NotRegistered exception reference/celery.registry.html
- celery.datastructures.PositionQueue.length attribute reference/celery.datastructures.html
- celery.worker.WorkController.process_task method reference/celery.worker.html
- celery.datastructures.PositionQueue class reference/celery.datastructures.html
- celery.messaging.TaskPublisher.delay_task method reference/celery.messaging.html
- celery.backends.base.BaseBackend.prepare_result method reference/celery.backends.base.html
- celery.result.TaskSetResult class reference/celery.result.html
- celery.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_module attribute reference/celery.backends.base.html
- celery.task.ExecuteRemoteTask class reference/celery.task.html
- celery.task.dmap_async function reference/celery.task.html
- celery.worker.WorkController.connection_diagnostics 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.TaskSetResult.waiting method reference/celery.result.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.timer.TimeoutError exception reference/celery.timer.html
- celery.backends.tyrant.Backend.get_server method reference/celery.backends.tyrant.html
- celery.task.TaskSet class reference/celery.task.html
- TASK_STATUS_RETRY data reference/celery.models.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.datastructures.ExceptionInfo.exception attribute reference/celery.datastructures.html
- celery.result.TaskSetResult.subtask_ids attribute reference/celery.result.html
- PeriodicTaskMeta.delay method reference/celery.models.html
- celery.timer.TimeoutTimer.timeout attribute reference/celery.timer.html
- celery.backends.database.Backend.cleanup method reference/celery.backends.database.html
- celery.task.TaskSet.total attribute reference/celery.task.html
- celery.conf.DAEMON_LOG_LEVEL data reference/celery.conf.html
- celery.backends.database.Backend class reference/celery.backends.database.html
- celery.result.BaseAsyncResult.status attribute reference/celery.result.html
- celery.worker.TaskWrapper.kwargs attribute reference/celery.worker.html
- celery.conf.QUEUE_WAKEUP_AFTER data reference/celery.conf.html
- celery.backends.database.Backend.get_result method reference/celery.backends.database.html
- celery.worker.TaskWrapper.on_success method reference/celery.worker.html
- celery.backends.get_backend_cls function reference/celery.backends.html
- celery.registry.TaskRegistry.register method reference/celery.registry.html
- celery.worker.TaskWrapper.args attribute reference/celery.worker.html
- celery.worker.TaskWrapper.task_func attribute reference/celery.worker.html
- celery.task.TaskSet.map classmethod reference/celery.task.html
- celery.backends.cache.Backend.get_result method reference/celery.backends.cache.html
- celery.task.Task.get_logger method reference/celery.task.html
- celery.conf.DAEMON_LOG_FILE data reference/celery.conf.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.backends.base.BaseBackend.UnpickleableExceptionWrapper.exc_args attribute reference/celery.backends.base.html
- TaskMeta.date_done attribute reference/celery.models.html
- celery.result.AsyncResult class reference/celery.result.html
- PeriodicTaskMeta.name attribute reference/celery.models.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.backends.tyrant.Backend.is_done method reference/celery.backends.tyrant.html
- celery.worker.TaskWrapper.extend_with_default_kwargs 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.backends.cache.Backend.is_done method reference/celery.backends.cache.html
- celery.task.Task.get_consumer method reference/celery.task.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.task.AsynchronousMapTask.run method reference/celery.task.html
- celery.worker.PeriodicWorkController.run method reference/celery.worker.html
- celery.platform.PIDFile.write method reference/celery.platform.html
- celery.platform.remove_pidfile function reference/celery.platform.html
- celery.platform.PIDFile class reference/celery.platform.html
- celery.worker.TaskWrapper.task_id attribute reference/celery.worker.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.worker.WorkController.loglevel attribute reference/celery.worker.html
- celery.task.TaskSet.join method reference/celery.task.html
- celery.worker.WorkController.queue_wakeup_after attribute reference/celery.worker.html
- celery.registry.TaskRegistry.get_all_regular method reference/celery.registry.html
- celery.worker.WorkController.run method reference/celery.worker.html
- celery.registry.TaskRegistry class reference/celery.registry.html
- celery.backends.DefaultBackend class reference/celery.backends.html
- celery.task.DeleteExpiredTaskMetaTask.run method reference/celery.task.html
- celery.worker.UnknownTask exception reference/celery.worker.html
- celery.timer.TimeoutTimer class reference/celery.timer.html
- celery.backends.get_default_periodicstatus_backend_cls function reference/celery.backends.html
- 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.worker.WorkController.reset_connection method reference/celery.worker.html
- celery.task.TaskSet.run method reference/celery.task.html
- celery.task.ExecuteRemoteTask.run method reference/celery.task.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.task.apply_async function reference/celery.task.html
- 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
- 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
- celery.backends.tyrant.Backend.tyrant_host attribute reference/celery.backends.tyrant.html
- celery.worker.WorkController.receive_message method reference/celery.worker.html
- celery.conf.AMQP_CONSUMER_QUEUE data reference/celery.conf.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
- celery.datastructures.PositionQueue.filled attribute reference/celery.datastructures.html
- celery.backends.base.UnpickleableExceptionWrapper.exc_module attribute reference/celery.backends.base.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.task.is_done function reference/celery.task.html
- celery.task.PeriodicTask.run_every attribute reference/celery.task.html
- 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.messaging.TaskConsumer.decoder method reference/celery.messaging.html
- celery.task.Task.delay classmethod reference/celery.task.html
- celery.backends.cache.Backend.get_status method reference/celery.backends.cache.html
- 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.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.registry.TaskRegistry.get_task method reference/celery.registry.html
- celery.result.BaseAsyncResult.get method reference/celery.result.html
- celery.conf.DAEMON_PID_FILE data reference/celery.conf.html
- celery.worker.WorkController.empty_msg_emit_every attribute reference/celery.worker.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.task.TaskSet.iterate method reference/celery.task.html
- PeriodicTaskMeta.total_run_count attribute reference/celery.models.html
- celery.datastructures.PositionQueue.UnfilledPosition class reference/celery.datastructures.html
- celery.result.TaskSetResult.completed_count method reference/celery.result.html
- celery.timer.EventTimer class reference/celery.timer.html
- 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
- celery.result.TaskSetResult.taskset_id attribute reference/celery.result.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
- celery.worker.TaskWrapper.task_name attribute reference/celery.worker.html
- celery.conf.SEND_CELERY_TASK_ERROR_EMAILS data reference/celery.conf.html
|