Parcourir la source

Removed module celery.task.strategy

Ask Solem il y a 16 ans
Parent
commit
39f6883e55

+ 0 - 51
celery/task/strategy.py

@@ -1,51 +0,0 @@
-from celery.utils import chunks
-
-
-def even_time_distribution(task, size, time_window, iterable, **apply_kwargs):
-    """With an iterator yielding task args, kwargs tuples, evenly distribute
-    the processing of its tasks throughout the time window available.
-
-    :param task: The kind of task (a :class:`celery.task.base.Task`.)
-    :param size: Total number of elements the iterator gives.
-    :param time_window: Total time available, in minutes.
-    :param iterable: Iterable yielding task args, kwargs tuples.
-    :param \*\*apply_kwargs: Additional keyword arguments to be passed on to
-        :func:`celery.execute.apply_async`.
-
-    Example
-
-        >>> class RefreshAllFeeds(Task):
-        ...
-        ...     def run(self, **kwargs):
-        ...         feeds = Feed.objects.all()
-        ...         total = feeds.count()
-        ...
-        ...         time_window = REFRESH_FEEDS_EVERY_INTERVAL_MINUTES
-        ...
-        ...         def iter_feed_task_args(iterable):
-        ...             for feed in iterable:
-        ...                 yield ([feed.feed_url], {}) # args, kwargs tuple
-        ...
-        ...         it = iter_feed_task_args(feeds.iterator())
-        ...
-        ...         even_time_distribution(RefreshFeedTask, total,
-        ...                                time_window, it)
-
-    """
-
-    bucketsize = size / time_window
-    buckets = chunks(iterable, int(bucketsize))
-
-    connection = task.establish_connection()
-    try:
-        for bucket_count, bucket in enumerate(buckets):
-            # Skew the countdown for items in this bucket by one.
-            seconds_eta = (bucket_count and 60 * bucket_count or None)
-
-            for args, kwargs in bucket:
-                task.apply_async(args=args, kwargs=kwargs,
-                                 connection=connection,
-                                 countdown=seconds_eta,
-                                 **apply_kwargs)
-    finally:
-        connection.close()

+ 0 - 8
docs/reference/celery.task.strategy.rst

@@ -1,8 +0,0 @@
-===============================================
- Common Task Strategies - celery.task.strategy
-===============================================
-
-.. currentmodule:: celery.task.strategy
-
-.. automodule:: celery.task.strategy
-    :members:

+ 0 - 1
docs/reference/index.rst

@@ -19,7 +19,6 @@
     celery.exceptions
     celery.task.rest
     celery.task.builtins
-    celery.task.strategy
     celery.loaders
     celery.loaders.base
     celery.loaders.default

+ 1 - 1
testproj/settings.py

@@ -33,7 +33,7 @@ COVERAGE_EXCLUDE_MODULES = ("celery.__init__",
                             "celery.loaders.default", # FIXME
                             "celery.backends.mongodb", # FIXME
                             "celery.backends.tyrant", # FIXME
-                            "celery.task.strategy")
+                            )
 COVERAGE_HTML_REPORT = True
 COVERAGE_BRANCH_COVERAGE = True