changelog-2.2.rst 33 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026
  1. .. _changelog-2.2:
  2. ===============================
  3. Change history for Celery 2.2
  4. ===============================
  5. .. contents::
  6. :local:
  7. .. _version-2.2.8:
  8. 2.2.8
  9. =====
  10. :release-date: 2011-11-25 04:00 P.M GMT
  11. :release-by: Ask Solem
  12. .. _v228-security-fixes:
  13. Security Fixes
  14. --------------
  15. * [Security: `CELERYSA-0001`_] Daemons would set effective id's rather than
  16. real id's when the :option:`--uid`/:option:`--gid` arguments to
  17. :program:`celery multi`, :program:`celeryd_detach`,
  18. :program:`celery beat` and :program:`celery events` were used.
  19. This means privileges weren't properly dropped, and that it would
  20. be possible to regain supervisor privileges later.
  21. .. _`CELERYSA-0001`:
  22. http://github.com/celery/celery/tree/master/docs/sec/CELERYSA-0001.txt
  23. .. _version-2.2.7:
  24. 2.2.7
  25. =====
  26. :release-date: 2011-06-13 04:00 P.M BST
  27. :release-by: Ask Solem
  28. * New signals: :signal:`after_setup_logger` and
  29. :signal:`after_setup_task_logger`
  30. These signals can be used to augment logging configuration
  31. after Celery has set up logging.
  32. * Redis result backend now works with Redis 2.4.4.
  33. * multi: The :option:`--gid` option now works correctly.
  34. * worker: Retry wrongfully used the repr of the traceback instead
  35. of the string representation.
  36. * App.config_from_object: Now loads module, not attribute of module.
  37. * Fixed issue where logging of objects would give "<Unrepresentable: ...>"
  38. .. _version-2.2.6:
  39. 2.2.6
  40. =====
  41. :release-date: 2011-04-15 04:00 P.M CEST
  42. :release-by: Ask Solem
  43. .. _v226-important:
  44. Important Notes
  45. ---------------
  46. * Now depends on Kombu 1.1.2.
  47. * Dependency lists now explicitly specifies that we don't want python-dateutil
  48. 2.x, as this version only supports py3k.
  49. If you have installed dateutil 2.0 by accident you should downgrade
  50. to the 1.5.0 version::
  51. pip install -U python-dateutil==1.5.0
  52. or by easy_install::
  53. easy_install -U python-dateutil==1.5.0
  54. .. _v226-fixes:
  55. Fixes
  56. -----
  57. * The new ``WatchedFileHandler`` broke Python 2.5 support (Issue #367).
  58. * Task: Don't use ``app.main`` if the task name is set explicitly.
  59. * Sending emails did not work on Python 2.5, due to a bug in
  60. the version detection code (Issue #378).
  61. * Beat: Adds method ``ScheduleEntry._default_now``
  62. This method can be overridden to change the default value
  63. of ``last_run_at``.
  64. * An error occurring in process cleanup could mask task errors.
  65. We no longer propagate errors happening at process cleanup,
  66. but log them instead. This way they will not interfere with publishing
  67. the task result (Issue #365).
  68. * Defining tasks did not work properly when using the Django
  69. ``shell_plus`` utility (Issue #366).
  70. * ``AsyncResult.get`` did not accept the ``interval`` and ``propagate``
  71. arguments.
  72. * worker: Fixed a bug where the worker would not shutdown if a
  73. :exc:`socket.error` was raised.
  74. .. _version-2.2.5:
  75. 2.2.5
  76. =====
  77. :release-date: 2011-03-28 06:00 P.M CEST
  78. :release-by: Ask Solem
  79. .. _v225-important:
  80. Important Notes
  81. ---------------
  82. * Now depends on Kombu 1.0.7
  83. .. _v225-news:
  84. News
  85. ----
  86. * Our documentation is now hosted by Read The Docs
  87. (http://docs.celeryproject.org), and all links have been changed to point to
  88. the new URL.
  89. * Logging: Now supports log rotation using external tools like `logrotate.d`_
  90. (Issue #321)
  91. This is accomplished by using the ``WatchedFileHandler``, which re-opens
  92. the file if it is renamed or deleted.
  93. .. _`logrotate.d`:
  94. http://www.ducea.com/2006/06/06/rotating-linux-log-files-part-2-logrotate/
  95. * otherqueues tutorial now documents how to configure Redis/Database result
  96. backends.
  97. * gevent: Now supports ETA tasks.
  98. But gevent still needs ``CELERY_DISABLE_RATE_LIMITS=True`` to work.
  99. * TaskSet User Guide: now contains TaskSet callback recipes.
  100. * Eventlet: New signals:
  101. * ``eventlet_pool_started``
  102. * ``eventlet_pool_preshutdown``
  103. * ``eventlet_pool_postshutdown``
  104. * ``eventlet_pool_apply``
  105. See :mod:`celery.signals` for more information.
  106. * New :setting:`BROKER_TRANSPORT_OPTIONS` setting can be used to pass
  107. additional arguments to a particular broker transport.
  108. * worker: ``worker_pid`` is now part of the request info as returned by
  109. broadcast commands.
  110. * TaskSet.apply/Taskset.apply_async now accepts an optional ``taskset_id``
  111. argument.
  112. * The taskset_id (if any) is now available in the Task request context.
  113. * SQLAlchemy result backend: taskset_id and taskset_id columns now have a
  114. unique constraint. (Tables need to recreated for this to take affect).
  115. * Task Userguide: Added section about choosing a result backend.
  116. * Removed unused attribute ``AsyncResult.uuid``.
  117. .. _v225-fixes:
  118. Fixes
  119. -----
  120. * multiprocessing.Pool: Fixes race condition when marking job with
  121. ``WorkerLostError`` (Issue #268).
  122. The process may have published a result before it was terminated,
  123. but we have no reliable way to detect that this is the case.
  124. So we have to wait for 10 seconds before marking the result with
  125. WorkerLostError. This gives the result handler a chance to retrieve the
  126. result.
  127. * multiprocessing.Pool: Shutdown could hang if rate limits disabled.
  128. There was a race condition when the MainThread was waiting for the pool
  129. semaphore to be released. The ResultHandler now terminates after 5
  130. seconds if there are unacked jobs, but no worker processes left to start
  131. them (it needs to timeout because there could still be an ack+result
  132. that we haven't consumed from the result queue. It
  133. is unlikely we will receive any after 5 seconds with no worker processes).
  134. * celerybeat: Now creates pidfile even if the ``--detach`` option is not set.
  135. * eventlet/gevent: The broadcast command consumer is now running in a separate
  136. greenthread.
  137. This ensures broadcast commands will take priority even if there are many
  138. active tasks.
  139. * Internal module ``celery.worker.controllers`` renamed to
  140. ``celery.worker.mediator``.
  141. * worker: Threads now terminates the program by calling ``os._exit``, as it
  142. is the only way to ensure exit in the case of syntax errors, or other
  143. unrecoverable errors.
  144. * Fixed typo in ``maybe_timedelta`` (Issue #352).
  145. * worker: Broadcast commands now logs with loglevel debug instead of warning.
  146. * AMQP Result Backend: Now resets cached channel if the connection is lost.
  147. * Polling results with the AMQP result backend was not working properly.
  148. * Rate limits: No longer sleeps if there are no tasks, but rather waits for
  149. the task received condition (Performance improvement).
  150. * ConfigurationView: ``iter(dict)`` should return keys, not items (Issue #362).
  151. * celerybeat: PersistentScheduler now automatically removes a corrupted
  152. schedule file (Issue #346).
  153. * Programs that doesn't support positional command-line arguments now provides
  154. a user friendly error message.
  155. * Programs no longer tries to load the configuration file when showing
  156. ``--version`` (Issue #347).
  157. * Autoscaler: The "all processes busy" log message is now severity debug
  158. instead of error.
  159. * worker: If the message body can't be decoded, it is now passed through
  160. ``safe_str`` when logging.
  161. This to ensure we don't get additional decoding errors when trying to log
  162. the failure.
  163. * ``app.config_from_object``/``app.config_from_envvar`` now works for all
  164. loaders.
  165. * Now emits a user-friendly error message if the result backend name is
  166. unknown (Issue #349).
  167. * :mod:`celery.contrib.batches`: Now sets loglevel and logfile in the task
  168. request so ``task.get_logger`` works with batch tasks (Issue #357).
  169. * worker: An exception was raised if using the amqp transport and the prefetch
  170. count value exceeded 65535 (Issue #359).
  171. The prefetch count is incremented for every received task with an
  172. ETA/countdown defined. The prefetch count is a short, so can only support
  173. a maximum value of 65535. If the value exceeds the maximum value we now
  174. disable the prefetch count, it is re-enabled as soon as the value is below
  175. the limit again.
  176. * cursesmon: Fixed unbound local error (Issue #303).
  177. * eventlet/gevent is now imported on demand so autodoc can import the modules
  178. without having eventlet/gevent installed.
  179. * worker: Ack callback now properly handles ``AttributeError``.
  180. * ``Task.after_return`` is now always called *after* the result has been
  181. written.
  182. * Cassandra Result Backend: Should now work with the latest ``pycassa``
  183. version.
  184. * multiprocessing.Pool: No longer cares if the putlock semaphore is released
  185. too many times. (this can happen if one or more worker processes are
  186. killed).
  187. * SQLAlchemy Result Backend: Now returns accidentally removed ``date_done`` again
  188. (Issue #325).
  189. * Task.request contex is now always initialized to ensure calling the task
  190. function directly works even if it actively uses the request context.
  191. * Exception occuring when iterating over the result from ``TaskSet.apply``
  192. fixed.
  193. * eventlet: Now properly schedules tasks with an ETA in the past.
  194. .. _version-2.2.4:
  195. 2.2.4
  196. =====
  197. :release-date: 2011-02-19 00:00 AM CET
  198. :release-by: Ask Solem
  199. .. _v224-fixes:
  200. Fixes
  201. -----
  202. * worker: 2.2.3 broke error logging, resulting in tracebacks not being logged.
  203. * AMQP result backend: Polling task states did not work properly if there were
  204. more than one result message in the queue.
  205. * ``TaskSet.apply_async()`` and ``TaskSet.apply()`` now supports an optional
  206. ``taskset_id`` keyword argument (Issue #331).
  207. * The current taskset id (if any) is now available in the task context as
  208. ``request.taskset`` (Issue #329).
  209. * SQLAlchemy result backend: `date_done` was no longer part of the results as it had
  210. been accidentally removed. It is now available again (Issue #325).
  211. * SQLAlchemy result backend: Added unique constraint on `Task.id` and
  212. `TaskSet.taskset_id`. Tables needs to be recreated for this to take effect.
  213. * Fixed exception raised when iterating on the result of ``TaskSet.apply()``.
  214. * Tasks Userguide: Added section on choosing a result backend.
  215. .. _version-2.2.3:
  216. 2.2.3
  217. =====
  218. :release-date: 2011-02-12 04:00 P.M CET
  219. :release-by: Ask Solem
  220. .. _v223-fixes:
  221. Fixes
  222. -----
  223. * Now depends on Kombu 1.0.3
  224. * Task.retry now supports a ``max_retries`` argument, used to change the
  225. default value.
  226. * `multiprocessing.cpu_count` may raise :exc:`NotImplementedError` on
  227. platforms where this is not supported (Issue #320).
  228. * Coloring of log messages broke if the logged object was not a string.
  229. * Fixed several typos in the init script documentation.
  230. * A regression caused `Task.exchange` and `Task.routing_key` to no longer
  231. have any effect. This is now fixed.
  232. * Routing Userguide: Fixes typo, routers in :setting:`CELERY_ROUTES` must be
  233. instances, not classes.
  234. * :program:`celeryev` did not create pidfile even though the
  235. :option:`--pidfile` argument was set.
  236. * Task logger format was no longer used. (Issue #317).
  237. The id and name of the task is now part of the log message again.
  238. * A safe version of ``repr()`` is now used in strategic places to ensure
  239. objects with a broken ``__repr__`` does not crash the worker, or otherwise
  240. make errors hard to understand (Issue #298).
  241. * Remote control command :control:`active_queues`: did not account for queues added
  242. at runtime.
  243. In addition the dictionary replied by this command now has a different
  244. structure: the exchange key is now a dictionary containing the
  245. exchange declaration in full.
  246. * The :option:`-Q` option to :program:`celery worker` removed unused queue
  247. declarations, so routing of tasks could fail.
  248. Queues are no longer removed, but rather `app.amqp.queues.consume_from()`
  249. is used as the list of queues to consume from.
  250. This ensures all queues are available for routing purposes.
  251. * celeryctl: Now supports the `inspect active_queues` command.
  252. .. _version-2.2.2:
  253. 2.2.2
  254. =====
  255. :release-date: 2011-02-03 04:00 P.M CET
  256. :release-by: Ask Solem
  257. .. _v222-fixes:
  258. Fixes
  259. -----
  260. * Celerybeat could not read the schedule properly, so entries in
  261. :setting:`CELERYBEAT_SCHEDULE` would not be scheduled.
  262. * Task error log message now includes `exc_info` again.
  263. * The `eta` argument can now be used with `task.retry`.
  264. Previously it was overwritten by the countdown argument.
  265. * celery multi/celeryd_detach: Now logs errors occuring when executing
  266. the `celery worker` command.
  267. * daemonizing tutorial: Fixed typo ``--time-limit 300`` ->
  268. ``--time-limit=300``
  269. * Colors in logging broke non-string objects in log messages.
  270. * ``setup_task_logger`` no longer makes assumptions about magic task kwargs.
  271. .. _version-2.2.1:
  272. 2.2.1
  273. =====
  274. :release-date: 2011-02-02 04:00 P.M CET
  275. :release-by: Ask Solem
  276. .. _v221-fixes:
  277. Fixes
  278. -----
  279. * Eventlet pool was leaking memory (Issue #308).
  280. * Deprecated function ``celery.execute.delay_task`` was accidentally removed,
  281. now available again.
  282. * ``BasePool.on_terminate`` stub did not exist
  283. * celeryd_detach: Adds readable error messages if user/group name does not
  284. exist.
  285. * Smarter handling of unicode decod errors when logging errors.
  286. .. _version-2.2.0:
  287. 2.2.0
  288. =====
  289. :release-date: 2011-02-01 10:00 AM CET
  290. :release-by: Ask Solem
  291. .. _v220-important:
  292. Important Notes
  293. ---------------
  294. * Carrot has been replaced with `Kombu`_
  295. Kombu is the next generation messaging library for Python,
  296. fixing several flaws present in Carrot that was hard to fix
  297. without breaking backwards compatibility.
  298. Also it adds:
  299. * First-class support for virtual transports; Redis, Django ORM,
  300. SQLAlchemy, Beanstalk, MongoDB, CouchDB and in-memory.
  301. * Consistent error handling with introspection,
  302. * The ability to ensure that an operation is performed by gracefully
  303. handling connection and channel errors,
  304. * Message compression (zlib, bzip2, or custom compression schemes).
  305. This means that `ghettoq` is no longer needed as the
  306. functionality it provided is already available in Celery by default.
  307. The virtual transports are also more feature complete with support
  308. for exchanges (direct and topic). The Redis transport even supports
  309. fanout exchanges so it is able to perform worker remote control
  310. commands.
  311. .. _`Kombu`: http://pypi.python.org/pypi/kombu
  312. * Magic keyword arguments pending deprecation.
  313. The magic keyword arguments were responsibile for many problems
  314. and quirks: notably issues with tasks and decorators, and name
  315. collisions in keyword arguments for the unaware.
  316. It wasn't easy to find a way to deprecate the magic keyword arguments,
  317. but we think this is a solution that makes sense and it will not
  318. have any adverse effects for existing code.
  319. The path to a magic keyword argument free world is:
  320. * the `celery.decorators` module is deprecated and the decorators
  321. can now be found in `celery.task`.
  322. * The decorators in `celery.task` disables keyword arguments by
  323. default
  324. * All examples in the documentation have been changed to use
  325. `celery.task`.
  326. This means that the following will have magic keyword arguments
  327. enabled (old style):
  328. .. code-block:: python
  329. from celery.decorators import task
  330. @task()
  331. def add(x, y, **kwargs):
  332. print("In task %s" % kwargs["task_id"])
  333. return x + y
  334. And this will not use magic keyword arguments (new style):
  335. .. code-block:: python
  336. from celery.task import task
  337. @task()
  338. def add(x, y):
  339. print("In task %s" % add.request.id)
  340. return x + y
  341. In addition, tasks can choose not to accept magic keyword arguments by
  342. setting the `task.accept_magic_kwargs` attribute.
  343. .. admonition:: Deprecation
  344. Using the decorators in :mod:`celery.decorators` emits a
  345. :class:`PendingDeprecationWarning` with a helpful message urging
  346. you to change your code, in version 2.4 this will be replaced with
  347. a :class:`DeprecationWarning`, and in version 4.0 the
  348. :mod:`celery.decorators` module will be removed and no longer exist.
  349. Similarly, the `task.accept_magic_kwargs` attribute will no
  350. longer have any effect starting from version 4.0.
  351. * The magic keyword arguments are now available as `task.request`
  352. This is called *the context*. Using thread-local storage the
  353. context contains state that is related to the current request.
  354. It is mutable and you can add custom attributes that will only be seen
  355. by the current task request.
  356. The following context attributes are always available:
  357. ===================================== ===================================
  358. **Magic Keyword Argument** **Replace with**
  359. ===================================== ===================================
  360. `kwargs["task_id"]` `self.request.id`
  361. `kwargs["delivery_info"]` `self.request.delivery_info`
  362. `kwargs["task_retries"]` `self.request.retries`
  363. `kwargs["logfile"]` `self.request.logfile`
  364. `kwargs["loglevel"]` `self.request.loglevel`
  365. `kwargs["task_is_eager` `self.request.is_eager`
  366. **NEW** `self.request.args`
  367. **NEW** `self.request.kwargs`
  368. ===================================== ===================================
  369. In addition, the following methods now automatically uses the current
  370. context, so you don't have to pass `kwargs` manually anymore:
  371. * `task.retry`
  372. * `task.get_logger`
  373. * `task.update_state`
  374. * `Eventlet`_ support.
  375. This is great news for I/O-bound tasks!
  376. To change pool implementations you use the :option:`-P|--pool` argument
  377. to :program:`celery worker`, or globally using the
  378. :setting:`CELERYD_POOL` setting. This can be the full name of a class,
  379. or one of the following aliases: `processes`, `eventlet`, `gevent`.
  380. For more information please see the :ref:`concurrency-eventlet` section
  381. in the User Guide.
  382. .. admonition:: Why not gevent?
  383. For our first alternative concurrency implementation we have focused
  384. on `Eventlet`_, but there is also an experimental `gevent`_ pool
  385. available. This is missing some features, notably the ability to
  386. schedule ETA tasks.
  387. Hopefully the `gevent`_ support will be feature complete by
  388. version 2.3, but this depends on user demand (and contributions).
  389. .. _`Eventlet`: http://eventlet.net
  390. .. _`gevent`: http://gevent.org
  391. * Python 2.4 support deprecated!
  392. We're happy^H^H^H^H^Hsad to announce that this is the last version
  393. to support Python 2.4.
  394. You are urged to make some noise if you're currently stuck with
  395. Python 2.4. Complain to your package maintainers, sysadmins and bosses:
  396. tell them it's time to move on!
  397. Apart from wanting to take advantage of with-statements, coroutines,
  398. conditional expressions and enhanced try blocks, the code base
  399. now contains so many 2.4 related hacks and workarounds it's no longer
  400. just a compromise, but a sacrifice.
  401. If it really isn't your choice, and you don't have the option to upgrade
  402. to a newer version of Python, you can just continue to use Celery 2.2.
  403. Important fixes can be backported for as long as there is interest.
  404. * worker: Now supports Autoscaling of child worker processes.
  405. The :option:`--autoscale` option can be used to configure the minimum
  406. and maximum number of child worker processes::
  407. --autoscale=AUTOSCALE
  408. Enable autoscaling by providing
  409. max_concurrency,min_concurrency. Example:
  410. --autoscale=10,3 (always keep 3 processes, but grow to
  411. 10 if necessary).
  412. * Remote Debugging of Tasks
  413. ``celery.contrib.rdb`` is an extended version of :mod:`pdb` that
  414. enables remote debugging of processes that does not have terminal
  415. access.
  416. Example usage:
  417. .. code-block:: python
  418. from celery.contrib import rdb
  419. from celery.task import task
  420. @task()
  421. def add(x, y):
  422. result = x + y
  423. rdb.set_trace() # <- set breakpoint
  424. return result
  425. :func:`~celery.contrib.rdb.set_trace` sets a breakpoint at the current
  426. location and creates a socket you can telnet into to remotely debug
  427. your task.
  428. The debugger may be started by multiple processes at the same time,
  429. so rather than using a fixed port the debugger will search for an
  430. available port, starting from the base port (6900 by default).
  431. The base port can be changed using the environment variable
  432. :envvar:`CELERY_RDB_PORT`.
  433. By default the debugger will only be available from the local host,
  434. to enable access from the outside you have to set the environment
  435. variable :envvar:`CELERY_RDB_HOST`.
  436. When the worker encounters your breakpoint it will log the following
  437. information::
  438. [INFO/MainProcess] Received task:
  439. tasks.add[d7261c71-4962-47e5-b342-2448bedd20e8]
  440. [WARNING/PoolWorker-1] Remote Debugger:6900:
  441. Please telnet 127.0.0.1 6900. Type `exit` in session to continue.
  442. [2011-01-18 14:25:44,119: WARNING/PoolWorker-1] Remote Debugger:6900:
  443. Waiting for client...
  444. If you telnet the port specified you will be presented
  445. with a ``pdb`` shell:
  446. .. code-block:: console
  447. $ telnet localhost 6900
  448. Connected to localhost.
  449. Escape character is '^]'.
  450. > /opt/devel/demoapp/tasks.py(128)add()
  451. -> return result
  452. (Pdb)
  453. Enter ``help`` to get a list of available commands,
  454. It may be a good idea to read the `Python Debugger Manual`_ if
  455. you have never used `pdb` before.
  456. .. _`Python Debugger Manual`: http://docs.python.org/library/pdb.html
  457. * Events are now transient and is using a topic exchange (instead of direct).
  458. The `CELERYD_EVENT_EXCHANGE`, `CELERYD_EVENT_ROUTING_KEY`,
  459. `CELERYD_EVENT_EXCHANGE_TYPE` settings are no longer in use.
  460. This means events will not be stored until there is a consumer, and the
  461. events will be gone as soon as the consumer stops. Also it means there
  462. can be multiple monitors running at the same time.
  463. The routing key of an event is the type of event (e.g. `worker.started`,
  464. `worker.heartbeat`, `task.succeeded`, etc. This means a consumer can
  465. filter on specific types, to only be alerted of the events it cares about.
  466. Each consumer will create a unique queue, meaning it is in effect a
  467. broadcast exchange.
  468. This opens up a lot of possibilities, for example the workers could listen
  469. for worker events to know what workers are in the neighborhood, and even
  470. restart workers when they go down (or use this information to optimize
  471. tasks/autoscaling).
  472. .. note::
  473. The event exchange has been renamed from "celeryevent" to "celeryev"
  474. so it does not collide with older versions.
  475. If you would like to remove the old exchange you can do so
  476. by executing the following command:
  477. .. code-block:: console
  478. $ camqadm exchange.delete celeryevent
  479. * The worker now starts without configuration, and configuration can be
  480. specified directly on the command-line.
  481. Configuration options must appear after the last argument, separated
  482. by two dashes:
  483. .. code-block:: console
  484. $ celery worker -l info -I tasks -- broker.host=localhost broker.vhost=/app
  485. * Configuration is now an alias to the original configuration, so changes
  486. to the original will reflect Celery at runtime.
  487. * `celery.conf` has been deprecated, and modifying `celery.conf.ALWAYS_EAGER`
  488. will no longer have any effect.
  489. The default configuration is now available in the
  490. :mod:`celery.app.defaults` module. The available configuration options
  491. and their types can now be introspected.
  492. * Remote control commands are now provided by `kombu.pidbox`, the generic
  493. process mailbox.
  494. * Internal module `celery.worker.listener` has been renamed to
  495. `celery.worker.consumer`, and `.CarrotListener` is now `.Consumer`.
  496. * Previously deprecated modules `celery.models` and
  497. `celery.management.commands` have now been removed as per the deprecation
  498. timeline.
  499. * [Security: Low severity] Removed `celery.task.RemoteExecuteTask` and
  500. accompanying functions: `dmap`, `dmap_async`, and `execute_remote`.
  501. Executing arbitrary code using pickle is a potential security issue if
  502. someone gains unrestricted access to the message broker.
  503. If you really need this functionality, then you would have to add
  504. this to your own project.
  505. * [Security: Low severity] The `stats` command no longer transmits the
  506. broker password.
  507. One would have needed an authenticated broker connection to receive
  508. this password in the first place, but sniffing the password at the
  509. wire level would have been possible if using unencrypted communication.
  510. .. _v220-news:
  511. News
  512. ----
  513. * The internal module `celery.task.builtins` has been removed.
  514. * The module `celery.task.schedules` is deprecated, and
  515. `celery.schedules` should be used instead.
  516. For example if you have::
  517. from celery.task.schedules import crontab
  518. You should replace that with::
  519. from celery.schedules import crontab
  520. The module needs to be renamed because it must be possible
  521. to import schedules without importing the `celery.task` module.
  522. * The following functions have been deprecated and is scheduled for
  523. removal in version 2.3:
  524. * `celery.execute.apply_async`
  525. Use `task.apply_async()` instead.
  526. * `celery.execute.apply`
  527. Use `task.apply()` instead.
  528. * `celery.execute.delay_task`
  529. Use `registry.tasks[name].delay()` instead.
  530. * Importing `TaskSet` from `celery.task.base` is now deprecated.
  531. You should use::
  532. >>> from celery.task import TaskSet
  533. instead.
  534. * New remote control commands:
  535. * `active_queues`
  536. Returns the queue declarations a worker is currently consuming from.
  537. * Added the ability to retry publishing the task message in
  538. the event of connection loss or failure.
  539. This is disabled by default but can be enabled using the
  540. :setting:`CELERY_TASK_PUBLISH_RETRY` setting, and tweaked by
  541. the :setting:`CELERY_TASK_PUBLISH_RETRY_POLICY` setting.
  542. In addition `retry`, and `retry_policy` keyword arguments have
  543. been added to `Task.apply_async`.
  544. .. note::
  545. Using the `retry` argument to `apply_async` requires you to
  546. handle the publisher/connection manually.
  547. * Periodic Task classes (`@periodic_task`/`PeriodicTask`) will *not* be
  548. deprecated as previously indicated in the source code.
  549. But you are encouraged to use the more flexible
  550. :setting:`CELERYBEAT_SCHEDULE` setting.
  551. * Built-in daemonization support of the worker using `celery multi`
  552. is no longer experimental and is considered production quality.
  553. See :ref:`daemon-generic` if you want to use the new generic init
  554. scripts.
  555. * Added support for message compression using the
  556. :setting:`CELERY_MESSAGE_COMPRESSION` setting, or the `compression` argument
  557. to `apply_async`. This can also be set using routers.
  558. * worker: Now logs stacktrace of all threads when receiving the
  559. `SIGUSR1` signal. (Does not work on cPython 2.4, Windows or Jython).
  560. Inspired by https://gist.github.com/737056
  561. * Can now remotely terminate/kill the worker process currently processing
  562. a task.
  563. The `revoke` remote control command now supports a `terminate` argument
  564. Default signal is `TERM`, but can be specified using the `signal`
  565. argument. Signal can be the uppercase name of any signal defined
  566. in the :mod:`signal` module in the Python Standard Library.
  567. Terminating a task also revokes it.
  568. Example::
  569. >>> from celery.task.control import revoke
  570. >>> revoke(task_id, terminate=True)
  571. >>> revoke(task_id, terminate=True, signal="KILL")
  572. >>> revoke(task_id, terminate=True, signal="SIGKILL")
  573. * `TaskSetResult.join_native`: Backend-optimized version of `join()`.
  574. If available, this version uses the backends ability to retrieve
  575. multiple results at once, unlike `join()` which fetches the results
  576. one by one.
  577. So far only supported by the AMQP result backend. Support for memcached
  578. and Redis may be added later.
  579. * Improved implementations of `TaskSetResult.join` and `AsyncResult.wait`.
  580. An `interval` keyword argument have been added to both so the
  581. polling interval can be specified (default interval is 0.5 seconds).
  582. A `propagate` keyword argument have been added to `result.wait()`,
  583. errors will be returned instead of raised if this is set to False.
  584. .. warning::
  585. You should decrease the polling interval when using the database
  586. result backend, as frequent polling can result in high database load.
  587. * The PID of the child worker process accepting a task is now sent as a field
  588. with the :event:`task-started` event.
  589. * The following fields have been added to all events in the worker class:
  590. * `sw_ident`: Name of worker software (e.g. py-celery).
  591. * `sw_ver`: Software version (e.g. 2.2.0).
  592. * `sw_sys`: Operating System (e.g. Linux, Windows, Darwin).
  593. * For better accuracy the start time reported by the multiprocessing worker
  594. process is used when calculating task duration.
  595. Previously the time reported by the accept callback was used.
  596. * `celerybeat`: New built-in daemonization support using the `--detach`
  597. option.
  598. * `celeryev`: New built-in daemonization support using the `--detach`
  599. option.
  600. * `TaskSet.apply_async`: Now supports custom publishers by using the
  601. `publisher` argument.
  602. * Added :setting:`CELERY_SEND_TASK_SENT_EVENT` setting.
  603. If enabled an event will be sent with every task, so monitors can
  604. track tasks before the workers receive them.
  605. * `celerybeat`: Now reuses the broker connection when calling
  606. scheduled tasks.
  607. * The configuration module and loader to use can now be specified on
  608. the command-line.
  609. For example:
  610. .. code-block:: console
  611. $ celery worker --config=celeryconfig.py --loader=myloader.Loader
  612. * Added signals: `beat_init` and `beat_embedded_init`
  613. * :signal:`celery.signals.beat_init`
  614. Dispatched when :program:`celerybeat` starts (either standalone or
  615. embedded). Sender is the :class:`celery.beat.Service` instance.
  616. * :signal:`celery.signals.beat_embedded_init`
  617. Dispatched in addition to the :signal:`beat_init` signal when
  618. :program:`celerybeat` is started as an embedded process. Sender
  619. is the :class:`celery.beat.Service` instance.
  620. * Redis result backend: Removed deprecated settings `REDIS_TIMEOUT` and
  621. `REDIS_CONNECT_RETRY`.
  622. * CentOS init script for :program:`celery worker` now available in `extra/centos`.
  623. * Now depends on `pyparsing` version 1.5.0 or higher.
  624. There have been reported issues using Celery with pyparsing 1.4.x,
  625. so please upgrade to the latest version.
  626. * Lots of new unit tests written, now with a total coverage of 95%.
  627. .. _v220-fixes:
  628. Fixes
  629. -----
  630. * `celeryev` Curses Monitor: Improved resize handling and UI layout
  631. (Issue #274 + Issue #276)
  632. * AMQP Backend: Exceptions occurring while sending task results are now
  633. propagated instead of silenced.
  634. the worker will then show the full traceback of these errors in the log.
  635. * AMQP Backend: No longer deletes the result queue after successful
  636. poll, as this should be handled by the
  637. :setting:`CELERY_AMQP_TASK_RESULT_EXPIRES` setting instead.
  638. * AMQP Backend: Now ensures queues are declared before polling results.
  639. * Windows: worker: Show error if running with `-B` option.
  640. Running celerybeat embedded is known not to work on Windows, so
  641. users are encouraged to run celerybeat as a separate service instead.
  642. * Windows: Utilities no longer output ANSI color codes on Windows
  643. * camqadm: Now properly handles Ctrl+C by simply exiting instead of showing
  644. confusing traceback.
  645. * Windows: All tests are now passing on Windows.
  646. * Remove bin/ directory, and `scripts` section from setup.py.
  647. This means we now rely completely on setuptools entrypoints.
  648. .. _v220-experimental:
  649. Experimental
  650. ------------
  651. * Jython: worker now runs on Jython using the threaded pool.
  652. All tests pass, but there may still be bugs lurking around the corners.
  653. * PyPy: worker now runs on PyPy.
  654. It runs without any pool, so to get parallel execution you must start
  655. multiple instances (e.g. using :program:`multi`).
  656. Sadly an initial benchmark seems to show a 30% performance decrease on
  657. pypy-1.4.1 + JIT. We would like to find out why this is, so stay tuned.
  658. * :class:`PublisherPool`: Experimental pool of task publishers and
  659. connections to be used with the `retry` argument to `apply_async`.
  660. The example code below will re-use connections and channels, and
  661. retry sending of the task message if the connection is lost.
  662. .. code-block:: python
  663. from celery import current_app
  664. # Global pool
  665. pool = current_app().amqp.PublisherPool(limit=10)
  666. def my_view(request):
  667. with pool.acquire() as publisher:
  668. add.apply_async((2, 2), publisher=publisher, retry=True)