Ask Solem 15 years ago
parent
commit
f0ddafa69a

+ 2 - 1
celery/backends/amqp.py

@@ -56,7 +56,8 @@ class AMQPBackend(BaseDictBackend):
     _connection = None
 
     def __init__(self, connection=None, exchange=None, exchange_type=None,
-            persistent=None, serializer=None, auto_delete=None, expires=None, **kwargs):
+            persistent=None, serializer=None, auto_delete=None,
+            expires=None, **kwargs):
         self._connection = connection
         self.exchange = exchange
         self.exchange_type = exchange_type

+ 0 - 5
celery/backends/cache.py

@@ -9,7 +9,6 @@ from celery.utils import timeutils
 from celery.datastructures import LocalCache
 
 
-
 def get_best_memcache(*args, **kwargs):
     try:
         import pylibmc as memcache
@@ -59,7 +58,6 @@ class CacheBackend(KeyValueStoreBackend):
                     "following backends: %s" % (self.backend,
                                                 ", ".join(backends.keys())))
 
-
     def get(self, key):
         return self.client.get(key)
 
@@ -71,6 +69,3 @@ class CacheBackend(KeyValueStoreBackend):
         if self._client is None:
             self._client = self.Client(self.servers, **self.options)
         return self._client
-
-
-

+ 0 - 1
celery/bin/celeryd.py

@@ -335,7 +335,6 @@ def install_worker_int_again_handler(worker):
     platform.install_signal_handler("SIGINT", _stop)
 
 
-
 def install_worker_term_handler(worker):
 
     def _stop(signum, frame):

+ 1 - 0
celery/db/models.py

@@ -35,6 +35,7 @@ class Task(ResultModelBase):
     def __repr__(self):
         return "<Task %s state: %s>" % (self.task_id, self.status)
 
+
 class TaskSet(ResultModelBase):
     """TaskSet result"""
     __tablename__ = "celery_tasksetmeta"

+ 0 - 4
celery/routes.py

@@ -83,7 +83,3 @@ def prepare(routes):
     if not hasattr(routes, "__iter__"):
         routes = (routes, )
     return map(expand_route, routes)
-
-
-
-

+ 1 - 1
celery/task/http.py

@@ -36,6 +36,7 @@ def utf8dict(tup):
     return dict((key.encode("utf-8"), maybe_utf8(value))
                     for key, value in tup)
 
+
 def extract_response(raw_response):
     """Extract the response text from a raw JSON response."""
     if not raw_response:
@@ -54,7 +55,6 @@ def extract_response(raw_response):
             raise UnknownStatusError(str(status))
 
 
-
 class MutableURL(object):
     """Object wrapping a Uniform Resource Locator.
 

+ 0 - 1
celery/task/sets.py

@@ -215,4 +215,3 @@ class TaskSet(UserList):
             "TaskSet.task_name is deprecated and will be removed in 1.4",
             DeprecationWarning)
         return self._task_name
-

+ 0 - 3
celery/tests/test_backends/test_base.py

@@ -158,9 +158,6 @@ class test_BaseDictBackend(unittest.TestCase):
         self.b._cache["task-exists"] = {"result": "task"}
 
 
-
-
-
 class test_KeyValueStoreBackend(unittest.TestCase):
 
     def setUp(self):

+ 0 - 1
celery/tests/test_backends/test_cache.py

@@ -66,7 +66,6 @@ class test_CacheBackend(unittest.TestCase):
                           CacheBackend, backend="unknown://")
 
 
-
 class test_get_best_memcache(unittest.TestCase):
 
     def mock_memcache(self):

+ 0 - 1
celery/tests/test_backends/test_database.py

@@ -135,4 +135,3 @@ class test_DatabaseBackend(unittest.TestCase):
 
     def test_TaskSet__repr__(self):
         self.assertIn("foo", repr(TaskSet("foo", None)))
-

+ 0 - 3
celery/tests/test_bin/test_celeryd.py

@@ -35,7 +35,6 @@ def disable_stdouts(fun):
     return disable
 
 
-
 class _WorkController(object):
 
     def __init__(self, *args, **kwargs):
@@ -143,7 +142,6 @@ class test_Worker(unittest.TestCase):
         self.assertTrue(worker_ready_sent[0])
 
 
-
 class test_funs(unittest.TestCase):
 
     @disable_stdouts
@@ -192,7 +190,6 @@ class test_funs(unittest.TestCase):
             sys.argv = s
 
 
-
 class test_signal_handlers(unittest.TestCase):
 
     class _Worker(object):

+ 1 - 1
celery/tests/test_buckets.py

@@ -94,7 +94,6 @@ class test_TokenBucketQueue(unittest.TestCase):
         self.assertEqual(x.get_nowait(), "The quick brown fox")
 
 
-
 class test_rate_limit_string(unittest.TestCase):
 
     @skip_if_disabled
@@ -283,6 +282,7 @@ class test_TaskBucket(unittest.TestCase):
         x.buckets[TaskC.name].put(3)
         self.assertItemsEqual(x.items, [1, 2, 3])
 
+
 class test_FastQueue(unittest.TestCase):
 
     def test_can_consume(self):

+ 0 - 2
celery/tests/test_concurrency_processes.py

@@ -91,5 +91,3 @@ class test_TaskPool(unittest.TestCase):
         pool = TaskPool(10)
         pool.start()
         pool.apply_async(lambda x: x, (2, ), {})
-
-

+ 0 - 1
celery/tests/test_datastructures.py

@@ -149,4 +149,3 @@ class test_AttributeDict(unittest.TestCase):
         self.assertRaises(AttributeError, getattr, x, "bar")
         x.bar = "foo"
         self.assertEqual(x["bar"], "foo")
-

+ 0 - 1
celery/tests/test_routes.py

@@ -100,4 +100,3 @@ class test_prepare(unittest.TestCase):
         self.assertIs(p[2], o)
 
         self.assertEqual(routes.prepare(o), [o])
-

+ 0 - 1
celery/tests/test_task_sets.py

@@ -127,7 +127,6 @@ class test_TaskSet(unittest.TestCase):
                         for i in (2, 4, 8)])
         self.assertEqual(len(ts), 3)
 
-
     def test_respects_ALWAYS_EAGER(self):
 
         class MockTaskSet(TaskSet):

+ 0 - 3
celery/tests/test_worker.py

@@ -450,9 +450,6 @@ class test_CarrotListener(unittest.TestCase):
         self.assertEqual(l.iterations, 1)
 
 
-
-
-
 class test_WorkController(unittest.TestCase):
 
     def setUp(self):

+ 0 - 1
celery/tests/test_worker_control.py

@@ -185,7 +185,6 @@ class test_ControlPanel(unittest.TestCase):
              "destination": hostname}
         self.assertRaises(SystemExit, self.panel.dispatch_from_message, m)
 
-
     def test_panel_reply(self):
 
         replies = []