Parcourir la source

Replace amqp:// with pyamqp:// in first steps doc (#3555)

According to Ask's answer to:
https://github.com/celery/celery/issues/3543
the amqp:// protocol uses librabbitmq, which - as of Celery 4 - is
broken and advised against.

This PR changes the First Steps tutorial to use the adviesed pyamqp://
URL scheme instead.
GDR! il y a 9 ans
Parent
commit
9508c462df
1 fichiers modifiés avec 4 ajouts et 4 suppressions
  1. 4 4
      docs/getting-started/first-steps-with-celery.rst

+ 4 - 4
docs/getting-started/first-steps-with-celery.rst

@@ -118,7 +118,7 @@ Let's create the file :file:`tasks.py`:
 
     from celery import Celery
 
-    app = Celery('tasks', broker='amqp://guest@localhost//')
+    app = Celery('tasks', broker='pyamqp://guest@localhost//')
 
     @app.task
     def add(x, y):
@@ -221,14 +221,14 @@ you choose to use a configuration module):
 
 .. code-block:: python
 
-    app = Celery('tasks', backend='rpc://', broker='amqp://')
+    app = Celery('tasks', backend='rpc://', broker='pyamqp://')
 
 Or if you want to use Redis as the result backend, but still use RabbitMQ as
 the message broker (a popular combination):
 
 .. code-block:: python
 
-    app = Celery('tasks', backend='redis://localhost', broker='amqp://')
+    app = Celery('tasks', backend='redis://localhost', broker='pyamqp://')
 
 To read more about result backends please see :ref:`task-result-backends`.
 
@@ -337,7 +337,7 @@ current directory or on the Python path, it could look like this:
 
 .. code-block:: python
 
-    broker_url = 'amqp://'
+    broker_url = 'pyamqp://'
     result_backend = 'rpc://'
 
     task_serializer = 'json'