Ask Solem 8 years ago
parent
commit
e6f4bdf03d

+ 0 - 2
celery/loaders/base.py

@@ -17,8 +17,6 @@ import sys
 from datetime import datetime
 
 from kombu.utils import json
-from kombu.utils import cached_property
-from kombu.utils.encoding import safe_str
 
 from celery import signals
 from celery.five import reraise, string_t

+ 1 - 2
celery/tests/app/test_app.py

@@ -17,7 +17,7 @@ from celery.app import base as _appbase
 from celery.app import defaults
 from celery.exceptions import ImproperlyConfigured
 from celery.five import keys
-from celery.loaders.base import BaseLoader, unconfigured
+from celery.loaders.base import unconfigured
 from celery.platforms import pyimplementation
 from celery.utils.serialization import pickle
 from celery.utils.timeutils import timezone
@@ -32,7 +32,6 @@ from celery.tests.case import (
     mock,
     patch,
 )
-from celery.utils import uuid
 from celery.utils.objects import Bunch
 
 THIS_IS_A_KEY = 'this is a value'

+ 0 - 1
celery/worker/components.py

@@ -18,7 +18,6 @@ from kombu.async.timer import Timer as _Timer
 from celery import bootsteps
 from celery._state import _set_task_join_will_block
 from celery.exceptions import ImproperlyConfigured
-from celery.five import string_t
 from celery.platforms import IS_WINDOWS
 from celery.utils.log import worker_logger as logger
 

+ 1 - 1
celery/worker/strategy.py

@@ -90,6 +90,7 @@ def default(task, app, consumer,
                 body = bytes(body) if isinstance(body, buffer_t) else body
         else:
             body, headers, decoded, utc = proto1_to_proto2(message, body)
+
         req = Req(
             message,
             on_ack=ack, on_reject=reject, app=app, hostname=hostname,
@@ -101,7 +102,6 @@ def default(task, app, consumer,
         if (req.expires or req.id in revoked_tasks) and req.revoked():
             return
 
-
         if events:
             send_event(
                 'task-received',