Browse Source

Rename references to taskset in docs

Ask Solem 12 years ago
parent
commit
9dd6f37029
4 changed files with 10 additions and 9 deletions
  1. 1 1
      celery/task/__init__.py
  2. 1 1
      docs/reference/celery.rst
  3. 6 6
      docs/userguide/canvas.rst
  4. 2 1
      docs/userguide/signals.rst

+ 1 - 1
celery/task/__init__.py

@@ -23,7 +23,7 @@ __all__ = [
 
 
 STATICA_HACK = True
 STATICA_HACK = True
 globals()['kcah_acitats'[::-1].upper()] = False
 globals()['kcah_acitats'[::-1].upper()] = False
-if STATICA_HACK:
+if STATICA_HACK:  # pragma: no cover
     # This is never executed, but tricks static analyzers (PyDev, PyCharm,
     # This is never executed, but tricks static analyzers (PyDev, PyCharm,
     # pylint, etc.) into knowing the types of these symbols, and what
     # pylint, etc.) into knowing the types of these symbols, and what
     # they contain.
     # they contain.

+ 1 - 1
docs/reference/celery.rst

@@ -241,7 +241,7 @@ and creating Celery applications.
 
 
     .. attribute:: Celery.GroupResult
     .. attribute:: Celery.GroupResult
 
 
-        Create new taskset result instance.
+        Create new group result instance.
         See :class:`~celery.result.GroupResult`.
         See :class:`~celery.result.GroupResult`.
 
 
     .. method:: Celery.worker_main(argv=None)
     .. method:: Celery.worker_main(argv=None)

+ 6 - 6
docs/userguide/canvas.rst

@@ -565,7 +565,7 @@ The :class:`~celery.group` function takes a list of subtasks::
     (proj.tasks.add(2, 2), proj.tasks.add(4, 4))
     (proj.tasks.add(2, 2), proj.tasks.add(4, 4))
 
 
 If you **call** the group, the tasks will be applied
 If you **call** the group, the tasks will be applied
-one after one in the current process, and a :class:`~@TaskSetResult`
+one after one in the current process, and a :class:`~celery.result.GroupResult`
 instance is returned which can be used to keep track of the results,
 instance is returned which can be used to keep track of the results,
 or tell how many tasks are ready and so on::
 or tell how many tasks are ready and so on::
 
 
@@ -667,7 +667,7 @@ Chords
 
 
 .. versionadded:: 2.3
 .. versionadded:: 2.3
 
 
-A chord is a task that only executes after all of the tasks in a taskset have
+A chord is a task that only executes after all of the tasks in a group have
 finished executing.
 finished executing.
 
 
 
 
@@ -800,7 +800,7 @@ Example decorated task:
         do_something()
         do_something()
 
 
 By default the synchronization step is implemented by having a recurring task
 By default the synchronization step is implemented by having a recurring task
-poll the completion of the taskset every second, calling the subtask when
+poll the completion of the group every second, calling the subtask when
 ready.
 ready.
 
 
 Example implementation:
 Example implementation:
@@ -808,9 +808,9 @@ Example implementation:
 .. code-block:: python
 .. code-block:: python
 
 
     @app.task(bind=True)
     @app.task(bind=True)
-    def unlock_chord(self, taskset, callback, interval=1, max_retries=None):
-        if taskset.ready():
-            return subtask(callback).delay(taskset.join())
+    def unlock_chord(self, group, callback, interval=1, max_retries=None):
+        if group.ready():
+            return subtask(callback).delay(group.join())
         raise self.retry(countdown=interval, max_retries=max_retries)
         raise self.retry(countdown=interval, max_retries=max_retries)
 
 
 
 

+ 2 - 1
docs/userguide/signals.rst

@@ -90,7 +90,8 @@ Provides arguments:
     The time to execute the task.
     The time to execute the task.
 
 
 * taskset
 * taskset
-    Id of the taskset this task is part of (if any).
+    Id of the group this task is part of (if any).
+    (named taskset for historial reasons)
 
 
 .. signal:: task_prerun
 .. signal:: task_prerun