Browse Source

Python 3.7 compat issues (#4852)

* renamed banckend.async to asynchronous

* adjust redis imports of async

* adjust imports of async

* import style adjust

* renamed doc from async to asynchronous

* renamed doc contents from async to asynchronous
Asif Saifuddin Auvi 6 years ago
parent
commit
e700276921

+ 0 - 0
celery/backends/async.py → celery/backends/asynchronous.py


+ 4 - 3
celery/backends/redis.py

@@ -19,7 +19,8 @@ from celery.utils.functional import dictfilter
 from celery.utils.log import get_logger
 from celery.utils.time import humanize_seconds
 
-from . import async, base
+from .asynchronous import AsyncBackendMixin, BaseResultConsumer
+from .base import BaseKeyValueStoreBackend
 
 try:
     from urllib.parse import unquote
@@ -74,7 +75,7 @@ E_LOST = 'Connection to Redis lost: Retry (%s/%s) %s.'
 logger = get_logger(__name__)
 
 
-class ResultConsumer(async.BaseResultConsumer):
+class ResultConsumer(BaseResultConsumer):
     _pubsub = None
 
     def __init__(self, *args, **kwargs):
@@ -138,7 +139,7 @@ class ResultConsumer(async.BaseResultConsumer):
             self._pubsub.unsubscribe(key)
 
 
-class RedisBackend(base.BaseKeyValueStoreBackend, async.AsyncBackendMixin):
+class RedisBackend(BaseKeyValueStoreBackend, AsyncBackendMixin):
     """Redis task result store."""
 
     ResultConsumer = ResultConsumer

+ 1 - 1
celery/backends/rpc.py

@@ -17,7 +17,7 @@ from celery._state import current_task, task_join_will_block
 from celery.five import items, range
 
 from . import base
-from .async import AsyncBackendMixin, BaseResultConsumer
+from .asynchronous import AsyncBackendMixin, BaseResultConsumer
 
 __all__ = ('BacklogLimitExceeded', 'RPCBackend')
 

+ 3 - 3
docs/internals/reference/celery.backends.async.rst → docs/internals/reference/celery.backends.asynchronous.rst

@@ -1,12 +1,12 @@
 =====================================
- ``celery.backends.async``
+ ``celery.backends.asynchronous``
 =====================================
 
 .. contents::
     :local:
-.. currentmodule:: celery.backends.async
+.. currentmodule:: celery.backends.asynchronous
 
-.. automodule:: celery.backends.async
+.. automodule:: celery.backends.asynchronous
     :members:
     :undoc-members:
 

+ 2 - 2
t/unit/backends/test_redis.py

@@ -146,7 +146,7 @@ class test_RedisResultConsumer:
     def get_consumer(self):
         return self.get_backend().result_consumer
 
-    @patch('celery.backends.async.BaseResultConsumer.on_after_fork')
+    @patch('celery.backends.asynchronous.BaseResultConsumer.on_after_fork')
     def test_on_after_fork(self, parent_method):
         consumer = self.get_consumer()
         consumer.start('none')
@@ -172,7 +172,7 @@ class test_RedisResultConsumer:
         parent_method.assert_called_once()
 
     @patch('celery.backends.redis.ResultConsumer.cancel_for')
-    @patch('celery.backends.async.BaseResultConsumer.on_state_change')
+    @patch('celery.backends.asynchronous.BaseResultConsumer.on_state_change')
     def test_on_state_change(self, parent_method, cancel_for):
         consumer = self.get_consumer()
         meta = {'task_id': 'testing', 'status': states.SUCCESS}