Bläddra i källkod

Docs: Adds event crossref type

Ask Solem 12 år sedan
förälder
incheckning
e60533b4bb
2 ändrade filer med 103 tillägg och 48 borttagningar
  1. 5 0
      docs/_ext/celerydocs.py
  2. 98 48
      docs/userguide/monitoring.rst

+ 5 - 0
docs/_ext/celerydocs.py

@@ -147,3 +147,8 @@ def setup(app):
         rolename="signal",
         indextemplate="pair: %s; signal",
     )
+    app.add_crossref_type(
+        directivename="event",
+        rolename="event",
+        indextemplate="pair: %s; event",
+    )

+ 98 - 48
docs/userguide/monitoring.rst

@@ -773,87 +773,137 @@ You can listen to specific events by specifying the handlers:
 .. _event-reference:
 
 Event Reference
----------------
+===============
 
 This list contains the events sent by the worker, and their arguments.
 
 .. _event-reference-task:
 
 Task Events
-~~~~~~~~~~~
+-----------
+
+.. event:: task-sent
+
+task-sent
+~~~~~~~~~
+
+:signature: ``task-sent(uuid, name, args, kwargs, retries, eta, expires,
+              queue, exchange, routing_key)``
+
+Sent when a task message is published and
+the :setting:`CELERY_SEND_TASK_SENT_EVENT` setting is enabled.
+
+.. event:: task-received
 
-* ``task-sent(uuid, name, args, kwargs, retries, eta, expires,
-  queue, exchange, routing_key)``
+task-received
+~~~~~~~~~~~~~
+
+:signature: ``task-received(uuid, name, args, kwargs, retries, eta, hostname,
+              timestamp)``
+
+Sent when the worker receives a task.
 
-   Sent when a task message is published and
-   the :setting:`CELERY_SEND_TASK_SENT_EVENT` setting is enabled.
+.. event:: task-started
 
-* ``task-received(uuid, name, args, kwargs, retries, eta, hostname,
-  timestamp)``
+task-started
+~~~~~~~~~~~~
 
-    Sent when the worker receives a task.
+:signature: ``task-started(uuid, hostname, timestamp, pid)``
 
-* ``task-started(uuid, hostname, timestamp, pid)``
+Sent just before the worker executes the task.
 
-    Sent just before the worker executes the task.
+.. event:: task-succeeded
 
-* ``task-succeeded(uuid, result, runtime, hostname, timestamp)``
+task-succeeded
+~~~~~~~~~~~~~~
 
-    Sent if the task executed successfully.
+:signature: ``task-succeeded(uuid, result, runtime, hostname, timestamp)``
 
-    Runtime is the time it took to execute the task using the pool.
-    (Starting from the task is sent to the worker pool, and ending when the
-    pool result handler callback is called).
+Sent if the task executed successfully.
 
-* ``task-failed(uuid, exception, traceback, hostname, timestamp)``
+Runtime is the time it took to execute the task using the pool.
+(Starting from the task is sent to the worker pool, and ending when the
+pool result handler callback is called).
+
+.. event:: task-failed
+
+task-failed
+~~~~~~~~~~~
 
-    Sent if the execution of the task failed.
+:signature: ``task-failed(uuid, exception, traceback, hostname, timestamp)``
 
-* ``task-revoked(uuid, terminated, signum, expired)``
+Sent if the execution of the task failed.
 
-    Sent if the task has been revoked (Note that this is likely
-    to be sent by more than one worker).
+.. event:: task-revoked
 
-    - ``terminated`` is set to true if the task process was terminated,
-      and the ``signum`` field set to the signal used.
+task-revoked
+~~~~~~~~~~~~
 
-    - ``expired`` is set to true if the task expired.
+:signature: ``task-revoked(uuid, terminated, signum, expired)``
 
-* ``task-retried(uuid, exception, traceback, hostname, timestamp)``
+Sent if the task has been revoked (Note that this is likely
+to be sent by more than one worker).
 
-    Sent if the task failed, but will be retried in the future.
+- ``terminated`` is set to true if the task process was terminated,
+    and the ``signum`` field set to the signal used.
+
+- ``expired`` is set to true if the task expired.
+
+.. event:: task-retried
+
+task-retried
+~~~~~~~~~~~~
+
+:signature: ``task-retried(uuid, exception, traceback, hostname, timestamp)``
+
+Sent if the task failed, but will be retried in the future.
 
 .. _event-reference-worker:
 
 Worker Events
+-------------
+
+.. event:: worker-online
+
+worker-online
 ~~~~~~~~~~~~~
 
-* ``worker-online(hostname, timestamp, freq, sw_ident, sw_ver, sw_sys)``
+:signature: ``worker-online(hostname, timestamp, freq, sw_ident, sw_ver, sw_sys)``
+
+The worker has connected to the broker and is online.
+
+- `hostname`: Hostname of the worker.
+- `timestamp`: Event timestamp.
+- `freq`: Heartbeat frequency in seconds (float).
+- `sw_ident`: Name of worker software (e.g. ``py-celery``).
+- `sw_ver`: Software version (e.g. 2.2.0).
+- `sw_sys`: Operating System (e.g. Linux, Windows, Darwin).
+
+.. event:: worker-heartbeat
+
+worker-heartbeat
+~~~~~~~~~~~~~~~~
 
-    The worker has connected to the broker and is online.
+:signature: ``worker-heartbeat(hostname, timestamp, freq, sw_ident, sw_ver, sw_sys,
+              active, processed)``
 
-    * `hostname`: Hostname of the worker.
-    * `timestamp`: Event timestamp.
-    * `freq`: Heartbeat frequency in seconds (float).
-    * `sw_ident`: Name of worker software (e.g. ``py-celery``).
-    * `sw_ver`: Software version (e.g. 2.2.0).
-    * `sw_sys`: Operating System (e.g. Linux, Windows, Darwin).
+Sent every minute, if the worker has not sent a heartbeat in 2 minutes,
+it is considered to be offline.
 
-* ``worker-heartbeat(hostname, timestamp, freq, sw_ident, sw_ver, sw_sys,
-    active, processed)``
+- `hostname`: Hostname of the worker.
+- `timestamp`: Event timestamp.
+- `freq`: Heartbeat frequency in seconds (float).
+- `sw_ident`: Name of worker software (e.g. ``py-celery``).
+- `sw_ver`: Software version (e.g. 2.2.0).
+- `sw_sys`: Operating System (e.g. Linux, Windows, Darwin).
+- `active`: Number of currently executing tasks.
+- `processed`: Total number of tasks processed by this worker.
 
-    Sent every minute, if the worker has not sent a heartbeat in 2 minutes,
-    it is considered to be offline.
+.. event:: worker-offline
 
-    * `hostname`: Hostname of the worker.
-    * `timestamp`: Event timestamp.
-    * `freq`: Heartbeat frequency in seconds (float).
-    * `sw_ident`: Name of worker software (e.g. ``py-celery``).
-    * `sw_ver`: Software version (e.g. 2.2.0).
-    * `sw_sys`: Operating System (e.g. Linux, Windows, Darwin).
-    * `active`: Number of currently executing tasks.
-    * `processed`: Total number of tasks processed by this worker.
+worker-offline
+~~~~~~~~~~~~~~
 
-* ``worker-offline(hostname, timestamp, freq, sw_ident, sw_ver, sw_sys)``
+:signature: ``worker-offline(hostname, timestamp, freq, sw_ident, sw_ver, sw_sys)``
 
-    The worker has disconnected from the broker.
+The worker has disconnected from the broker.