瀏覽代碼

Protocol docs: Missing 'id' in example task message

Ask Solem 14 年之前
父節點
當前提交
53651c9063
共有 4 個文件被更改,包括 2 次插入242 次删除
  1. 0 57
      docs/internals/events.rst
  2. 0 2
      docs/internals/index.rst
  3. 0 182
      docs/internals/moduleindex.rst
  4. 2 1
      docs/internals/protocol.rst

+ 0 - 57
docs/internals/events.rst

@@ -1,57 +0,0 @@
-=======================
- List of Worker Events
-=======================
-
-This is the list of events sent by the worker.
-The monitor uses these to visualize the state of the cluster.
-
-.. contents::
-    :local:
-
-
-Task Events
-===========
-
-* task-received(uuid, name, args, kwargs, retries, eta, hostname, timestamp)
-
-    Sent when the worker receives a task.
-
-* task-started(uuid, hostname, timestamp)
-
-    Sent just before the worker executes the task.
-
-* task-succeeded(uuid, result, runtime, hostname, timestamp)
-
-    Sent if the task executed successfully.
-    Runtime is the time it took to execute the task using the pool.
-    (Time starting from the task is sent to the pool, and ending when the
-    pool result handlers callback is called).
-
-* task-failed(uuid, exception, traceback, hostname, timestamp)
-
-    Sent if the execution of the task failed.
-
-* task-revoked(uuid)
-
-    Sent if the task has been revoked (Note that this is likely
-    to be sent by more than one worker)
-
-* task-retried(uuid, exception, traceback, hostname, timestamp)
-
-    Sent if the task failed, but will be retried.
-
-Worker Events
-=============
-
-* worker-online(hostname, timestamp)
-
-    The worker has connected to the broker and is online.
-
-* worker-heartbeat(hostname, timestamp)
-
-    Sent every minute, if the worker has not sent a heartbeat in 2 minutes,
-    it's considered to be offline.
-
-* worker-offline(hostname, timestamp)
-
-    The worker has disconnected from the broker.

+ 0 - 2
docs/internals/index.rst

@@ -13,7 +13,5 @@
     deprecation
     worker
     protocol
-    events
-    moduleindex
     app-overview
     reference/index

+ 0 - 182
docs/internals/moduleindex.rst

@@ -1,182 +0,0 @@
-.. _internals-module-overview:
-
-==============
- Module Index
-==============
-
-.. contents::
-    :local:
-
-Worker
-======
-
-celery.worker
--------------
-
-* :class:`~celery.worker.WorkController`
-
-This is the worker's main process. It starts and stops all the components
-required by the worker: Pool, Mediator, Scheduler, ClockService, and Consumer.
-
-* :func:`~celery.worker.process_initializer`
-
-This is the function used to initialize pool processes. It sets up loggers and
-imports required task modules, etc.
-
-celery.worker.job
------------------
-
-* :class:`~celery.worker.job.TaskRequest`
-
-A request to execute a task. Contains the task name, id, args and kwargs.
-Handles acknowledgement, execution, writing results to backends and error handling
-(including error e-mails)
-
-celery.worker.pool
-------------------
-
-celery.worker.consumer
-----------------------
-
-celery.worker.controllers
--------------------------
-
-celery.worker.scheduler
------------------------
-
-celery.worker.buckets
----------------------
-
-celery.worker.heartbeat
------------------------
-
-celery.worker.revoke
---------------------
-
-celery.worker.control
----------------------
-
-* celery.worker.registry
-
-
-Tasks
-=====
-
-celery.decorators
------------------
-
-celery.registry
----------------
-
-celery.task
------------
-
-celery.task.base
-----------------
-
-celery.task.http
-----------------
-
-celery.task.control
--------------------
-
-Execution
-=========
-
-celery.execute
---------------
-
-celery.execute.trace
---------------------
-
-celery.result
--------------
-
-celery.states
--------------
-
-celery.signals
-
-Messaging
-=========
-
-celery.messaging
-----------------
-
-Result backends
-===============
-
-celery.backends
----------------
-
-celery.backends.base
---------------------
-
-celery.backends.amqp
---------------------
-
-celery.backends.database
-------------------------
-
-Loaders
-=======
-
-celery.loaders
---------------
-
-Loader autodetection, and working with the currently
-selected loader.
-
-celery.loaders.base - Loader base classes
------------------------------------------
-
-celery.loaders.default - The default loader
--------------------------------------------
-
-CeleryBeat
-==========
-
-celery.beat
------------
-
-Events
-======
-
-celery.events
--------------
-
-Logging
-=======
-
-celery.log
-----------
-
-celery.utils.patch
-------------------
-
-Configuration
-=============
-
-celery.conf
------------
-
-Miscellaneous
-=============
-
-celery.datastructures
----------------------
-
-celery.exceptions
------------------
-
-celery.platform
----------------
-
-celery.utils
-------------
-
-celery.utils.info
------------------
-
-celery.utils.compat
--------------------

+ 2 - 1
docs/internals/protocol.rst

@@ -60,7 +60,8 @@ format:
 
 .. code-block:: javascript
 
-    {"task": "celery.task.PingTask",
+    {"id": "4cc7438e-afd4-4f8f-a2f3-f46567e7ca77",
+     "task": "celery.task.PingTask",
      "args": [],
      "kwargs": {},
      "retries": 0,