Selaa lähdekoodia

Updated Changelog

Ask Solem 15 vuotta sitten
vanhempi
commit
7634e103b2
3 muutettua tiedostoa jossa 13 lisäystä ja 3 poistoa
  1. 13 0
      Changelog
  2. 0 2
      celery/tests/test_backends/test_amqp.py
  3. 0 1
      celery/worker/__init__.py

+ 13 - 0
Changelog

@@ -42,6 +42,12 @@
   ``backend.reload_taskset_result`` (that's for those who want to send
   results incrementally).
 
+* ``celeryd`` now works on Windows again. Note that if running with Django,
+  you can't use ``project.settings`` as the settings module name, but the
+  following should work::
+
+		$ python manage.py celeryd --settings=settings
+
 * Execution: ``.messaging.TaskPublisher.send_task`` now
   incorporates all the functionality apply_async previously did (like
   converting countdowns to eta), so :func:`celery.execute.apply_async` is
@@ -85,6 +91,9 @@
   A ``REDIS_PASSWORD`` setting has been added, so you can use the new
   simple authentication mechanism in Redis.
 
+* The redis result backend no longer calls ``SAVE`` when disconnecting,
+  as this is apparently better handled by Redis itself.
+
 * If ``settings.DEBUG`` is on, celeryd now warns about the possible
   memory leak it can result in.
 
@@ -124,6 +133,10 @@
 
 * TaskPublisher: Declarations are now done once (per process).
 
+* Added ``Task.delivery_mode`` and the ``CELERY_DEFAULT_DELIVERY_MODE``
+  setting. These can be used to mark messages non-persistent (i.e. so they are
+  lost if the broker is restarted).
+
 * Now have our own ``ImproperlyConfigured`` exception, instead of using the
   Django one.
 

+ 0 - 2
celery/tests/test_backends/test_amqp.py

@@ -1,8 +1,6 @@
 import sys
 import unittest2 as unittest
 
-from celery.exceptions import ImproperlyConfigured
-
 from celery import states
 from celery.utils import gen_unique_id
 from celery.backends.amqp import AMQPBackend

+ 0 - 1
celery/worker/__init__.py

@@ -40,7 +40,6 @@ def process_initializer():
     current_loader().init_worker()
 
 
-
 class WorkController(object):
     """Executes tasks waiting in the task queue.