routing.rst 18 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587
  1. .. _guide-routing:
  2. ===============
  3. Routing Tasks
  4. ===============
  5. .. note::
  6. Alternate routing concepts like topic and fanout may not be
  7. available for all transports, please consult the `transport comparison table`_.
  8. .. _`transport comparison table`:
  9. http://kombu.readthedocs.org/en/latest/introduction.html#transport-comparison
  10. .. contents::
  11. :local:
  12. .. _routing-basics:
  13. Basics
  14. ======
  15. .. _routing-automatic:
  16. Automatic routing
  17. -----------------
  18. The simplest way to do routing is to use the
  19. :setting:`CELERY_CREATE_MISSING_QUEUES` setting (on by default).
  20. With this setting on, a named queue that is not already defined in
  21. :setting:`CELERY_QUEUES` will be created automatically. This makes it easy to
  22. perform simple routing tasks.
  23. Say you have two servers, `x`, and `y` that handles regular tasks,
  24. and one server `z`, that only handles feed related tasks. You can use this
  25. configuration::
  26. CELERY_ROUTES = {'feed.tasks.import_feed': {'queue': 'feeds'}}
  27. With this route enabled import feed tasks will be routed to the
  28. `"feeds"` queue, while all other tasks will be routed to the default queue
  29. (named `"celery"` for historical reasons).
  30. Now you can start server `z` to only process the feeds queue like this:
  31. .. code-block:: bash
  32. user@z:/$ celery worker -Q feeds
  33. You can specify as many queues as you want, so you can make this server
  34. process the default queue as well:
  35. .. code-block:: bash
  36. user@z:/$ celery worker -Q feeds,celery
  37. .. _routing-changing-default-queue:
  38. Changing the name of the default queue
  39. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  40. You can change the name of the default queue by using the following
  41. configuration:
  42. .. code-block:: python
  43. from kombu import Exchange, Queue
  44. CELERY_DEFAULT_QUEUE = 'default'
  45. CELERY_QUEUES = (
  46. Queue('default', Exchange('default'), routing_key='default'),
  47. )
  48. .. _routing-autoqueue-details:
  49. How the queues are defined
  50. ~~~~~~~~~~~~~~~~~~~~~~~~~~
  51. The point with this feature is to hide the complex AMQP protocol for users
  52. with only basic needs. However -- you may still be interested in how these queues
  53. are declared.
  54. A queue named `"video"` will be created with the following settings:
  55. .. code-block:: python
  56. {'exchange': 'video',
  57. 'exchange_type': 'direct',
  58. 'routing_key': 'video'}
  59. The non-AMQP backends like `ghettoq` does not support exchanges, so they
  60. require the exchange to have the same name as the queue. Using this design
  61. ensures it will work for them as well.
  62. .. _routing-manual:
  63. Manual routing
  64. --------------
  65. Say you have two servers, `x`, and `y` that handles regular tasks,
  66. and one server `z`, that only handles feed related tasks, you can use this
  67. configuration:
  68. .. code-block:: python
  69. from kombu import Queue
  70. CELERY_DEFAULT_QUEUE = 'default'
  71. CELERY_QUEUES = (
  72. Queue('default', routing_key='task.#'),
  73. Queue('feed_tasks', routing_key='feed.#'),
  74. )
  75. CELERY_DEFAULT_EXCHANGE = 'tasks'
  76. CELERY_DEFAULT_EXCHANGE_TYPE = 'topic'
  77. CELERY_DEFAULT_ROUTING_KEY = 'task.default'
  78. :setting:`CELERY_QUEUES` is a list of :class:`~kombu.entitity.Queue`
  79. instances.
  80. If you don't set the exchange or exchange type values for a key, these
  81. will be taken from the :setting:`CELERY_DEFAULT_EXCHANGE` and
  82. :setting:`CELERY_DEFAULT_EXCHANGE_TYPE` settings.
  83. To route a task to the `feed_tasks` queue, you can add an entry in the
  84. :setting:`CELERY_ROUTES` setting:
  85. .. code-block:: python
  86. CELERY_ROUTES = {
  87. 'feeds.tasks.import_feed': {
  88. 'queue': 'feed_tasks',
  89. 'routing_key': 'feed.import',
  90. },
  91. }
  92. You can also override this using the `routing_key` argument to
  93. :meth:`Task.apply_async`, or :func:`~celery.execute.send_task`:
  94. >>> from feeds.tasks import import_feed
  95. >>> import_feed.apply_async(args=['http://cnn.com/rss'],
  96. ... queue='feed_tasks',
  97. ... routing_key='feed.import')
  98. To make server `z` consume from the feed queue exclusively you can
  99. start it with the ``-Q`` option:
  100. .. code-block:: bash
  101. user@z:/$ celery worker -Q feed_tasks --hostname=z.example.com
  102. Servers `x` and `y` must be configured to consume from the default queue:
  103. .. code-block:: bash
  104. user@x:/$ celery worker -Q default --hostname=x.example.com
  105. user@y:/$ celery worker -Q default --hostname=y.example.com
  106. If you want, you can even have your feed processing worker handle regular
  107. tasks as well, maybe in times when there's a lot of work to do:
  108. .. code-block:: python
  109. user@z:/$ celery worker -Q feed_tasks,default --hostname=z.example.com
  110. If you have another queue but on another exchange you want to add,
  111. just specify a custom exchange and exchange type:
  112. .. code-block:: python
  113. from kombu import Exchange, Queue
  114. CELERY_QUEUES = (
  115. Queue('feed_tasks', routing_key='feed.#'),
  116. Queue('regular_tasks', routing_key='task.#'),
  117. Queue('image_tasks', exchange=Exchange('mediatasks', type='direct'),
  118. routing_key='image.compress'),
  119. )
  120. If you're confused about these terms, you should read up on AMQP.
  121. .. seealso::
  122. In addition to the :ref:`amqp-primer` below, there's
  123. `Rabbits and Warrens`_, an excellent blog post describing queues and
  124. exchanges. There's also AMQP in 10 minutes*: `Flexible Routing Model`_,
  125. and `Standard Exchange Types`_. For users of RabbitMQ the `RabbitMQ FAQ`_
  126. could be useful as a source of information.
  127. .. _`Rabbits and Warrens`: http://blogs.digitar.com/jjww/2009/01/rabbits-and-warrens/
  128. .. _`Flexible Routing Model`: http://bit.ly/95XFO1
  129. .. _`Standard Exchange Types`: http://bit.ly/EEWca
  130. .. _`RabbitMQ FAQ`: http://www.rabbitmq.com/faq.html
  131. .. _amqp-primer:
  132. AMQP Primer
  133. ===========
  134. Messages
  135. --------
  136. A message consists of headers and a body. Celery uses headers to store
  137. the content type of the message and its content encoding. The
  138. content type is usually the serialization format used to serialize the
  139. message. The body contains the name of the task to execute, the
  140. task id (UUID), the arguments to apply it with and some additional
  141. metadata -- like the number of retries or an ETA.
  142. This is an example task message represented as a Python dictionary:
  143. .. code-block:: python
  144. {'task': 'myapp.tasks.add',
  145. 'id': '54086c5e-6193-4575-8308-dbab76798756',
  146. 'args': [4, 4],
  147. 'kwargs': {}}
  148. .. _amqp-producers-consumers-brokers:
  149. Producers, consumers and brokers
  150. --------------------------------
  151. The client sending messages is typically called a *publisher*, or
  152. a *producer*, while the entity receiving messages is called
  153. a *consumer*.
  154. The *broker* is the message server, routing messages from producers
  155. to consumers.
  156. You are likely to see these terms used a lot in AMQP related material.
  157. .. _amqp-exchanges-queues-keys:
  158. Exchanges, queues and routing keys.
  159. -----------------------------------
  160. 1. Messages are sent to exchanges.
  161. 2. An exchange routes messages to one or more queues. Several exchange types
  162. exists, providing different ways to do routing, or implementing
  163. different messaging scenarios.
  164. 3. The message waits in the queue until someone consumes it.
  165. 4. The message is deleted from the queue when it has been acknowledged.
  166. The steps required to send and receive messages are:
  167. 1. Create an exchange
  168. 2. Create a queue
  169. 3. Bind the queue to the exchange.
  170. Celery automatically creates the entities necessary for the queues in
  171. :setting:`CELERY_QUEUES` to work (except if the queue's `auto_declare`
  172. setting is set to :const:`False`).
  173. Here's an example queue configuration with three queues;
  174. One for video, one for images and one default queue for everything else:
  175. .. code-block:: python
  176. from kombu import Exchange, Queue
  177. CELERY_QUEUES = (
  178. Queue('default', Exchange('default'), routing_key='default'),
  179. Queue('videos', Exchange('media'), routing_key='media.video'),
  180. Queue('images', Exchange('media'), routing_key='media.image'),
  181. )
  182. CELERY_DEFAULT_QUEUE = 'default'
  183. CELERY_DEFAULT_EXCHANGE_TYPE = 'direct'
  184. CELERY_DEFAULT_ROUTING_KEY = 'default'
  185. .. _amqp-exchange-types:
  186. Exchange types
  187. --------------
  188. The exchange type defines how the messages are routed through the exchange.
  189. The exchange types defined in the standard are `direct`, `topic`,
  190. `fanout` and `headers`. Also non-standard exchange types are available
  191. as plug-ins to RabbitMQ, like the `last-value-cache plug-in`_ by Michael
  192. Bridgen.
  193. .. _`last-value-cache plug-in`:
  194. http://github.com/squaremo/rabbitmq-lvc-plugin
  195. .. _amqp-exchange-type-direct:
  196. Direct exchanges
  197. ~~~~~~~~~~~~~~~~
  198. Direct exchanges match by exact routing keys, so a queue bound by
  199. the routing key `video` only receives messages with that routing key.
  200. .. _amqp-exchange-type-topic:
  201. Topic exchanges
  202. ~~~~~~~~~~~~~~~
  203. Topic exchanges matches routing keys using dot-separated words, and the
  204. wildcard characters: ``*`` (matches a single word), and ``#`` (matches
  205. zero or more words).
  206. With routing keys like ``usa.news``, ``usa.weather``, ``norway.news`` and
  207. ``norway.weather``, bindings could be ``*.news`` (all news), ``usa.#`` (all
  208. items in the USA) or ``usa.weather`` (all USA weather items).
  209. .. _amqp-api:
  210. Related API commands
  211. --------------------
  212. .. method:: exchange.declare(exchange_name, type, passive,
  213. durable, auto_delete, internal)
  214. Declares an exchange by name.
  215. :keyword passive: Passive means the exchange won't be created, but you
  216. can use this to check if the exchange already exists.
  217. :keyword durable: Durable exchanges are persistent. That is - they survive
  218. a broker restart.
  219. :keyword auto_delete: This means the queue will be deleted by the broker
  220. when there are no more queues using it.
  221. .. method:: queue.declare(queue_name, passive, durable, exclusive, auto_delete)
  222. Declares a queue by name.
  223. Exclusive queues can only be consumed from by the current connection.
  224. Exclusive also implies `auto_delete`.
  225. .. method:: queue.bind(queue_name, exchange_name, routing_key)
  226. Binds a queue to an exchange with a routing key.
  227. Unbound queues will not receive messages, so this is necessary.
  228. .. method:: queue.delete(name, if_unused=False, if_empty=False)
  229. Deletes a queue and its binding.
  230. .. method:: exchange.delete(name, if_unused=False)
  231. Deletes an exchange.
  232. .. note::
  233. Declaring does not necessarily mean "create". When you declare you
  234. *assert* that the entity exists and that it's operable. There is no
  235. rule as to whom should initially create the exchange/queue/binding,
  236. whether consumer or producer. Usually the first one to need it will
  237. be the one to create it.
  238. .. _amqp-api-hands-on:
  239. Hands-on with the API
  240. ---------------------
  241. Celery comes with a tool called :program:`celery amqp`
  242. that is used for command line access to the AMQP API, enabling access to
  243. administration tasks like creating/deleting queues and exchanges, purging
  244. queues or sending messages. It can also be used for non-AMQP brokers,
  245. but different implementation may not implement all commands.
  246. You can write commands directly in the arguments to :program:`celery amqp`,
  247. or just start with no arguments to start it in shell-mode:
  248. .. code-block:: bash
  249. $ celery amqp
  250. -> connecting to amqp://guest@localhost:5672/.
  251. -> connected.
  252. 1>
  253. Here ``1>`` is the prompt. The number 1, is the number of commands you
  254. have executed so far. Type ``help`` for a list of commands available.
  255. It also supports auto-completion, so you can start typing a command and then
  256. hit the `tab` key to show a list of possible matches.
  257. Let's create a queue you can send messages to:
  258. .. code-block:: bash
  259. $ celery amqp
  260. 1> exchange.declare testexchange direct
  261. ok.
  262. 2> queue.declare testqueue
  263. ok. queue:testqueue messages:0 consumers:0.
  264. 3> queue.bind testqueue testexchange testkey
  265. ok.
  266. This created the direct exchange ``testexchange``, and a queue
  267. named ``testqueue``. The queue is bound to the exchange using
  268. the routing key ``testkey``.
  269. From now on all messages sent to the exchange ``testexchange`` with routing
  270. key ``testkey`` will be moved to this queue. You can send a message by
  271. using the ``basic.publish`` command::
  272. 4> basic.publish 'This is a message!' testexchange testkey
  273. ok.
  274. Now that the message is sent you can retrieve it again. You can use the
  275. ``basic.get``` command here, which polls for new messages on the queue
  276. (which is alright for maintainence tasks, for services you'd want to use
  277. ``basic.consume`` instead)
  278. Pop a message off the queue::
  279. 5> basic.get testqueue
  280. {'body': 'This is a message!',
  281. 'delivery_info': {'delivery_tag': 1,
  282. 'exchange': u'testexchange',
  283. 'message_count': 0,
  284. 'redelivered': False,
  285. 'routing_key': u'testkey'},
  286. 'properties': {}}
  287. AMQP uses acknowledgment to signify that a message has been received
  288. and processed successfully. If the message has not been acknowledged
  289. and consumer channel is closed, the message will be delivered to
  290. another consumer.
  291. Note the delivery tag listed in the structure above; Within a connection
  292. channel, every received message has a unique delivery tag,
  293. This tag is used to acknowledge the message. Also note that
  294. delivery tags are not unique across connections, so in another client
  295. the delivery tag `1` might point to a different message than in this channel.
  296. You can acknowledge the message you received using ``basic.ack``::
  297. 6> basic.ack 1
  298. ok.
  299. To clean up after our test session you should delete the entities you created::
  300. 7> queue.delete testqueue
  301. ok. 0 messages deleted.
  302. 8> exchange.delete testexchange
  303. ok.
  304. .. _routing-tasks:
  305. Routing Tasks
  306. =============
  307. .. _routing-defining-queues:
  308. Defining queues
  309. ---------------
  310. In Celery available queues are defined by the :setting:`CELERY_QUEUES` setting.
  311. Here's an example queue configuration with three queues;
  312. One for video, one for images and one default queue for everything else:
  313. .. code-block:: python
  314. default_exchange = Exchange('default', type='direct')
  315. media_exchange = Exchange('media', type='direct')
  316. CELERY_QUEUES = (
  317. Queue('default', default_exchange, routing_key='default'),
  318. Queue('videos', media_exchange, routing_key='media.video'),
  319. Queue('images', media_exchange, routing_key='media.image')
  320. )
  321. CELERY_DEFAULT_QUEUE = 'default'
  322. CELERY_DEFAULT_EXCHANGE = 'default'
  323. CELERY_DEFAULT_ROUTING_KEY = 'default'
  324. Here, the :setting:`CELERY_DEFAULT_QUEUE` will be used to route tasks that
  325. doesn't have an explicit route.
  326. The default exchange, exchange type and routing key will be used as the
  327. default routing values for tasks, and as the default values for entries
  328. in :setting:`CELERY_QUEUES`.
  329. .. _routing-task-destination:
  330. Specifying task destination
  331. ---------------------------
  332. The destination for a task is decided by the following (in order):
  333. 1. The :ref:`routers` defined in :setting:`CELERY_ROUTES`.
  334. 2. The routing arguments to :func:`Task.apply_async`.
  335. 3. Routing related attributes defined on the :class:`~celery.task.base.Task`
  336. itself.
  337. It is considered best practice to not hard-code these settings, but rather
  338. leave that as configuration options by using :ref:`routers`;
  339. This is the most flexible approach, but sensible defaults can still be set
  340. as task attributes.
  341. .. _routers:
  342. Routers
  343. -------
  344. A router is a class that decides the routing options for a task.
  345. All you need to define a new router is to create a class with a
  346. ``route_for_task`` method:
  347. .. code-block:: python
  348. class MyRouter(object):
  349. def route_for_task(self, task, args=None, kwargs=None):
  350. if task == 'myapp.tasks.compress_video':
  351. return {'exchange': 'video',
  352. 'exchange_type': 'topic',
  353. 'routing_key': 'video.compress'}
  354. return None
  355. If you return the ``queue`` key, it will expand with the defined settings of
  356. that queue in :setting:`CELERY_QUEUES`:
  357. .. code-block:: javascript
  358. {'queue': 'video', 'routing_key': 'video.compress'}
  359. becomes -->
  360. .. code-block:: javascript
  361. {'queue': 'video',
  362. 'exchange': 'video',
  363. 'exchange_type': 'topic',
  364. 'routing_key': 'video.compress'}
  365. You install router classes by adding them to the :setting:`CELERY_ROUTES`
  366. setting::
  367. CELERY_ROUTES = (MyRouter(), )
  368. Router classes can also be added by name::
  369. CELERY_ROUTES = ('myapp.routers.MyRouter', )
  370. For simple task name -> route mappings like the router example above,
  371. you can simply drop a dict into :setting:`CELERY_ROUTES` to get the
  372. same behavior:
  373. .. code-block:: python
  374. CELERY_ROUTES = ({'myapp.tasks.compress_video': {
  375. 'queue': 'video',
  376. 'routing_key': 'video.compress'
  377. }}, )
  378. The routers will then be traversed in order, it will stop at the first router
  379. returning a true value, and use that as the final route for the task.
  380. Broadcast
  381. ---------
  382. Celery can also support broadcast routing.
  383. Here is an example exchange ``broadcast_tasks`` that delivers
  384. copies of tasks to all workers connected to it:
  385. .. code-block:: python
  386. from kombu.common import Broadcast
  387. CELERY_QUEUES = (Broadcast('broadcast_tasks'), )
  388. CELERY_ROUTES = {'tasks.reload_cache': {'queue': 'broadcast_tasks'}}
  389. Now the ``tasks.reload_tasks`` task will be sent to every
  390. worker consuming from this queue.
  391. .. admonition:: Broadcast & Results
  392. Note that Celery result does not define what happens if two
  393. tasks have the same task_id. If the same task is distributed to more
  394. than one worker, then the state history may not be preserved.
  395. It is a good idea to set the ``task.ignore_result`` attribute in
  396. this case.