|
@@ -2,15 +2,28 @@
|
|
|
Change history
|
|
|
==============
|
|
|
|
|
|
+0.2.0-pre1 [2009-05-20 04:13 P.M CET] askh@opera.com
|
|
|
+----------------------------------------------------
|
|
|
+
|
|
|
+ * It's getting quite stable, with a lot of new features, so bump
|
|
|
+ version to 0.2. This is a pre-release.
|
|
|
+
|
|
|
+ * ``celery.task.mark_as_read()`` and ``celery.task.mark_as_failure()`` has
|
|
|
+ been removed. Use ``celery.backends.default_backend.mark_as_read()``,
|
|
|
+ and ``celery.backends.default_backend.mark_as_failure()`` instead.
|
|
|
+
|
|
|
0.1.15 [2009-05-20 04:13 P.M CET] askh@opera.com
|
|
|
------------------------------------------------
|
|
|
|
|
|
- * The celery daemon was leaking AMQP connections, this should be fixed, if you have any problems with too many files open (like ``emfile`` errors in ``rabbit.log``, please contact us!
|
|
|
+ * The celery daemon was leaking AMQP connections, this should be fixed,
|
|
|
+ if you have any problems with too many files open (like ``emfile``
|
|
|
+ errors in ``rabbit.log``, please contact us!
|
|
|
|
|
|
0.1.14 [2009-05-19 01:08 P.M CET] askh@opera.com
|
|
|
------------------------------------------------
|
|
|
|
|
|
- * Fixed a syntax error in the ``TaskSet`` class. (No such variable ``TimeOutError``).
|
|
|
+ * Fixed a syntax error in the ``TaskSet`` class. (No such variable
|
|
|
+ ``TimeOutError``).
|
|
|
|
|
|
0.1.13 [2009-05-19 12:36 P.M CET] askh@opera.com
|
|
|
------------------------------------------------
|
|
@@ -28,17 +41,22 @@ Change history
|
|
|
* Now using the Sphinx documentation system, you can build
|
|
|
the html documentation by doing ::
|
|
|
|
|
|
- $ cd docs
|
|
|
- $ make html
|
|
|
+ $ cd docs
|
|
|
+ $ make html
|
|
|
|
|
|
- and the result will be in ``docs/.build/html``.
|
|
|
+ and the result will be in ``docs/.build/html``.
|
|
|
|
|
|
0.1.12 [2009-05-18 04:38 P.M CET] askh@opera.com
|
|
|
------------------------------------------------
|
|
|
|
|
|
- * delay_task() etc. now returns ``celery.task.AsyncResult`` object, which lets you check the result and any failure that might have happened. It kind of works like the ``multiprocessing.AsyncResult`` class returned by ``multiprocessing.Pool.map_async``.
|
|
|
+ * ``delay_task()`` etc. now returns ``celery.task.AsyncResult`` object,
|
|
|
+ which lets you check the result and any failure that might have
|
|
|
+ happened. It kind of works like the ``multiprocessing.AsyncResult``
|
|
|
+ class returned by ``multiprocessing.Pool.map_async``.
|
|
|
|
|
|
- * Added dmap() and dmap_async(). This works like the * ``multiprocessing.Pool`` versions except they are tasks distributed to the celery server. Example:
|
|
|
+ * Added dmap() and dmap_async(). This works like the
|
|
|
+ ``multiprocessing.Pool`` versions except they are tasks
|
|
|
+ distributed to the celery server. Example:
|
|
|
|
|
|
>>> from celery.task import dmap
|
|
|
>>> import operator
|
|
@@ -69,7 +87,8 @@ Change history
|
|
|
0.1.11 [2009-05-12 02:08 P.M CET] askh@opera.com
|
|
|
-------------------------------------------------
|
|
|
|
|
|
- * The logging system was leaking file descriptors, resulting in servers stopping with the EMFILES (too many open files) error. (fixed)
|
|
|
+ * The logging system was leaking file descriptors, resulting in
|
|
|
+ servers stopping with the EMFILES (too many open files) error. (fixed)
|
|
|
|
|
|
0.1.10 [2009-05-11 12:46 P.M CET] askh@opera.com
|
|
|
-------------------------------------------------
|
|
@@ -85,33 +104,44 @@ Change history
|
|
|
|
|
|
* Better test coverage
|
|
|
* More documentation
|
|
|
- * celeryd doesn't emit ``Queue is empty`` message if ``settings.CELERYD_EMPTY_MSG_EMIT_EVERY`` is 0.
|
|
|
+ * celeryd doesn't emit ``Queue is empty`` message if
|
|
|
+ ``settings.CELERYD_EMPTY_MSG_EMIT_EVERY`` is 0.
|
|
|
|
|
|
0.1.7 [2009-04-30 1:50 P.M CET] askh@opera.com
|
|
|
-----------------------------------------------
|
|
|
|
|
|
* Added some unittests
|
|
|
|
|
|
- * Can now use the database for task metadata (like if the task has been executed or not). Set ``settings.CELERY_TASK_META``
|
|
|
+ * Can now use the database for task metadata (like if the task has
|
|
|
+ been executed or not). Set ``settings.CELERY_TASK_META``
|
|
|
|
|
|
- * Can now run ``python setup.py test`` to run the unittests from within the ``testproj`` project.
|
|
|
+ * Can now run ``python setup.py test`` to run the unittests from
|
|
|
+ within the ``testproj`` project.
|
|
|
|
|
|
- * Can set the AMQP exchange/routing key/queue using ``settings.CELERY_AMQP_EXCHANGE``, ``settings.CELERY_AMQP_ROUTING_KEY``, and ``settings.CELERY_AMQP_CONSUMER_QUEUE``.
|
|
|
+ * Can set the AMQP exchange/routing key/queue using
|
|
|
+ ``settings.CELERY_AMQP_EXCHANGE``, ``settings.CELERY_AMQP_ROUTING_KEY``,
|
|
|
+ and ``settings.CELERY_AMQP_CONSUMER_QUEUE``.
|
|
|
|
|
|
0.1.6 [2009-04-28 2:13 P.M CET] askh@opera.com
|
|
|
-----------------------------------------------
|
|
|
|
|
|
- * Introducing ``TaskSet``. A set of subtasks is executed and you can find out how many, or if all them, are done (excellent for progress bars and such)
|
|
|
+ * Introducing ``TaskSet``. A set of subtasks is executed and you can
|
|
|
+ find out how many, or if all them, are done (excellent for progress bars and such)
|
|
|
|
|
|
- * Now catches all exceptions when running ``Task.__call__``, so the daemon doesn't die. This does't happen for pure functions yet, only ``Task`` classes.
|
|
|
+ * Now catches all exceptions when running ``Task.__call__``, so the
|
|
|
+ daemon doesn't die. This does't happen for pure functions yet, only
|
|
|
+ ``Task`` classes.
|
|
|
|
|
|
* ``autodiscover()`` now works with zipped eggs.
|
|
|
|
|
|
- * celeryd: Now adds curernt working directory to ``sys.path`` for convenience.
|
|
|
+ * celeryd: Now adds curernt working directory to ``sys.path`` for
|
|
|
+ convenience.
|
|
|
|
|
|
- * The ``run_every`` attribute of ``PeriodicTask`` classes can now be a ``datetime.timedelta()`` object.
|
|
|
+ * The ``run_every`` attribute of ``PeriodicTask`` classes can now be a
|
|
|
+ ``datetime.timedelta()`` object.
|
|
|
|
|
|
- * celeryd: You can now set the ``DJANGO_PROJECT_DIR`` variable for ``celeryd`` and it will add that to ``sys.path`` for easy launching.
|
|
|
+ * celeryd: You can now set the ``DJANGO_PROJECT_DIR`` variable
|
|
|
+ for ``celeryd`` and it will add that to ``sys.path`` for easy launching.
|
|
|
|
|
|
* Can now check if a task has been executed or not via HTTP.
|
|
|
|
|
@@ -131,7 +161,8 @@ Change history
|
|
|
|
|
|
* Now has ``PeriodicTasks``, to have ``cron`` like functionality.
|
|
|
|
|
|
- * Project changed name from ``crunchy`` to ``celery``. The details of the name change request is in ``docs/name_change_request.txt``.
|
|
|
+ * Project changed name from ``crunchy`` to ``celery``. The details of
|
|
|
+ the name change request is in ``docs/name_change_request.txt``.
|
|
|
|
|
|
0.1.0 [2009-04-24 11:28 A.M CET] askh@opera.com
|
|
|
------------------------------------------------
|