| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573 | .. _guide-routing:=============== Routing Tasks===============.. note::    Alternate routing concepts like topic and fanout may not be    available for all transports, please consult the `transport comparison table`_... _`transport comparison table`:    http://kombu.readthedocs.org/en/latest/introduction.html#transport-comparison.. contents::    :local:.. _routing-basics:Basics======.. _routing-automatic:Automatic routing-----------------The simplest way to do routing is to use the:setting:`CELERY_CREATE_MISSING_QUEUES` setting (on by default).With this setting on, a named queue that is not already defined in:setting:`CELERY_QUEUES` will be created automatically.  This makes it easy toperform simple routing tasks.Say you have two servers, `x`, and `y` that handles regular tasks,and one server `z`, that only handles feed related tasks.  You can use thisconfiguration::    CELERY_ROUTES = {"feed.tasks.import_feed": {"queue": "feeds"}}With this route enabled import feed tasks will be routed to the`"feeds"` queue, while all other tasks will be routed to the default queue(named `"celery"` for historical reasons).Now you can start server `z` to only process the feeds queue like this::    (z)$ celeryd -Q feedsYou can specify as many queues as you want, so you can make this serverprocess the default queue as well::    (z)$ celeryd -Q feeds,celery.. _routing-changing-default-queue:Changing the name of the default queue~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~You can change the name of the default queue by using the followingconfiguration:.. code-block:: python    from kombu import Exchange, Queue    CELERY_DEFAULT_QUEUE = "default"    CELERY_QUEUES = (        Queue("default", Exchange("default"), routing_key="default"),    ).. _routing-autoqueue-details:How the queues are defined~~~~~~~~~~~~~~~~~~~~~~~~~~The point with this feature is to hide the complex AMQP protocol for userswith only basic needs. However -- you may still be interested in how these queuesare declared.A queue named `"video"` will be created with the following settings:.. code-block:: python    {"exchange": "video",     "exchange_type": "direct",     "routing_key": "video"}The non-AMQP backends like `ghettoq` does not support exchanges, so theyrequire the exchange to have the same name as the queue. Using this designensures it will work for them as well... _routing-manual:Manual routing--------------Say you have two servers, `x`, and `y` that handles regular tasks,and one server `z`, that only handles feed related tasks, you can use thisconfiguration:.. code-block:: python    from kombu import Queue    CELERY_DEFAULT_QUEUE = "default"    CELERY_QUEUES = (        Queue("default",    routing_key="task.#"),        Queue("feed_tasks", routing_key="feed.#"),    )    CELERY_DEFAULT_EXCHANGE = "tasks"    CELERY_DEFAULT_EXCHANGE_TYPE = "topic"    CELERY_DEFAULT_ROUTING_KEY = "task.default":setting:`CELERY_QUEUES` is a list of :class:`~kombu.entitity.Queue`instances.If you don't set the exchange or exchange type values for a key, thesewill be taken from the :setting:`CELERY_DEFAULT_EXCHANGE` and:setting:`CELERY_DEFAULT_EXCHANGE_TYPE` settings.To route a task to the `feed_tasks` queue, you can add an entry in the:setting:`CELERY_ROUTES` setting:.. code-block:: python    CELERY_ROUTES = {            "feeds.tasks.import_feed": {                "queue": "feed_tasks",                "routing_key": "feed.import",            },    }You can also override this using the `routing_key` argument to:meth:`Task.apply_async`, or :func:`~celery.execute.send_task`:    >>> from feeds.tasks import import_feed    >>> import_feed.apply_async(args=["http://cnn.com/rss"],    ...                         queue="feed_tasks",    ...                         routing_key="feed.import")To make server `z` consume from the feed queue exclusively you canstart it with the ``-Q`` option::    (z)$ celeryd -Q feed_tasks --hostname=z.example.comServers `x` and `y` must be configured to consume from the default queue::    (x)$ celeryd -Q default --hostname=x.example.com    (y)$ celeryd -Q default --hostname=y.example.comIf you want, you can even have your feed processing worker handle regulartasks as well, maybe in times when there's a lot of work to do::    (z)$ celeryd -Q feed_tasks,default --hostname=z.example.comIf you have another queue but on another exchange you want to add,just specify a custom exchange and exchange type:.. code-block:: python    from kombu import Exchange, Queue    CELERY_QUEUES = (        Queue("feed_tasks",    routing_key="feed.#"),        Queue("regular_tasks", routing_key="task.#"),        Queue("image_tasks",   exchange=Exchange("mediatasks", type="direct"),                               routing_key="image.compress"),    )If you're confused about these terms, you should read up on AMQP... seealso::    In addition to the :ref:`amqp-primer` below, there's    `Rabbits and Warrens`_, an excellent blog post describing queues and    exchanges. There's also AMQP in 10 minutes*: `Flexible Routing Model`_,    and `Standard Exchange Types`_. For users of RabbitMQ the `RabbitMQ FAQ`_    could be useful as a source of information... _`Rabbits and Warrens`: http://blogs.digitar.com/jjww/2009/01/rabbits-and-warrens/.. _`Flexible Routing Model`: http://bit.ly/95XFO1.. _`Standard Exchange Types`: http://bit.ly/EEWca.. _`RabbitMQ FAQ`: http://www.rabbitmq.com/faq.html.. _amqp-primer:AMQP Primer===========Messages--------A message consists of headers and a body.  Celery uses headers to storethe content type of the message and its content encoding.  Thecontent type is usually the serialization format used to serialize themessage. The body contains the name of the task to execute, thetask id (UUID), the arguments to execute it with and some additionalmetadata -- like the number of retries or an ETA.This is an example task message represented as a Python dictionary:.. code-block:: python    {"task": "myapp.tasks.add",     "id": "54086c5e-6193-4575-8308-dbab76798756",     "args": [4, 4],     "kwargs": {}}.. _amqp-producers-consumers-brokers:Producers, consumers and brokers--------------------------------The client sending messages is typically called a *publisher*, ora *producer*, while the entity receiving messages is calleda *consumer*.The *broker* is the message server, routing messages from producersto consumers.You are likely to see these terms used a lot in AMQP related material... _amqp-exchanges-queues-keys:Exchanges, queues and routing keys.-----------------------------------1. Messages are sent to exchanges.2. An exchange routes messages to one or more queues.  Several exchange types   exists, providing different ways to do routing, or implementing   different messaging scenarios.3. The message waits in the queue until someone consumes it.4. The message is deleted from the queue when it has been acknowledged.The steps required to send and receive messages are:1. Create an exchange2. Create a queue3. Bind the queue to the exchange.Celery automatically creates the entities necessary for the queues in:setting:`CELERY_QUEUES` to work (except if the queue's `auto_declare`setting is set to :const:`False`).Here's an example queue configuration with three queues;One for video, one for images and one default queue for everything else:.. code-block:: python    from kombu import Exchange, Queue    CELERY_QUEUES = (        Queue("default", Exchange("default"), routing_key="default"),        Queue("videos",  Exchange("media"),   routing_key="media.video"),        Queue("images",  Exchange("media"),   routing_key="media.image"),    )    CELERY_DEFAULT_QUEUE = "default"    CELERY_DEFAULT_EXCHANGE_TYPE = "direct"    CELERY_DEFAULT_ROUTING_KEY = "default".. _amqp-exchange-types:Exchange types--------------The exchange type defines how the messages are routed through the exchange.The exchange types defined in the standard are `direct`, `topic`,`fanout` and `headers`.  Also non-standard exchange types are availableas plug-ins to RabbitMQ, like the `last-value-cache plug-in`_ by MichaelBridgen... _`last-value-cache plug-in`:    http://github.com/squaremo/rabbitmq-lvc-plugin.. _amqp-exchange-type-direct:Direct exchanges~~~~~~~~~~~~~~~~Direct exchanges match by exact routing keys, so a queue bound bythe routing key `video` only receives messages with that routing key... _amqp-exchange-type-topic:Topic exchanges~~~~~~~~~~~~~~~Topic exchanges matches routing keys using dot-separated words, and thewildcard characters: ``*`` (matches a single word), and ``#`` (matcheszero or more words).With routing keys like ``usa.news``, ``usa.weather``, ``norway.news`` and``norway.weather``, bindings could be ``*.news`` (all news), ``usa.#`` (allitems in the USA) or ``usa.weather`` (all USA weather items)... _amqp-api:Related API commands--------------------.. method:: exchange.declare(exchange_name, type, passive,                             durable, auto_delete, internal)    Declares an exchange by name.    :keyword passive: Passive means the exchange won't be created, but you        can use this to check if the exchange already exists.    :keyword durable: Durable exchanges are persistent.  That is - they survive        a broker restart.    :keyword auto_delete: This means the queue will be deleted by the broker        when there are no more queues using it... method:: queue.declare(queue_name, passive, durable, exclusive, auto_delete)    Declares a queue by name.    Exclusive queues can only be consumed from by the current connection.    Exclusive also implies `auto_delete`... method:: queue.bind(queue_name, exchange_name, routing_key)    Binds a queue to an exchange with a routing key.    Unbound queues will not receive messages, so this is necessary... method:: queue.delete(name, if_unused=False, if_empty=False)    Deletes a queue and its binding... method:: exchange.delete(name, if_unused=False)    Deletes an exchange... note::    Declaring does not necessarily mean "create".  When you declare you    *assert* that the entity exists and that it's operable.  There is no    rule as to whom should initially create the exchange/queue/binding,    whether consumer or producer.  Usually the first one to need it will    be the one to create it... _amqp-api-hands-on:Hands-on with the API---------------------Celery comes with a tool called :program:`camqadm` (short for Celery AMQ Admin).It's used for command-line access to the AMQP API, enabling access toadministration tasks like creating/deleting queues and exchanges, purgingqueues or sending messages.You can write commands directly in the arguments to :program:`camqadm`,or just start with no arguments to start it in shell-mode::    $ camqadm    -> connecting to amqp://guest@localhost:5672/.    -> connected.    1>Here ``1>`` is the prompt.  The number 1, is the number of commands youhave executed so far.  Type ``help`` for a list of commands available.It also supports auto-completion, so you can start typing a command and thenhit the `tab` key to show a list of possible matches.Let's create a queue we can send messages to::    1> exchange.declare testexchange direct    ok.    2> queue.declare testqueue    ok. queue:testqueue messages:0 consumers:0.    3> queue.bind testqueue testexchange testkey    ok.This created the direct exchange ``testexchange``, and a queuenamed ``testqueue``.  The queue is bound to the exchange usingthe routing key ``testkey``.From now on all messages sent to the exchange ``testexchange`` with routingkey ``testkey`` will be moved to this queue.  We can send a message byusing the ``basic.publish`` command::    4> basic.publish "This is a message!" testexchange testkey    ok.Now that the message is sent we can retrieve it again.  We use the``basic.get``` command here, which polls for new messages on the queue.Pop a message off the queue::    5> basic.get testqueue    {'body': 'This is a message!',     'delivery_info': {'delivery_tag': 1,                       'exchange': u'testexchange',                       'message_count': 0,                       'redelivered': False,                       'routing_key': u'testkey'},     'properties': {}}AMQP uses acknowledgment to signify that a message has been receivedand processed successfully.  If the message has not been acknowledgedand consumer channel is closed, the message will be delivered toanother consumer.Note the delivery tag listed in the structure above; Within a connectionchannel, every received message has a unique delivery tag,This tag is used to acknowledge the message.  Also note thatdelivery tags are not unique across connections, so in another clientthe delivery tag `1` might point to a different message than in this channel.You can acknowledge the message we received using ``basic.ack``::    6> basic.ack 1    ok.To clean up after our test session we should delete the entities we created::    7> queue.delete testqueue    ok. 0 messages deleted.    8> exchange.delete testexchange    ok... _routing-tasks:Routing Tasks=============.. _routing-defining-queues:Defining queues---------------In Celery available queues are defined by the :setting:`CELERY_QUEUES` setting.Here's an example queue configuration with three queues;One for video, one for images and one default queue for everything else:.. code-block:: python    CELERY_QUEUES = {        "default": {            "exchange": "default",            "routing_key": "default"},        "videos": {            "exchange": "media",            "exchange_type": "topic",            "routing_key": "media.video",        },        "images": {            "exchange": "media",            "exchange_type": "topic",            "routing_key": "media.image",        }    }    CELERY_DEFAULT_QUEUE = "default"    CELERY_DEFAULT_EXCHANGE = "default"    CELERY_DEFAULT_EXCHANGE_TYPE = "direct"    CELERY_DEFAULT_ROUTING_KEY = "default"Here, the :setting:`CELERY_DEFAULT_QUEUE` will be used to route tasks thatdoesn't have an explicit route.The default exchange, exchange type and routing key will be used as thedefault routing values for tasks, and as the default values for entriesin :setting:`CELERY_QUEUES`... _routing-task-destination:Specifying task destination---------------------------The destination for a task is decided by the following (in order):1. The :ref:`routers` defined in :setting:`CELERY_ROUTES`.2. The routing arguments to :func:`Task.apply_async`.3. Routing related attributes defined on the :class:`~celery.task.base.Task`   itself.It is considered best practice to not hard-code these settings, but ratherleave that as configuration options by using :ref:`routers`;This is the most flexible approach, but sensible defaults can still be setas task attributes... _routers:Routers-------A router is a class that decides the routing options for a task.All you need to define a new router is to create a class with a``route_for_task`` method:.. code-block:: python    class MyRouter(object):        def route_for_task(self, task, args=None, kwargs=None):            if task == "myapp.tasks.compress_video":                return {"exchange": "video",                        "exchange_type": "topic",                        "routing_key": "video.compress"}            return NoneIf you return the ``queue`` key, it will expand with the defined settings ofthat queue in :setting:`CELERY_QUEUES`::    {"queue": "video", "routing_key": "video.compress"}    becomes -->        {"queue": "video",         "exchange": "video",         "exchange_type": "topic",         "routing_key": "video.compress"}You install router classes by adding them to the :setting:`CELERY_ROUTES`setting::    CELERY_ROUTES = (MyRouter(), )Router classes can also be added by name::    CELERY_ROUTES = ("myapp.routers.MyRouter", )For simple task name -> route mappings like the router example above,you can simply drop a dict into :setting:`CELERY_ROUTES` to get thesame behavior:.. code-block:: python    CELERY_ROUTES = ({"myapp.tasks.compress_video": {                            "queue": "video",                            "routing_key": "video.compress"                     }}, )The routers will then be traversed in order, it will stop at the first routerreturning a true value, and use that as the final route for the task.Broadcast---------Celery can also support broadcast routing.Here is an example exchange ``bcast`` that uses this:.. code-block:: python    from kombu.common import Broadcast    CELERY_QUEUES = (Broadcast("broadcast_tasks"), )    CELERY_ROUTES = {"tasks.reload_cache": "broadcast_tasks"}Now the ``tasks.reload_tasks`` task will be sent to everyworker consuming from this queue... admonition:: Broadcast & Results    Note that Celery result does not define what happens if two    tasks have the same task_id.  If the same task is distributed to more    than one worker, then the state history may not be preserved.    It is a good idea to set the ``task.ignore_result`` attribute in    this case.
 |