announcement.rst 5.7 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163
  1. ===============================
  2. Celery 1.0 has been released!
  3. ===============================
  4. We're happy to announce the release of Celery 1.0.
  5. What is it?
  6. ===========
  7. Celery is a task queue/job queue based on distributed message passing.
  8. It is focused on real-time operation, but supports scheduling as well.
  9. The execution units, called tasks, are executed concurrently on one or
  10. more worker servers. Tasks can execute asynchronously (in the background) or synchronously
  11. (wait until ready).
  12. Celery is already used in production to process millions of tasks a day.
  13. Celery was originally created for use with Django, but is now usable
  14. from any Python project. It can
  15. also operate with other languages via webhooks.
  16. The recommended message broker is `RabbitMQ`_, but support for Redis and
  17. databases is also available.
  18. .. _`RabbitMQ`: http://rabbitmq.org
  19. Features
  20. --------
  21. See http://celery.github.com/celery/getting-started/introduction.html#features
  22. Stable API
  23. ==========
  24. From this version on the public API is considered stable. This means there won't
  25. be any backwards incompatible changes in new minor versions. Changes to the
  26. API will be deprecated; so, for example, if we decided to remove a function
  27. that existed in Celery 1.0:
  28. * Celery 1.2 will contain a backwards-compatible replica of the function which
  29. will raise a `PendingDeprecationWarning`.
  30. This warning is silent by default; you need to explicitly turn on display
  31. of these warnings.
  32. * Celery 1.4 will contain the backwards-compatible replica, but the warning
  33. will be promoted to a full-fledged `DeprecationWarning`. This warning
  34. is loud by default, and will likely be quite annoying.
  35. * Celery 1.6 will remove the feature outright.
  36. See the `Celery Deprecation Timeline`_ for a list of pending removals.
  37. .. _`Celery Deprecation Timeline`:
  38. http://celery.github.com/celery/internals/deprecation.html
  39. What's new?
  40. ===========
  41. * Task decorators
  42. Write tasks as regular functions and decorate them.
  43. There are both :func:`task`, and :func:`periodic_task` decorators.
  44. * Tasks are automatically registered
  45. Registering the tasks manually was getting tedious, so now you don't have
  46. to anymore. You can still do it manually if you need to, just
  47. disable :attr:`Task.autoregister`. The concept of abstract task classes
  48. has also been introduced, this is like django models, where only the
  49. subclasses of an abstract task is registered.
  50. * Events
  51. If enabled, the worker will send events, telling you what tasks it
  52. executes, their results, and how long it took to execute them. It also
  53. sends out heartbeats, so listeners are able to detect nonfunctional
  54. workers. This is the basis for the new real-time web monitor we're working on
  55. (`celerymon`_).
  56. .. _`celerymon`: http://github.com/celery/celerymon/
  57. * Rate limiting
  58. Global and per task rate limits. 10 tasks a second? or one an hour? You
  59. decide. It's using the awesome `token bucket algorithm`_, which is
  60. commonly used for network traffic shaping. It accounts for bursts of
  61. activity, so your workers won't be bored by having nothing to do.
  62. .. _`token bucket algorithm`: http://en.wikipedia.org/wiki/Token_bucket
  63. * New periodic task service.
  64. Periodic tasks are no longer dispatched by `celeryd`, but instead by a
  65. separate service called `celerybeat`. This is an optimized, centralized
  66. service dedicated to your periodic tasks, which means you don't have to
  67. worry about deadlocks or race conditions any more. But that does mean you
  68. have to make sure only one instance of this service is running at any one
  69. time.
  70. **TIP:** If you're only running a single `celeryd` server, you can embed
  71. `celerybeat` inside it. Just add the `--beat` argument.
  72. * Broadcast commands
  73. If you change your mind and don't want to run a task after all, you
  74. now have the option to revoke it.
  75. Also, you can rate limit tasks or even shut down the worker remotely.
  76. It doesn't have many commands yet, but we're waiting for broadcast
  77. commands to reach its full potential, so please share your ideas
  78. if you have any.
  79. * Multiple queues
  80. The worker is able to receive tasks on multiple queues at once.
  81. This opens up a lot of new possibilities when combined with the impressive
  82. routing support in AMQP.
  83. * Platform agnostic message format.
  84. The message format has been standardized and is now using the ISO-8601 format
  85. for dates instead of Python `datetime` objects. This means you can write task
  86. consumers in other languages than Python (`eceleryd` anyone?)
  87. * Timely
  88. Periodic tasks are now scheduled on the clock, i.e. `timedelta(hours=1)`
  89. means every hour at :00 minutes, not every hour from the server starts.
  90. To revert to the previous behavior you have the option to enable
  91. :attr:`PeriodicTask.relative`.
  92. * ... and a lot more!
  93. To read about these and other changes in detail, please refer to
  94. the `changelog`_. This document contains crucial information for those
  95. upgrading from a previous version of Celery, so be sure to read the entire
  96. change set before you continue.
  97. .. _`changelog`: http://celery.github.com/celery/changelog.html
  98. **TIP:** If you install the :mod:`setproctitle` module you can see which
  99. task each worker process is currently executing in `ps` listings.
  100. Just install it using pip: `pip install setproctitle`.
  101. Resources
  102. =========
  103. * Homepage: http://celeryproject.org
  104. * Download: http://pypi.python.org/pypi/celery
  105. * Documentation: http://docs.celeryproject.org/
  106. * Changelog: http://docs.celeryproject.org/changelog.html
  107. * Code: http://github.com/celery/celery/
  108. * FAQ: http://celery.github.com/celery/faq.html
  109. * Mailing-list: http://groups.google.com/group/celery-users
  110. * IRC: #celery on irc.freenode.net.