whatsnew-4.0.rst 59 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863
  1. .. _whatsnew-4.0:
  2. ===========================================
  3. What's new in Celery 4.0 (0Today8)
  4. ===========================================
  5. :Author: Ask Solem (``ask at celeryproject.org``)
  6. .. sidebar:: Change history
  7. What's new documents describe the changes in major versions,
  8. we also have a :ref:`changelog` that lists the changes in bugfix
  9. releases (0.0.x), while older series are archived under the :ref:`history`
  10. section.
  11. Celery is a simple, flexible, and reliable distributed system to
  12. process vast amounts of messages, while providing operations with
  13. the tools required to maintain such a system.
  14. It's a task queue with focus on real-time processing, while also
  15. supporting task scheduling.
  16. Celery has a large and diverse community of users and contributors,
  17. you should come join us :ref:`on IRC <irc-channel>`
  18. or :ref:`our mailing-list <mailing-list>`.
  19. To read more about Celery you should go read the :ref:`introduction <intro>`.
  20. While this version is backward compatible with previous versions
  21. it's important that you read the following section.
  22. This version is officially supported on CPython 2.7, 3.4, and 3.5.
  23. and also supported on PyPy.
  24. .. _`website`: http://celeryproject.org/
  25. .. topic:: Table of Contents
  26. Make sure you read the important notes before upgrading to this version.
  27. .. contents::
  28. :local:
  29. :depth: 2
  30. Preface
  31. =======
  32. XXX To be written
  33. Wall of Contributors
  34. --------------------
  35. XXX Needs update
  36. Aaron McMillin, Adam Renberg, Adrien Guinet, Ahmet Demir, Aitor Gómez-Goiri,
  37. Albert Wang, Alex Koshelev, Alex Rattray, Alex Williams, Alexander Koshelev,
  38. Alexander Lebedev, Alexander Oblovatniy, Alexey Kotlyarov, Ali Bozorgkhan,
  39. Alice Zoë Bevan–McGregor, Allard Hoeve, Alman One, Andrea Rabbaglietti,
  40. Andrea Rosa, Andrei Fokau, Andrew Rodionoff, Andriy Yurchuk,
  41. Aneil Mallavarapu, Areski Belaid, Artyom Koval, Ask Solem, Balthazar Rouberol,
  42. Berker Peksag, Bert Vanderbauwhede, Brian Bouterse, Chris Duryee, Chris Erway,
  43. Chris Harris, Chris Martin, Corey Farwell, Craig Jellick, Cullen Rhodes,
  44. Dallas Marlow, Daniel Wallace, Danilo Bargen, Davanum Srinivas, Dave Smith,
  45. David Baumgold, David Harrigan, David Pravec, Dennis Brakhane, Derek Anderson,
  46. Dmitry Malinovsky, Dudás Ádám, Dustin J. Mitchell, Ed Morley, Fatih Sucu,
  47. Feanil Patel, Felix Schwarz, Fernando Rocha, Flavio Grossi, Frantisek Holop,
  48. Gao Jiangmiao, Gerald Manipon, Gilles Dartiguelongue, Gino Ledesma,
  49. Hank John, Hogni Gylfason, Ilya Georgievsky, Ionel Cristian Mărieș,
  50. James Pulec, Jared Lewis, Jason Veatch, Jasper Bryant-Greene, Jeremy Tillman,
  51. Jocelyn Delalande, Joe Jevnik, John Anderson, John Kirkham, John Whitlock,
  52. Joshua Harlow, Juan Rossi, Justin Patrin, Kai Groner, Kevin Harvey,
  53. Konstantinos Koukopoulos, Kouhei Maeda, Kracekumar Ramaraju,
  54. Krzysztof Bujniewicz, Latitia M. Haskins, Len Buckens, Lorenzo Mancini,
  55. Lucas Wiman, Luke Pomfrey, Marcio Ribeiro, Marin Atanasov Nikolov,
  56. Mark Parncutt, Maxime Vdb, Mher Movsisyan, Michael (:github_user:`michael-k`),
  57. Michael Duane Mooring, Michael Permana, Mickaël Penhard, Mike Attwood,
  58. Morton Fox, Môshe van der Sterre, Nat Williams, Nathan Van Gheem, Nik Nyby,
  59. Omer Katz, Omer Korner, Ori Hoch, Paul Pearce, Paulo Bu, Philip Garnero,
  60. Piotr Maślanka, Radek Czajka, Raghuram Srinivasan, Randy Barlow,
  61. Rodolfo Carvalho, Roger Hu, Rongze Zhu, Ross Deane, Ryan Luckie,
  62. Rémy Greinhofer, Samuel Jaillet, Sergey Azovskov, Sergey Tikhonov,
  63. Seungha Kim, Steve Peak, Sukrit Khera, Tadej Janež, Tewfik Sadaoui,
  64. Thomas French, Thomas Grainger, Tobias Schottdorf, Tocho Tochev,
  65. Valentyn Klindukh, Vic Kumar, Vladimir Bolshakov, Vladimir Gorbunov,
  66. Wayne Chang, Wil Langford, Will Thompson, William King, Yury Selivanov,
  67. Zoran Pavlovic, 許邱翔, :github_user:`allenling`, :github_user:`bee-keeper`,
  68. :github_user:`ffeast`, :github_user:`flyingfoxlee`, :github_user:`gdw2`,
  69. :github_user:`gitaarik`, :github_user:`hankjin`, :github_user:`m-vdb`,
  70. :github_user:`mdk`, :github_user:`nokrik`, :github_user:`ocean1`,
  71. :github_user:`orlo666`, :github_user:`raducc`, :github_user:`wanglei`,
  72. :github_user:`worldexception`.
  73. .. _v400-important:
  74. Important Notes
  75. ===============
  76. Dropped support for Python 2.6
  77. ------------------------------
  78. Celery now requires Python 2.7 or later,
  79. and also drops support for Python 3.3 so supported versions are:
  80. - CPython 2.7
  81. - CPython 3.4
  82. - CPython 3.5
  83. - PyPy 5.4 (``pypy2``)
  84. - PyPy 5.5-alpha (``pypy3``)
  85. Last major version to support Python 2
  86. --------------------------------------
  87. Starting from Celery 5.0 only Python 3.5+ will be supported.
  88. To make sure you're not affected by this change you should pin
  89. the Celery version in your requirements file, either to a specific
  90. version: ``celery==4.0.0``, or a range: ``celery>=4.0,<5.0``.
  91. Dropping support for Python 2 will enable us to remove massive
  92. amounts of compatibility code, and going with Python 3.5 allows
  93. us to take advantage of typing, async/await, asyncio, and similar
  94. concepts there's no alternative for in older versions.
  95. Celery 4.x will continue to work on Python 2.7, 3.4, 3.5; just as Celery 3.x
  96. still works on Python 2.6.
  97. Django support
  98. --------------
  99. Celery now supports Django 1.8 and newer versions.
  100. Removed features
  101. ----------------
  102. - Microsoft Windows is no longer supported.
  103. The test suite is passing, and Celery seems to be working with Windows,
  104. but we make no guarantees as we are unable to diagnose issues on this
  105. platform.
  106. - Jython is no longer supported.
  107. Features removed for simplicity
  108. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  109. - Webhook task machinery (``celery.task.http``) has been removed.
  110. Nowadays it's easy to use the :pypi:`requests` module to write
  111. webhook tasks manually. We would love to use requests but we
  112. are simply unable to as there's a very vocal 'anti-dependency'
  113. mob in the Python community
  114. If you need backwards compatibility
  115. you can simply copy + paste the 3.1 version of the module and make sure
  116. it's imported by the worker:
  117. https://github.com/celery/celery/blob/3.1/celery/task/http.py
  118. - Task no longer sends error emails.
  119. This also removes support for ``app.mail_admins``, and any functionality
  120. related to sending emails.
  121. - ``celery.contrib.batches`` has been removed.
  122. This was an experimental feature, so not covered by our deprecation
  123. timeline guarantee.
  124. You can copy and pase the existing batches code for use within your projects:
  125. https://github.com/celery/celery/blob/3.1/celery/contrib/batches.py
  126. Features removed for lack of funding
  127. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  128. We announced with the 3.1 release that some transports were
  129. moved to experimental status, and that there'd be no official
  130. support for the transports, citing a lack of resources.
  131. As this subtle hint for the need of funding failed
  132. we've removed them completely, breaking backwards compatibility.
  133. - Using the Django ORM as a broker is no longer supported.
  134. - Using SQLAlchemy as a broker is no longer supported.
  135. - Using CouchDB as a broker is no longer supported.
  136. - Using IronMQ as a broker is no longer supported.
  137. - Using Beanstalk as a broker is no longer supported.
  138. In addition some features have been removed completely so that
  139. attempting to use them will raise an exception:
  140. - The ``--autoreload`` feature has been removed.
  141. This was an experimental feature, and not covered by our deprecation
  142. timeline guarantee. The flag is removed completely so the worker
  143. will crash at startup when present. Luckily this
  144. flag isn't used in production systems.
  145. - The experimental ``threads`` pool is no longer supported and has been removed.
  146. - The force_execv feature is no longer supported.
  147. The ``celery worker`` command now ignores the ``--no-execv``,
  148. ``--force-execv``, and the ``CELERYD_FORCE_EXECV`` setting.
  149. This flag will be removed completely in 5.0 and the worker
  150. will raise an error.
  151. - The old legacy "amqp" result backend has been deprecated, and will
  152. be removed in Celery 5.0.
  153. Please use the ``rpc`` result backend for RPC-style calls, and a
  154. persistent result backend for multi-consumer results.
  155. **Now to the good news**...
  156. New Task Message Protocol
  157. -------------------------
  158. .. :sha:`e71652d384b1b5df2a4e6145df9f0efb456bc71c`
  159. This version introduces a brand new task message protocol,
  160. the first major change to the protocol since the beginning of the project.
  161. The new protocol is enabled by default in this version and since the new
  162. version isn't backwards compatible you have to be careful when upgrading.
  163. The 3.1.24 version was released to add compatibility with the new protocol
  164. so the easiest way to upgrade is to upgrade to that version first, then
  165. upgrade to 4.0 in a second deployment.
  166. If you wish to keep using the old protocol you may also configure
  167. the protocol version number used:
  168. .. code-block:: python
  169. app = Celery()
  170. app.conf.task_protocol = 1
  171. Read more about the features available in the new protocol in the news
  172. section found later in this document.
  173. Lowercase setting names
  174. -----------------------
  175. In the pursuit of beauty all settings are now renamed to be in all
  176. lowercase and some setting names have been renamed for consistency.
  177. This change is fully backwards compatible so you can still use the uppercase
  178. setting names, but we would like you to upgrade as soon as possible and
  179. you can this automatically using the :program:`celery upgrade settings`
  180. command:
  181. .. code-block:: console
  182. $ celery upgrade settings proj/settings.py
  183. This command will modify your module in-place to use the new lower-case
  184. names (if you want uppercase with a "``CELERY``" prefix see block below),
  185. and save a backup in :file:`proj/settings.py.orig`.
  186. .. admonition:: For Django users and others who want to keep uppercase names
  187. If you're loading Celery configuration from the Django settings module
  188. then you'll want to keep using the uppercase names.
  189. You also want to use a ``CELERY_`` prefix so that no Celery settings
  190. collide with Django settings used by other apps.
  191. To do this, you'll first need to convert your settings file
  192. to use the new consistent naming scheme, and add the prefix to all
  193. Celery related settings:
  194. .. code-block:: console
  195. $ celery upgrade settings --django proj/settings.py
  196. After upgrading the settings file, you need to set the prefix explicitly
  197. in your ``proj/celery.py`` module:
  198. .. code-block:: python
  199. app.config_from_object('django.conf:settings', namespace='CELERY')
  200. You can find the most up to date Django Celery integration example
  201. here: :ref:`django-first-steps`.
  202. Note that this will also add a prefix to settings that didn't previously
  203. have one, like ``BROKER_URL``.
  204. Luckily you don't have to manually change the files, as
  205. the :program:`celery upgrade settings --django` program should do the
  206. right thing.
  207. The loader will try to detect if your configuration is using the new format,
  208. and act accordingly, but this also means you're not allowed to mix and
  209. match new and old setting names, that's unless you provide a value for both
  210. alternatives.
  211. The major difference between previous versions, apart from the lower case
  212. names, are the renaming of some prefixes, like ``celerybeat_`` to ``beat_``,
  213. ``celeryd_`` to ``worker_``.
  214. The ``celery_`` prefix has also been removed, and task related settings
  215. from this name-space is now prefixed by ``task_``, worker related settings
  216. with ``worker_``.
  217. Apart from this most of the settings will be the same in lowercase, apart from
  218. a few special ones:
  219. ===================================== ==========================================================
  220. **Setting name** **Replace with**
  221. ===================================== ==========================================================
  222. ``CELERY_MAX_CACHED_RESULTS`` :setting:`result_cache_max`
  223. ``CELERY_MESSAGE_COMPRESSION`` :setting:`result_compression`/:setting:`task_compression`.
  224. ``CELERY_TASK_RESULT_EXPIRES`` :setting:`result_expires`
  225. ``CELERY_RESULT_DBURI`` :setting:`sqlalchemy_dburi`
  226. ``CELERY_RESULT_ENGINE_OPTIONS`` :setting:`sqlalchemy_engine_options`
  227. ``-*-_DB_SHORT_LIVED_SESSIONS`` :setting:`sqlalchemy_short_lived_sessions`
  228. ``CELERY_RESULT_DB_TABLE_NAMES`` :setting:`sqlalchemy_db_names`
  229. ``CELERY_ACKS_LATE`` :setting:`task_acks_late`
  230. ``CELERY_ALWAYS_EAGER`` :setting:`task_always_eager`
  231. ``CELERY_ANNOTATIONS`` :setting:`task_annotations`
  232. ``CELERY_MESSAGE_COMPRESSION`` :setting:`task_compression`
  233. ``CELERY_CREATE_MISSING_QUEUES`` :setting:`task_create_missing_queues`
  234. ``CELERY_DEFAULT_DELIVERY_MODE`` :setting:`task_default_delivery_mode`
  235. ``CELERY_DEFAULT_EXCHANGE`` :setting:`task_default_exchange`
  236. ``CELERY_DEFAULT_EXCHANGE_TYPE`` :setting:`task_default_exchange_type`
  237. ``CELERY_DEFAULT_QUEUE`` :setting:`task_default_queue`
  238. ``CELERY_DEFAULT_RATE_LIMIT`` :setting:`task_default_rate_limit`
  239. ``CELERY_DEFAULT_ROUTING_KEY`` :setting:`task_default_routing_key`
  240. ``-"-_EAGER_PROPAGATES_EXCEPTIONS`` :setting:`task_eager_propagates`
  241. ``CELERY_IGNORE_RESULT`` :setting:`task_ignore_result`
  242. ``CELERY_TASK_PUBLISH_RETRY`` :setting:`task_publish_retry`
  243. ``CELERY_TASK_PUBLISH_RETRY_POLICY`` :setting:`task_publish_retry_policy`
  244. ``CELERY_QUEUES`` :setting:`task_queues`
  245. ``CELERY_ROUTES`` :setting:`task_routes`
  246. ``CELERY_SEND_TASK_SENT_EVENT`` :setting:`task_send_sent_event`
  247. ``CELERY_TASK_SERIALIZER`` :setting:`task_serializer`
  248. ``CELERYD_TASK_SOFT_TIME_LIMIT`` :setting:`task_soft_time_limit`
  249. ``CELERYD_TASK_TIME_LIMIT`` :setting:`task_time_limit`
  250. ``CELERY_TRACK_STARTED`` :setting:`task_track_started`
  251. ``CELERY_DISABLE_RATE_LIMITS`` :setting:`worker_disable_rate_limits`
  252. ``CELERY_ENABLE_REMOTE_CONTROL`` :setting:`worker_enable_remote_control`
  253. ``CELERYD_SEND_EVENTS`` :setting:`worker_send_task_events`
  254. ===================================== ==========================================================
  255. You can see a full table of the changes in :ref:`conf-old-settings-map`.
  256. Json is now the default serializer
  257. ----------------------------------
  258. The time has finally come to end the reign of :mod:`pickle` as the default
  259. serialization mechanism, and json is the default serializer starting from this
  260. version.
  261. This change was :ref:`announced with the release of Celery 3.1
  262. <last-version-to-enable-pickle>`.
  263. If you're still depending on :mod:`pickle` being the default serializer,
  264. then you have to configure your app before upgrading to 4.0:
  265. .. code-block:: python
  266. task_serializer = 'pickle'
  267. result_serializer = 'pickle'
  268. accept_content = {'pickle'}
  269. The Json serializer now also supports some additional types:
  270. - :class:`~datetime.datetime`, :class:`~datetime.time`, :class:`~datetime.date`
  271. Converted to json text, in ISO-8601 format.
  272. - :class:`~decimal.Decimal`
  273. Converted to json text.
  274. - :class:`django.utils.functional.Promise`
  275. Django only: Lazy strings used for translation etc., are evaluated
  276. and conversion to a json type is attempted.
  277. - :class:`uuid.UUID`
  278. Converted to json text.
  279. You can also define a ``__json__`` method on your custom classes to support
  280. JSON serialization (must return a json compatible type):
  281. .. code-block:: python
  282. class Person:
  283. first_name = None
  284. last_name = None
  285. address = None
  286. def __json__(self):
  287. return {
  288. 'first_name': self.first_name,
  289. 'last_name': self.last_name,
  290. 'address': self.address,
  291. }
  292. The Task base class no longer automatically register tasks
  293. ----------------------------------------------------------
  294. The :class:`~@Task` class is no longer using a special meta-class
  295. that automatically registers the task in the task registry.
  296. Instead this is now handled by the :class:`@task` decorators.
  297. If you're still using class based tasks, then you need to register
  298. these manually:
  299. .. code-block:: python
  300. class CustomTask(Task):
  301. def run(self):
  302. print('running')
  303. app.tasks.register(CustomTask())
  304. The best practice is to use custom task classes only for overriding
  305. general behavior, and then using the task decorator to realize the task:
  306. .. code-block:: python
  307. @app.task(bind=True, base=CustomTask)
  308. def custom(self):
  309. print('running')
  310. This change also means that the ``abstract`` attribute of the task
  311. no longer has any effect.
  312. Task argument checking
  313. ----------------------
  314. The arguments of the task are now verified when calling the task,
  315. even asynchronously:
  316. .. code-block:: pycon
  317. >>> @app.task
  318. ... def add(x, y):
  319. ... return x + y
  320. >>> add.delay(8, 8)
  321. <AsyncResult: f59d71ca-1549-43e0-be41-4e8821a83c0c>
  322. >>> add.delay(8)
  323. Traceback (most recent call last):
  324. File "<stdin>", line 1, in <module>
  325. File "celery/app/task.py", line 376, in delay
  326. return self.apply_async(args, kwargs)
  327. File "celery/app/task.py", line 485, in apply_async
  328. check_arguments(*(args or ()), **(kwargs or {}))
  329. TypeError: add() takes exactly 2 arguments (1 given)
  330. You can disable the argument checking for any task by setting its
  331. :attr:`~@Task.typing` attribute to :const:`False`:
  332. .. code-block:: pycon
  333. >>> @app.task(typing=False)
  334. ... def add(x, y):
  335. ... return x + y
  336. Redis Events not backward compatible
  337. ------------------------------------
  338. The Redis ``fanout_patterns`` and ``fanout_prefix`` transport
  339. options are now enabled by default.
  340. Workers/monitors without these flags enabled won't be able to
  341. see workers with this flag disabled. They can still execute tasks,
  342. but they cannot receive each others monitoring messages.
  343. You can upgrade in a backward compatible manner by first configuring
  344. your 3.1 workers and monitors to enable the settings, before the final
  345. upgrade to 4.0:
  346. .. code-block:: python
  347. BROKER_TRANSPORT_OPTIONS = {
  348. 'fanout_patterns': True,
  349. 'fanout_prefix': True,
  350. }
  351. Django: Auto-discover now supports Django app configurations
  352. ------------------------------------------------------------
  353. The ``autodiscover_tasks()`` function can now be called without arguments,
  354. and the Django handler will automatically find your installed apps:
  355. .. code-block:: python
  356. app.autodiscover_tasks()
  357. The Django integration :ref:`example in the documentation
  358. <django-first-steps>` has been updated to use the argument-less call.
  359. This also ensures compatibility with the new, ehm, ``AppConfig`` stuff
  360. introduced in recent Django versions.
  361. Worker direct queues no longer use auto-delete
  362. ----------------------------------------------
  363. Workers/clients running 4.0 will no longer be able to send
  364. worker direct messages to workers running older versions, and vice versa.
  365. If you're relying on worker direct messages you should upgrade
  366. your 3.x workers and clients to use the new routing settings first,
  367. by replacing :func:`celery.utils.worker_direct` with this implementation:
  368. .. code-block:: python
  369. from kombu import Exchange, Queue
  370. worker_direct_exchange = Exchange('C.dq2')
  371. def worker_direct(hostname):
  372. return Queue(
  373. '{hostname}.dq2'.format(hostname),
  374. exchange=worker_direct_exchange,
  375. routing_key=hostname,
  376. )
  377. This feature closed Issue #2492.
  378. Old command-line programs removed
  379. ---------------------------------
  380. Installing Celery will no longer install the ``celeryd``,
  381. ``celerybeat`` and ``celeryd-multi`` programs.
  382. This was announced with the release of Celery 3.1, but you may still
  383. have scripts pointing to the old names, so make sure you update these
  384. to use the new umbrella command:
  385. +-------------------+--------------+-------------------------------------+
  386. | Program | New Status | Replacement |
  387. +===================+==============+=====================================+
  388. | ``celeryd`` | **REMOVED** | :program:`celery worker` |
  389. +-------------------+--------------+-------------------------------------+
  390. | ``celerybeat`` | **REMOVED** | :program:`celery beat` |
  391. +-------------------+--------------+-------------------------------------+
  392. | ``celeryd-multi`` | **REMOVED** | :program:`celery multi` |
  393. +-------------------+--------------+-------------------------------------+
  394. .. _v400-news:
  395. News
  396. ====
  397. New protocol highlights
  398. -----------------------
  399. The new protocol fixes many problems with the old one, and enables
  400. some long-requested features:
  401. - Most of the data are now sent as message headers, instead of being
  402. serialized with the message body.
  403. In version 1 of the protocol the worker always had to deserialize
  404. the message to be able to read task meta-data like the task id,
  405. name, etc. This also meant that the worker was forced to double-decode
  406. the data, first deserializing the message on receipt, serializing
  407. the message again to send to child process, then finally the child process
  408. deserializes the message again.
  409. Keeping the meta-data fields in the message headers means the worker
  410. doesn't actually have to decode the payload before delivering
  411. the task to the child process, and also that it's now possible
  412. for the worker to reroute a task written in a language different
  413. from Python to a different worker.
  414. - A new ``lang`` message header can be used to specify the programming
  415. language the task is written in.
  416. - Worker stores results for internal errors like ``ContentDisallowed``,
  417. and other deserialization errors.
  418. - Worker stores results and sends monitoring events for unregistered
  419. task errors.
  420. - Worker calls callbacks/errbacks even when the result is sent by the
  421. parent process (e.g., :exc:`WorkerLostError` when a child process
  422. terminates, deserialization errors, unregistered tasks).
  423. - A new ``origin`` header contains information about the process sending
  424. the task (worker node-name, or PID and host-name information).
  425. - A new ``shadow`` header allows you to modify the task name used in logs.
  426. This is useful for dispatch like patterns, like a task that calls
  427. any function using pickle (don't do this at home):
  428. .. code-block:: python
  429. from celery import Task
  430. from celery.utils.imports import qualname
  431. class call_as_task(Task):
  432. def shadow_name(self, args, kwargs, options):
  433. return 'call_as_task:{0}'.format(qualname(args[0]))
  434. def run(self, fun, *args, **kwargs):
  435. return fun(*args, **kwargs)
  436. call_as_task = app.tasks.register(call_as_task())
  437. - New ``argsrepr`` and ``kwargsrepr`` fields contain textual representations
  438. of the task arguments (possibly truncated) for use in logs, monitors, etc.
  439. This means the worker doesn't have to deserialize the message payload
  440. to display the task arguments for informational purposes.
  441. - Chains now use a dedicated ``chain`` field enabling support for chains
  442. of thousands and more tasks.
  443. - New ``parent_id`` and ``root_id`` headers adds information about
  444. a tasks relationship with other tasks.
  445. - ``parent_id`` is the task id of the task that called this task
  446. - ``root_id`` is the first task in the work-flow.
  447. These fields can be used to improve monitors like flower to group
  448. related messages together (like chains, groups, chords, complete
  449. work-flows, etc).
  450. - ``app.TaskProducer`` replaced by :meth:`@amqp.create_task_message` and
  451. :meth:`@amqp.send_task_message`.
  452. Dividing the responsibilities into creating and sending means that
  453. people who want to send messages using a Python AMQP client directly,
  454. doesn't have to implement the protocol.
  455. The :meth:`@amqp.create_task_message` method calls either
  456. :meth:`@amqp.as_task_v2`, or :meth:`@amqp.as_task_v1` depending
  457. on the configured task protocol, and returns a special
  458. :class:`~celery.app.amqp.task_message` tuple containing the
  459. headers, properties and body of the task message.
  460. .. seealso::
  461. The new task protocol is documented in full here:
  462. :ref:`message-protocol-task-v2`.
  463. Prefork: Tasks now log from the child process
  464. ---------------------------------------------
  465. Logging of task success/failure now happens from the child process
  466. executing the task. As a result logging utilities,
  467. like Sentry can get full information about tasks, including
  468. variables in the traceback stack.
  469. Prefork: One log-file per child process
  470. ---------------------------------------
  471. Init-scrips and :program:`celery multi` now uses the `%I` log file format
  472. option (e.g., :file:`/var/log/celery/%n%I.log`).
  473. This change was necessary to ensure each child
  474. process has a separate log file after moving task logging
  475. to the child process, as multiple processes writing to the same
  476. log file can cause corruption.
  477. You're encouraged to upgrade your init-scripts and
  478. :program:`celery multi` arguments to use this new option.
  479. Configure broker URL for read/write separately
  480. ----------------------------------------------
  481. New :setting:`broker_read_url` and :setting:`broker_write_url` settings
  482. have been added so that separate broker URLs can be provided
  483. for connections used for consuming/publishing.
  484. In addition to the configuration options, two new methods have been
  485. added the app API:
  486. - ``app.connection_for_read()``
  487. - ``app.connection_for_write()``
  488. These should now be used in place of ``app.connection()`` to specify
  489. the intent of the required connection.
  490. .. note::
  491. Two connection pools are available: ``app.pool`` (read), and
  492. ``app.producer_pool`` (write). The latter doesn't actually give connections
  493. but full :class:`kombu.Producer` instances.
  494. .. code-block:: python
  495. def publish_some_message(app, producer=None):
  496. with app.producer_or_acquire(producer) as producer:
  497. ...
  498. def consume_messages(app, connection=None):
  499. with app.connection_or_acquire(connection) as connection:
  500. ...
  501. Canvas Refactor
  502. ---------------
  503. The canvas/work-flow implementation have been heavily refactored
  504. to fix some long outstanding issues.
  505. .. :sha:`d79dcd8e82c5e41f39abd07ffed81ca58052bcd2`
  506. .. :sha:`1e9dd26592eb2b93f1cb16deb771cfc65ab79612`
  507. .. :sha:`e442df61b2ff1fe855881c1e2ff9acc970090f54`
  508. .. :sha:`0673da5c09ac22bdd49ba811c470b73a036ee776`
  509. - Error callbacks can now take real exception and traceback instances
  510. (Issue #2538).
  511. .. code-block:: pycon
  512. >>> add.s(2, 2).on_error(log_error.s()).delay()
  513. Where ``log_error`` could be defined as:
  514. .. code-block:: python
  515. @app.task
  516. def log_error(request, exc, traceback):
  517. with open(os.path.join('/var/errors', request.id), 'a') as fh:
  518. print('--\n\n{0} {1} {2}'.format(
  519. task_id, exc, traceback), file=fh)
  520. See :ref:`guide-canvas` for more examples.
  521. - Now unrolls groups within groups into a single group (Issue #1509).
  522. - chunks/map/starmap tasks now routes based on the target task
  523. - chords and chains can now be immutable.
  524. - Fixed bug where serialized signatures weren't converted back into
  525. signatures (Issue #2078)
  526. Fix contributed by **Ross Deane**.
  527. - Fixed problem where chains and groups didn't work when using JSON
  528. serialization (Issue #2076).
  529. Fix contributed by **Ross Deane**.
  530. - Creating a chord no longer results in multiple values for keyword
  531. argument 'task_id' (Issue #2225).
  532. Fix contributed by **Aneil Mallavarapu**.
  533. - Fixed issue where the wrong result is returned when a chain
  534. contains a chord as the penultimate task.
  535. Fix contributed by **Aneil Mallavarapu**.
  536. - Special case of ``group(A.s() | group(B.s() | C.s()))`` now works.
  537. - Chain: Fixed bug with incorrect id set when a subtask is also a chain.
  538. - ``group | group`` is now flattened into a single group (Issue #2573).
  539. - Fixed issue where ``group | task`` wasn't upgrading correctly
  540. to chord (Issue #2922).
  541. - Chords now properly sets ``result.parent`` links.
  542. Amazon SQS transport now officially supported
  543. ---------------------------------------------
  544. The SQS broker transport has been rewritten to use async I/O and as such
  545. joins RabbitMQ and Redis as officially supported transports.
  546. The new implementation also takes advantage of long polling,
  547. and closes several issues related to using SQS as a broker.
  548. This work was sponsored by Nextdoor.
  549. Apache QPid transport now officially supported
  550. ----------------------------------------------
  551. Contributed by **Brian Bouterse**.
  552. Schedule tasks based on sunrise, sunset, dawn and dusk
  553. ------------------------------------------------------
  554. See :ref:`beat-solar` for more information.
  555. Contributed by **Mark Parncutt**.
  556. New API for configuring periodic tasks
  557. --------------------------------------
  558. This new API enables you to use signatures when defining periodic tasks,
  559. removing the chance of mistyping task names.
  560. An example of the new API is :ref:`here <beat-entries>`.
  561. .. :sha:`bc18d0859c1570f5eb59f5a969d1d32c63af764b`
  562. .. :sha:`132d8d94d38f4050db876f56a841d5a5e487b25b`
  563. Handling task connection errors
  564. -------------------------------
  565. Connection related errors occuring while sending a task is now re-raised
  566. as a :exc:`kombu.exceptions.OperationalError` error:
  567. .. code-block:: pycon
  568. >>> try:
  569. ... add.delay(2, 2)
  570. ... except add.OperationalError as exc:
  571. ... print('Could not send task %r: %r' % (add, exc))
  572. See :ref:`calling-connection-errors` for more information.
  573. RabbitMQ priority queue support
  574. -------------------------------
  575. See :ref:`routing-options-rabbitmq-priorities` for more information.
  576. Contributed by **Gerald Manipon**.
  577. Prefork: Limit child process resident memory size
  578. -------------------------------------------------
  579. .. :sha:`5cae0e754128750a893524dcba4ae030c414de33`
  580. You can now limit the maximum amount of memory allocated per prefork
  581. pool child process by setting the worker
  582. :option:`--max-memory-per-child <celery worker --max-memory-per-child>` option,
  583. or the :setting:`worker_max_memory_per_child` setting.
  584. The limit is for RSS/resident memory size and is specified in kilobytes.
  585. A child process having exceeded the limit will be terminated and replaced
  586. with a new process after the currently executing task returns.
  587. See :ref:`worker-max-memory-per-child` for more information.
  588. Contributed by **Dave Smith**.
  589. Redis: Result backend optimizations
  590. -----------------------------------
  591. RPC is now using pub/sub for streaming task results
  592. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  593. Calling ``result.get()`` when using the Redis result backend
  594. used to be extremely expensive as it was using polling to wait
  595. for the result to become available. A default polling
  596. interval of 0.5 seconds didn't help performance, but was
  597. necessary to avoid a spin loop.
  598. The new implementation is using Redis Pub/Sub mechanisms to
  599. publish and retrieve results immediately, greatly improving
  600. task round-trip times.
  601. Contributed by **Yaroslav Zhavoronkov** and **Ask Solem**.
  602. New optimized chord join implementation
  603. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  604. This was an experimental feature introduced in Celery 3.1,
  605. that could only be enabled by adding ``?new_join=1`` to the
  606. result backend URL configuration.
  607. We feel that the implementation has been tested thoroughly enough
  608. to be considered stable and enabled by default.
  609. The new implementation greatly reduces the overhead of chords,
  610. and especially with larger chords the performance benefit can be massive.
  611. New Result backends
  612. -------------------
  613. New Riak result backend introduced
  614. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  615. See :ref:`conf-riak-result-backend` for more information.
  616. Contributed by **Gilles Dartiguelongue**, **Alman One** and **NoKriK**.
  617. New CouchDB result backend introduced
  618. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  619. See :ref:`conf-couchdb-result-backend` for more information.
  620. Contributed by **Nathan Van Gheem**.
  621. New Consul result backend introduced
  622. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  623. Add support for Consul as a backend using the Key/Value store of Consul.
  624. Consul has an HTTP API where through you can store keys with their values.
  625. The backend extends KeyValueStoreBackend and implements most of the methods.
  626. Mainly to set, get and remove objects.
  627. This allows Celery to store Task results in the K/V store of Consul.
  628. Consul also allows to set a TTL on keys using the Sessions from Consul. This way
  629. the backend supports auto expiry of Task results.
  630. For more information on Consul visit http://consul.io/
  631. The backend uses :pypi:`python-consul` for talking to the HTTP API.
  632. This package is fully Python 3 compliant just as this backend is:
  633. .. code-block:: console
  634. $ pip install python-consul
  635. That installs the required package to talk to Consul's HTTP API from Python.
  636. Contributed by **Wido den Hollander**.
  637. Brand new Cassandra result backend
  638. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  639. A brand new Cassandra backend utilizing the new :pypi:`cassandra-driver`
  640. library is replacing the old result backend using the older
  641. :pypi:`pycassa` library.
  642. See :ref:`conf-cassandra-result-backend` for more information.
  643. .. # XXX What changed?
  644. New Elasticsearch result backend introduced
  645. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  646. See :ref:`conf-elasticsearch-result-backend` for more information.
  647. Contributed by **Ahmet Demir**.
  648. New File-system result backend introduced
  649. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  650. See :ref:`conf-filesystem-result-backend` for more information.
  651. Contributed by **Môshe van der Sterre**.
  652. Event Batching
  653. --------------
  654. Events are now buffered in the worker and sent as a list, reducing
  655. the overhead required to send monitoring events.
  656. For authors of custom event monitors there will be no action
  657. required as long as you're using the Python Celery
  658. helpers (:class:`~@events.Receiver`) to implement your monitor.
  659. However, if you're parsing raw event messages you must now account
  660. for batched event messages, as they differ from normal event messages
  661. in the following way:
  662. - The routing key for a batch of event messages will be set to
  663. ``<event-group>.multi`` where the only batched event group
  664. is currently ``task`` (giving a routing key of ``task.multi``).
  665. - The message body will be a serialized list-of-dictionaries instead
  666. of a dictionary. Each item in the list can be regarded
  667. as a normal event message body.
  668. .. :sha:`03399b4d7c26fb593e61acf34f111b66b340ba4e`
  669. ``Task.replace``
  670. ----------------
  671. Task.replace changed, removes Task.replace_in_chord.
  672. The two methods had almost the same functionality, but the old
  673. ``Task.replace`` would force the new task to inherit the
  674. callbacks/errbacks of the existing task.
  675. If you replace a node in a tree, then you wouldn't expect the new node to
  676. inherit the children of the old node, so this seems like unexpected
  677. behavior.
  678. So ``self.replace(sig)`` now works for any task, in addition ``sig`` can now
  679. be a group.
  680. Groups are automatically converted to a chord, where the callback
  681. will "accumulate" the results of the group tasks.
  682. A new built-in task (`celery.accumulate` was added for this purpose)
  683. Closes #817
  684. Optimized Beat implementation
  685. -----------------------------
  686. The :program:`celery beat` implementation has been optimized
  687. for millions of periodic tasks by using a heap to schedule entries.
  688. Contributed by **Ask Solem** and **Alexander Koshelev**.
  689. Task Auto-retry Decorator
  690. -------------------------
  691. Writing custom retry handling for exception events is so common
  692. that we now have built-in support for it.
  693. For this a new ``autoretry_for`` argument is now supported by
  694. the task decorators, where you can specify a tuple of exceptions
  695. to automatically retry for.
  696. See :ref:`task-autoretry` for more information.
  697. Contributed by **Dmitry Malinovsky**.
  698. .. :sha:`75246714dd11e6c463b9dc67f4311690643bff24`
  699. Remote Task Tracebacks
  700. ----------------------
  701. The new :setting:`task_remote_tracebacks` will make task tracebacks more
  702. useful by injecting the stack of the remote worker.
  703. This feature requires the additional :pypi:`tblib` library.
  704. Contributed by **Ionel Cristian Mărieș**.
  705. Async Result API
  706. ----------------
  707. Gevent/Eventlet: Dedicated thread for consuming results
  708. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  709. When using :pypi:`gevent`, or :pypi:`eventlet` there is now a single
  710. thread responsible for consuming events.
  711. This means that if you have many calls retrieving results, there will be
  712. a dedicated thread for consuming them:
  713. .. code-block:: python
  714. result = add.delay(2, 2)
  715. # this call will delegate to the result consumer thread:
  716. # once the consumer thread has received the result this greenlet can
  717. # continue.
  718. value = result.get(timeout=3)
  719. This makes performing RPC calls when using gevent/eventlet perform much
  720. better.
  721. ``AsyncResult.then(on_success, on_error)``
  722. ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
  723. The AsyncResult API has been extended to support the :class:`~vine.promise` protocol.
  724. This currently only works with the RPC (amqp) and Redis result backends, but
  725. lets you attach callbacks to when tasks finish:
  726. .. code-block:: python
  727. import gevent.monkey
  728. monkey.patch_all()
  729. import time
  730. from celery import Celery
  731. app = Celery(broker='amqp://', backend='rpc')
  732. @app.task
  733. def add(x, y):
  734. return x + y
  735. def on_result_ready(result):
  736. print('Received result for id %r: %r' % (result.id, result.result,))
  737. add.delay(2, 2).then(on_result_ready)
  738. time.sleep(3) # run gevent event loop for a while.
  739. Demonstrated using gevent here, but really this is an API that's more useful
  740. in callback-based event loops like :pypi:`twisted`, or :pypi:`tornado`.
  741. RPC Result Backend matured
  742. --------------------------
  743. Lots of bugs in the previously experimental RPC result backend have been fixed
  744. and we now consider it production ready.
  745. Contributed by **Ask Solem**, **Morris Tweed**.
  746. New Task Router API
  747. -------------------
  748. The :setting:`task_routes` setting can now hold functions, and map routes
  749. now support glob patterns and regexes.
  750. Instead of using router classes you can now simply define a function:
  751. .. code-block:: python
  752. def route_for_task(name, args, kwargs, options, task=None, **kwargs):
  753. from proj import tasks
  754. if name == tasks.add.name:
  755. return {'queue': 'hipri'}
  756. If you don't need the arguments you can use start arguments, just make
  757. sure you always also accept star arguments so that we have the ability
  758. to add more features in the future:
  759. .. code-block:: python
  760. def route_for_task(name, *args, **kwargs):
  761. from proj import tasks
  762. if name == tasks.add.name:
  763. return {'queue': 'hipri', 'priority': 9}
  764. Both the ``options`` argument and the new ``task`` keyword argument
  765. are new to the function-style routers, and will make it easier to write
  766. routers based on execution options, or properties of the task.
  767. The optional ``task`` keyword argument won't be set if a task is called
  768. by name using :meth:`@send_task`.
  769. For more examples, including using glob/regexes in routers please see
  770. :setting:`task_routes` and :ref:`routing-automatic`.
  771. In Other News
  772. -------------
  773. Requirements
  774. ~~~~~~~~~~~~
  775. - Now depends on :ref:`Kombu 4.0 <kombu:version-4.0>`.
  776. - Now depends on :pypi:`billiard` version 3.5.
  777. - No longer depends on :pypi:`anyjson`. Good-bye old friend :(
  778. Tasks
  779. ~~~~~
  780. - The "anon-exchange" is now used for simple name-name direct routing.
  781. This increases performance as it completely bypasses the routing table,
  782. in addition it also improves reliability for the Redis broker transport.
  783. - An empty ResultSet now evaluates to True.
  784. Fix contributed by **Colin McIntosh**.
  785. - New :setting:`task_reject_on_worker_lost` setting, and
  786. :attr:`~@Task.reject_on_worker_lost` task attribute decides what happens
  787. when the child worker process executing a late ack task is terminated.
  788. Contributed by **Michael Permana**.
  789. - ``Task.subtask`` renamed to ``Task.signature`` with alias.
  790. - ``Task.subtask_from_request`` renamed to
  791. ``Task.signature_from_request`` with alias.
  792. - The ``delivery_mode`` attribute for :class:`kombu.Queue` is now
  793. respected (Issue #1953).
  794. - Routes in :setting:`task-routes` can now specify a
  795. :class:`~kombu.Queue` instance directly.
  796. Example:
  797. .. code-block:: python
  798. task_routes = {'proj.tasks.add': {'queue': Queue('add')}}
  799. - ``AsyncResult`` now raises :exc:`ValueError` if task_id is None.
  800. (Issue #1996).
  801. - Retried tasks didn't forward expires setting (Issue #3297).
  802. - ``result.get()`` now supports an ``on_message`` argument to set a
  803. callback to be called for every message received.
  804. - New abstract classes added:
  805. - :class:`~celery.utils.abstract.CallableTask`
  806. Looks like a task.
  807. - :class:`~celery.utils.abstract.CallableSignature`
  808. Looks like a task signature.
  809. - ``Task.replace`` now properly forwards callbacks (Issue #2722).
  810. Fix contributed by **Nicolas Unravel**.
  811. - ``Task.replace``: Append to chain/chord (Closes #3232)
  812. Fixed issue #3232, adding the signature to the chain (if there's any).
  813. Fixed the chord suppress if the given signature contains one.
  814. Fix contributed by :github_user:`honux`.
  815. - Task retry now also throws in eager mode.
  816. Fix contributed by **Feanil Patel**.
  817. Beat
  818. ~~~~
  819. - Fixed crontab infinite loop with invalid date.
  820. When occurrence can never be reached (example, April, 31th), trying
  821. to reach the next occurrence would trigger an infinite loop.
  822. Try fixing that by raising a RuntimeError after 2,000 iterations
  823. (Also added a test for crontab leap years in the process)
  824. Fix contributed by **Romuald Brunet**.
  825. - Now ensures the program exits with a non-zero exit code when an
  826. exception terminates the service.
  827. Fix contributed by **Simon Peeters**.
  828. App
  829. ~~~
  830. - Dates are now always timezone aware even if
  831. :setting:`enable_utc` is disabled (Issue #943).
  832. Fix contributed by **Omer Katz**.
  833. - **Config**: App preconfiguration is now also pickled with the configuration.
  834. Fix contributed by **Jeremy Zafran**.
  835. - The application can now change how task names are generated using
  836. the :meth:`~@gen_task_name` method.
  837. Contributed by **Dmitry Malinovsky**.
  838. - App has new ``app.current_worker_task`` property that
  839. returns the task that's currently being worked on (or :const:`None`).
  840. (Issue #2100).
  841. Execution Pools
  842. ~~~~~~~~~~~~~~~
  843. - **Eventlet/Gevent**: Fixed race condition leading to "simultaneous read"
  844. errors (Issue #2812).
  845. - **Prefork**: Prefork pool now uses ``poll`` instead of ``select`` where
  846. available (Issue #2373).
  847. - **Prefork**: Fixed bug where the pool would refuse to shut down the
  848. worker (Issue #2606).
  849. - **Eventlet**: Now returns pool size in :program:`celery inspect stats`
  850. command.
  851. Contributed by **Alexander Oblovatniy**.
  852. Transports
  853. ~~~~~~~~~~
  854. - **Redis Transport**: The Redis transport now supports the
  855. :setting:`broker_use_ssl` option.
  856. Programs
  857. ~~~~~~~~
  858. - :program:`celery multi`: ``%n`` format for is now synonym with
  859. ``%N`` to be consistent with :program:`celery worker`.
  860. - :program:`celery inspect`/:program:`celery control`: now supports a new
  861. :option:`--json <celery inspect --json>` option to give output in json format.
  862. - :program:`celery inspect registered`: now ignores built-in tasks.
  863. - :program:`celery purge` now takes ``-Q`` and ``-X`` options
  864. used to specify what queues to include and exclude from the purge.
  865. - New :program:`celery logtool`: Utility for filtering and parsing
  866. celery worker log-files
  867. - :program:`celery multi`: now passes through `%i` and `%I` log
  868. file formats.
  869. - General: ``%p`` can now be used to expand to the full worker node-name
  870. in log-file/pid-file arguments.
  871. - A new command line option
  872. :option:`--executable <celery worker --executable>` is now
  873. available for daemonizing programs (:program:`celery worker` and
  874. :program:`celery beat`).
  875. Contributed by **Bert Vanderbauwhede**.
  876. - :program:`celery worker`: supports new
  877. :option:`--prefetch-multiplier <celery worker --prefetch-multiplier>` option.
  878. Contributed by **Mickaël Penhard**.
  879. Worker
  880. ~~~~~~
  881. - Improvements and fixes for :class:`~celery.utils.collections.LimitedSet`.
  882. Getting rid of leaking memory + adding ``minlen`` size of the set:
  883. the minimal residual size of the set after operating for some time.
  884. ``minlen`` items are kept, even if they should've been expired.
  885. Problems with older and even more old code:
  886. #. Heap would tend to grow in some scenarios
  887. (like adding an item multiple times).
  888. #. Adding many items fast wouldn't clean them soon enough (if ever).
  889. #. When talking to other workers, revoked._data was sent, but
  890. it was processed on the other side as iterable.
  891. That means giving those keys new (current)
  892. time-stamp. By doing this workers could recycle
  893. items forever. Combined with 1) and 2), this means that in
  894. large set of workers, you're getting out of memory soon.
  895. All those problems should be fixed now.
  896. This should fix issues #3095, #3086.
  897. Contributed by **David Pravec**.
  898. - New settings to control remote control command queues.
  899. - :setting:`control_queue_expires`
  900. Set queue expiry time for both remote control command queues,
  901. and remote control reply queues.
  902. - :setting:`control_queue_ttl`
  903. Set message time-to-live for both remote control command queues,
  904. and remote control reply queues.
  905. Contributed by **Alan Justino**.
  906. - Worker now only starts the remote control command consumer if the
  907. broker transport used actually supports them.
  908. - Gossip now sets ``x-message-ttl`` for event queue to heartbeat_interval s.
  909. (Issue #2005).
  910. - Now preserves exit code (Issue #2024).
  911. - Fixed crash when the ``-purge`` argument was used.
  912. - Log--level for unrecoverable errors changed from ``error`` to
  913. ``critical``.
  914. - Improved rate limiting accuracy.
  915. - Account for missing timezone information in task expires field.
  916. Fix contributed by **Albert Wang**.
  917. - The worker no longer has a ``Queues`` bootsteps, as it is now
  918. superfluous.
  919. - Now emits the "Received task" line even for revoked tasks.
  920. (Issue #3155).
  921. - Now respects :setting:`broker_connection_retry` setting.
  922. Fix contributed by **Nat Williams**.
  923. - New :data:`celery.worker.state.requests` enables O(1) loookup
  924. of active/reserved tasks by id.
  925. - Auto-scale didn't always update keep-alive when scaling down.
  926. Fix contributed by **Philip Garnero**.
  927. - Fixed typo ``options_list`` -> ``option_list``.
  928. Fix contributed by **Greg Wilbur**.
  929. Debugging Utilities
  930. ~~~~~~~~~~~~~~~~~~~
  931. - :mod:`celery.contrib.rdb`: Changed remote debugger banner so that you can copy and paste
  932. the address easily (no longer has a period in the address).
  933. Contributed by **Jonathan Vanasco**.
  934. - Fixed compatibility with recent :pypi:`psutil` versions (Issue #3262).
  935. Signals
  936. ~~~~~~~
  937. - **App**: New signals for app configuration/finalization:
  938. - :data:`app.on_configure <@on_configure>`
  939. - :data:`app.on_after_configure <@on_after_configure>`
  940. - :data:`app.on_after_finalize <@on_after_finalize>`
  941. - **Task**: New task signals for rejected task messages:
  942. - :data:`celery.signals.task_rejected`.
  943. - :data:`celery.signals.task_unknown`.
  944. - **Worker**: New signal for when a heartbeat event is sent.
  945. - :data:`celery.signals.heartbeat_sent`
  946. Contributed by **Kevin Richardson**.
  947. Events
  948. ~~~~~~
  949. - Event messages now uses the RabbitMQ ``x-message-ttl`` option
  950. to ensure older event messages are discarded.
  951. The default is 5 seconds, but can be changed using the
  952. :setting:`event_queue_ttl` setting.
  953. - Event monitors now sets the :setting:`event_queue_expires`
  954. setting by default.
  955. The queues will now expire after 60 seconds after the monitor stops
  956. consuming from it.
  957. - Fixed a bug where a None value wasn't handled properly.
  958. Fix contributed by **Dongweiming**.
  959. - New :setting:`event_queue_prefix` setting can now be used
  960. to change the default ``celeryev`` queue prefix for event receiver queues.
  961. Contributed by **Takeshi Kanemoto**.
  962. - ``State.tasks_by_type`` and ``State.tasks_by_worker`` can now be
  963. used as a mapping for fast access to this information.
  964. Canvas
  965. ~~~~~~
  966. - ``chunks``/``map``/``starmap`` are now routed based on the target task.
  967. - ``Signature.link`` now works when argument is scalar (not a list)
  968. (Issue #2019).
  969. - ``group()`` now properly forwards keyword arguments (Issue #3426).
  970. Fix contributed by **Samuel Giffard**.
  971. Deployment
  972. ~~~~~~~~~~
  973. - Generic init-scripts now support
  974. :envvar:`CELERY_SU` and :envvar:`CELERYD_SU_ARGS` environment variables
  975. to set the path and arguments for :command:`su` (:manpage:`su(1)`).
  976. - Generic init-scripts now better support FreBSD and other BSD
  977. systems by searching :file:`/usr/local/etc/` for the configuration file.
  978. Contributed by **Taha Jahangir**.
  979. - Generic init-script: Fixed strange bug for ``celerybeat`` where
  980. restart didn't always work (Issue #3018).
  981. - The systemd init script now uses a shell when executing
  982. services.
  983. Contributed by **Tomas Machalek**.
  984. Result Backends
  985. ~~~~~~~~~~~~~~~
  986. - Redis: Now has a default socket timeout of 5 seconds.
  987. The default can be changed using the new :setting:`redis_socket_timeout`
  988. setting.
  989. Contributed by **Raghuram Srinivasan**.
  990. - RPC Backend result queues are now auto delete by default (Issue #2001).
  991. - RPC Backend: Fixed problem where exception
  992. wasn't deserialized properly with the json serializer (Issue #2518).
  993. Fix contributed by **Allard Hoeve**.
  994. - CouchDB: Fixed typo causing the backend to not be found
  995. (Issue #3287).
  996. Fix contributed by **Andrew Stewart**.
  997. - MongoDB: Now supports setting the :setting:`result_serialzier` setting
  998. to ``bson`` to use the MongoDB libraries own serializer.
  999. Contributed by **Davide Quarta**.
  1000. - MongoDB: URI handling has been improved to use
  1001. database name, user and password from the URI if provided.
  1002. Contributed by **Samuel Jaillet**.
  1003. - SQLAlchemy result backend: Now ignores all result
  1004. engine options when using NullPool (Issue #1930).
  1005. - SQLAlchemy result backend: Now sets max char size to 155 to deal
  1006. with brain damaged MySQL unicode implementation (Issue #1748).
  1007. - **General**: All Celery exceptions/warnings now inherit from common
  1008. :class:`~celery.exceptions.CeleryError`/:class:`~celery.exceptions.CeleryWarning`.
  1009. (Issue #2643).
  1010. Documentation Improvements
  1011. ~~~~~~~~~~~~~~~~~~~~~~~~~~
  1012. Contributed by:
  1013. - Adam Chainz
  1014. - Arthur Vuillard
  1015. - Batiste Bieler
  1016. - Daniel Devine
  1017. - Edward Betts
  1018. - Jason Veatch
  1019. - Jeff Widman
  1020. - Manuel Kaufmann
  1021. - Maxime Beauchemin
  1022. - Mitchel Humpherys
  1023. - Rik
  1024. - Tayfun Sen
  1025. Reorganization, Deprecations, and Removals
  1026. ==========================================
  1027. Incompatible changes
  1028. --------------------
  1029. - Prefork: Calling ``result.get()`` or joining any result from within a task
  1030. now raises :exc:`RuntimeError`.
  1031. In previous versions this would emit a warning.
  1032. - :mod:`celery.worker.consumer` is now a package, not a module.
  1033. - Module ``celery.worker.job`` renamed to :mod:`celery.worker.request`.
  1034. - Beat: ``Scheduler.Publisher``/``.publisher`` renamed to
  1035. ``.Producer``/``.producer``.
  1036. - Result: The task_name argument/attribute of :class:`@AsyncResult` was
  1037. removed.
  1038. This was historically a field used for :mod:`pickle` compatibility,
  1039. but is no longer needed.
  1040. - Backends: Arguments named ``status`` renamed to ``state``.
  1041. - Backends: ``backend.get_status()`` renamed to ``backend.get_state()``.
  1042. - Backends: ``backend.maybe_reraise()`` renamed to ``.maybe_throw()``
  1043. The promise API uses .throw(), so this change was made to make it more
  1044. consistent.
  1045. There's an alias available, so you can still use maybe_reraise until
  1046. Celery 5.0.
  1047. .. _v400-unscheduled-removals:
  1048. Unscheduled Removals
  1049. --------------------
  1050. - The experimental :mod:`celery.contrib.methods` feature has been removed,
  1051. as there were far many bugs in the implementation to be useful.
  1052. - The CentOS init-scripts have been removed.
  1053. These didn't really add any features over the generic init-scripts,
  1054. so you're encouraged to use them instead, or something like
  1055. :pypi:`supervisor`.
  1056. .. _v400-deprecations-reorg:
  1057. Reorganization Deprecations
  1058. ---------------------------
  1059. These symbols have been renamed, and while there's an alias available in this
  1060. version for backward compatibility, they will be removed in Celery 5.0, so
  1061. make sure you rename these ASAP to make sure it won't break for that release.
  1062. Chances are that you'll only use the first in this list, but you never
  1063. know:
  1064. - ``celery.utils.worker_direct`` ->
  1065. :meth:`celery.utils.nodenames.worker_direct`.
  1066. - ``celery.utils.nodename`` -> :meth:`celery.utils.nodenames.nodename`.
  1067. - ``celery.utils.anon_nodename`` ->
  1068. :meth:`celery.utils.nodenames.anon_nodename`.
  1069. - ``celery.utils.nodesplit`` -> :meth:`celery.utils.nodenames.nodesplit`.
  1070. - ``celery.utils.default_nodename`` ->
  1071. :meth:`celery.utils.nodenames.default_nodename`.
  1072. - ``celery.utils.node_format`` -> :meth:`celery.utils.nodenames.node_format`.
  1073. - ``celery.utils.host_format`` -> :meth:`celery.utils.nodenames.host_format`.
  1074. .. _v400-removals:
  1075. Scheduled Removals
  1076. ------------------
  1077. Modules
  1078. ~~~~~~~
  1079. - Module ``celery.worker.job`` has been renamed to :mod:`celery.worker.request`.
  1080. This was an internal module so shouldn't have any effect.
  1081. It's now part of the public API so must not change again.
  1082. - Module ``celery.task.trace`` has been renamed to ``celery.app.trace``
  1083. as the ``celery.task`` package is being phased out. The module
  1084. will be removed in version 5.0 so please change any import from::
  1085. from celery.task.trace import X
  1086. to::
  1087. from celery.app.trace import X
  1088. - Old compatibility aliases in the :mod:`celery.loaders` module
  1089. has been removed.
  1090. - Removed ``celery.loaders.current_loader()``, use: ``current_app.loader``
  1091. - Removed ``celery.loaders.load_settings()``, use: ``current_app.conf``
  1092. Result
  1093. ~~~~~~
  1094. - ``AsyncResult.serializable()`` and ``celery.result.from_serializable``
  1095. has been removed:
  1096. Use instead:
  1097. .. code-block:: pycon
  1098. >>> tup = result.as_tuple()
  1099. >>> from celery.result import result_from_tuple
  1100. >>> result = result_from_tuple(tup)
  1101. - Removed ``BaseAsyncResult``, use ``AsyncResult`` for instance checks
  1102. instead.
  1103. - Removed ``TaskSetResult``, use ``GroupResult`` instead.
  1104. - ``TaskSetResult.total`` -> ``len(GroupResult)``
  1105. - ``TaskSetResult.taskset_id`` -> ``GroupResult.id``
  1106. - Removed ``ResultSet.subtasks``, use ``ResultSet.results`` instead.
  1107. TaskSet
  1108. ~~~~~~~
  1109. TaskSet has been renamed to group and TaskSet will be removed in version 4.0.
  1110. Old::
  1111. >>> from celery.task import TaskSet
  1112. >>> TaskSet(add.subtask((i, i)) for i in xrange(10)).apply_async()
  1113. New::
  1114. >>> from celery import group
  1115. >>> group(add.s(i, i) for i in xrange(10))()
  1116. Events
  1117. ~~~~~~
  1118. - Removals for class :class:`celery.events.state.Worker`:
  1119. - ``Worker._defaults`` attribute.
  1120. Use ``{k: getattr(worker, k) for k in worker._fields}``.
  1121. - ``Worker.update_heartbeat``
  1122. Use ``Worker.event(None, timestamp, received)``
  1123. - ``Worker.on_online``
  1124. Use ``Worker.event('online', timestamp, received, fields)``
  1125. - ``Worker.on_offline``
  1126. Use ``Worker.event('offline', timestamp, received, fields)``
  1127. - ``Worker.on_heartbeat``
  1128. Use ``Worker.event('heartbeat', timestamp, received, fields)``
  1129. - Removals for class :class:`celery.events.state.Task`:
  1130. - ``Task._defaults`` attribute.
  1131. Use ``{k: getattr(task, k) for k in task._fields}``.
  1132. - ``Task.on_sent``
  1133. Use ``Worker.event('sent', timestamp, received, fields)``
  1134. - ``Task.on_received``
  1135. Use ``Task.event('received', timestamp, received, fields)``
  1136. - ``Task.on_started``
  1137. Use ``Task.event('started', timestamp, received, fields)``
  1138. - ``Task.on_failed``
  1139. Use ``Task.event('failed', timestamp, received, fields)``
  1140. - ``Task.on_retried``
  1141. Use ``Task.event('retried', timestamp, received, fields)``
  1142. - ``Task.on_succeeded``
  1143. Use ``Task.event('succeeded', timestamp, received, fields)``
  1144. - ``Task.on_revoked``
  1145. Use ``Task.event('revoked', timestamp, received, fields)``
  1146. - ``Task.on_unknown_event``
  1147. Use ``Task.event(short_type, timestamp, received, fields)``
  1148. - ``Task.update``
  1149. Use ``Task.event(short_type, timestamp, received, fields)``
  1150. - ``Task.merge``
  1151. Contact us if you need this.
  1152. Magic keyword arguments
  1153. ~~~~~~~~~~~~~~~~~~~~~~~
  1154. Support for the very old magic keyword arguments accepted by tasks is
  1155. finally removed in this version.
  1156. If you're still using these you have to rewrite any task still
  1157. using the old ``celery.decorators`` module and depending
  1158. on keyword arguments being passed to the task,
  1159. for example::
  1160. from celery.decorators import task
  1161. @task()
  1162. def add(x, y, task_id=None):
  1163. print('My task id is %r' % (task_id,))
  1164. should be rewritten into::
  1165. from celery import task
  1166. @task(bind=True)
  1167. def add(self, x, y):
  1168. print('My task id is {0.request.id}'.format(self))
  1169. Removed Settings
  1170. ----------------
  1171. The following settings have been removed, and is no longer supported:
  1172. Logging Settings
  1173. ~~~~~~~~~~~~~~~~
  1174. ===================================== =====================================
  1175. **Setting name** **Replace with**
  1176. ===================================== =====================================
  1177. ``CELERYD_LOG_LEVEL`` :option:`celery worker --loglevel`
  1178. ``CELERYD_LOG_FILE`` :option:`celery worker --logfile`
  1179. ``CELERYBEAT_LOG_LEVEL`` :option:`celery beat --loglevel`
  1180. ``CELERYBEAT_LOG_FILE`` :option:`celery beat --loglevel`
  1181. ``CELERYMON_LOG_LEVEL`` celerymon is deprecated, use flower
  1182. ``CELERYMON_LOG_FILE`` celerymon is deprecated, use flower
  1183. ``CELERYMON_LOG_FORMAT`` celerymon is deprecated, use flower
  1184. ===================================== =====================================
  1185. Task Settings
  1186. ~~~~~~~~~~~~~~
  1187. ===================================== =====================================
  1188. **Setting name** **Replace with**
  1189. ===================================== =====================================
  1190. ``CELERY_CHORD_PROPAGATES`` N/A
  1191. ===================================== =====================================
  1192. Changes to internal API
  1193. -----------------------
  1194. - Module ``celery.datastructures`` renamed to :mod:`celery.utils.collections`.
  1195. - Module ``celery.utils.timeutils`` renamed to :mod:`celery.utils.time`.
  1196. - ``celery.utils.datastructures.DependencyGraph`` moved to
  1197. :mod:`celery.utils.graph`.
  1198. - ``celery.utils.jsonify`` is now :func:`celery.utils.serialization.jsonify`.
  1199. - ``celery.utils.strtobool`` is now
  1200. :func:`celery.utils.serialization.strtobool`.
  1201. - ``celery.utils.is_iterable`` has been removed.
  1202. Instead use::
  1203. isinstance(x, collections.Iterable)
  1204. - ``celery.utils.lpmerge`` is now :func:`celery.utils.collections.lpmerge`.
  1205. - ``celery.utils.cry`` is now :func:`celery.utils.debug.cry`.
  1206. - ``celery.utils.isatty`` is now :func:`celery.platforms.isatty`.
  1207. - ``celery.utils.gen_task_name`` is now
  1208. :func:`celery.utils.imports.gen_task_name`.
  1209. - ``celery.utils.deprecated`` is now :func:`celery.utils.deprecated.Callable`
  1210. - ``celery.utils.deprecated_property`` is now
  1211. :func:`celery.utils.deprecated.Property`.
  1212. - ``celery.utils.warn_deprecated`` is now :func:`celery.utils.deprecated.warn`
  1213. .. _v400-deprecations:
  1214. Deprecation Time-line Changes
  1215. =============================
  1216. See the :ref:`deprecation-timeline`.