routing.rst 17 KB

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