Browse Source

Change remaining references to kombu.async into kombu.asynchronous.

Omer Katz 6 years ago
parent
commit
ae350676db

+ 1 - 1
docs/userguide/configuration.rst

@@ -2467,7 +2467,7 @@ Name of the consumer class used by the worker.
 ``worker_timer``
 ``worker_timer``
 ~~~~~~~~~~~~~~~~
 ~~~~~~~~~~~~~~~~
 
 
-Default: ``"kombu.async.hub.timer:Timer"``.
+Default: ``"kombu.asynchronous.hub.timer:Timer"``.
 
 
 Name of the ETA scheduler class used by the worker.
 Name of the ETA scheduler class used by the worker.
 Default is or set by the pool implementation.
 Default is or set by the pool implementation.

+ 4 - 4
docs/userguide/extending.rst

@@ -148,7 +148,7 @@ Attributes
 
 
 .. attribute:: hub
 .. attribute:: hub
 
 
-    Event loop object (:class:`~kombu.async.Hub`). You can use
+    Event loop object (:class:`~kombu.asynchronous.Hub`). You can use
     this to register callbacks in the event loop.
     this to register callbacks in the event loop.
 
 
     This is only supported by async I/O enabled transports (amqp, redis),
     This is only supported by async I/O enabled transports (amqp, redis),
@@ -179,7 +179,7 @@ Attributes
 
 
 .. attribute:: timer
 .. attribute:: timer
 
 
-    :class:`~kombu.async.timer.Timer` used to schedule functions.
+    :class:`~kombu.asynchronous.timer.Timer` used to schedule functions.
 
 
     Your worker bootstep must require the Timer bootstep to use this:
     Your worker bootstep must require the Timer bootstep to use this:
 
 
@@ -349,7 +349,7 @@ Attributes
 
 
 .. attribute:: hub
 .. attribute:: hub
 
 
-    Event loop object (:class:`~kombu.async.Hub`). You can use
+    Event loop object (:class:`~kombu.asynchronous.Hub`). You can use
     this to register callbacks in the event loop.
     this to register callbacks in the event loop.
 
 
     This is only supported by async I/O enabled transports (amqp, redis),
     This is only supported by async I/O enabled transports (amqp, redis),
@@ -873,7 +873,7 @@ Worker API
 ==========
 ==========
 
 
 
 
-:class:`~kombu.async.Hub` - The workers async event loop
+:class:`~kombu.asynchronous.Hub` - The workers async event loop
 --------------------------------------------------------
 --------------------------------------------------------
 :supported transports: amqp, redis
 :supported transports: amqp, redis
 
 

+ 1 - 1
t/unit/worker/test_loops.py

@@ -5,7 +5,7 @@ import socket
 
 
 import pytest
 import pytest
 from case import Mock
 from case import Mock
-from kombu.async import ERR, READ, WRITE, Hub
+from kombu.asynchronous import ERR, READ, WRITE, Hub
 
 
 from celery.bootsteps import CLOSE, RUN
 from celery.bootsteps import CLOSE, RUN
 from celery.exceptions import (InvalidTaskError, WorkerLostError,
 from celery.exceptions import (InvalidTaskError, WorkerLostError,

+ 1 - 1
t/unit/worker/test_worker.py

@@ -1047,7 +1047,7 @@ class test_WorkController(ConsumerCase):
         assert w.process_task is w._process_task
         assert w.process_task is w._process_task
 
 
     def test_Pool_create(self):
     def test_Pool_create(self):
-        from kombu.async.semaphore import LaxBoundedSemaphore
+        from kombu.asynchronous.semaphore import LaxBoundedSemaphore
         w = Mock()
         w = Mock()
         w._conninfo.connection_errors = w._conninfo.channel_errors = ()
         w._conninfo.connection_errors = w._conninfo.channel_errors = ()
         w.hub = Mock()
         w.hub = Mock()