release-date: | 2012-07-07 01:30 P.M BST | -
---|---|
by: | Ask Solem | -
release-date: | 2012-06-06 16:00 P.M BST | -
---|---|
by: | Ask Solem | -
This is a dummy release performed for the following goals:
-If you’re looking for versions prior to 3.x you should see History.
+release-date: | 2012-04-16 07:00 P.M BST | +
---|---|
state: | DEVEL |
by: | Ask Solem | +
branch: | master |
release-date: | 2012-04-13 04:30 P.M GMT | -
---|---|
by: | Ask Solem | +
release-date: | 2012-07-26 07:00 P.M BST |
Now depends on Kombu 2.1.5.
+Now depends on Kombu 2.3
Django documentation has been moved to the main Celery docs.
+New experimental standalone Celery monitor: Flower
-See Django.
+-See Celery Flower: Web interface to read more about it!
+Contributed by Mher Movsisyan.
- -
New celeryd_init signal can be used to configure workers -by hostname.
-Signal.connect can now be used as a decorator.
+Now supports AMQP heartbeats if using the new pyamqp:// transport.
-Example:
-+from celery.signals import task_sent - -@task_sent.connect -def on_task_sent(**kwargs): - print("sent task: %r" % (kwargs, )) -- -+
The py-amqp transport requires the amqp library to be installed:
+-$ pip install amqp- -
Invalid task messages are now rejected instead of acked.
--This means that they will be moved to the dead-letter queue -introduced in the latest RabbitMQ version (but must be enabled -manually, consult the RabbitMQ documentation).
-Internal logging calls has been cleaned up to work -better with tools like Sentry.
--+Contributed by David Cramer.
-- -
Then you need to set the transport URL prefix to pyamqp://.
New method subtask.clone() can be used to clone an existing -subtask with augmented arguments/options.
---Example:
--->>> s = add.subtask((5, )) ->>> new = s.clone(args=(10, ), countdown=5}) ->>> new.args -(10, 5) - ->>> new.options -{"countdown": 5} +The default heartbeat value is 10 seconds, but this can be changed using +the BROKER_HEARTBEAT setting:
+-BROKER_HEARTBEAT = 5.0Chord callbacks are now triggered in eager mode.
+- + +
If the broker heartbeat is set to 10 seconds, the heartbeats will be +monitored every 5 seconds (double the hertbeat rate).
+See the Kombu 2.3 changelog for more information.
+-Fixes¶
-
Programs now verifies that the pidfile is actually written correctly -(Issue #641).
---Hopefully this will crash the worker immediately if the system -is out of space to store the complete pidfile.
-In addition, we now verify that existing pidfiles contain -a new line so that a partially written pidfile is detected as broken, -as before doing:
+- -
Now supports RabbitMQ Consumer Cancel Notifications, using the pyamqp:// +transport.
--echo -n “1” > celeryd.pid
-would cause celeryd to think that an existing instance was already -running (init has pid 1 after all).
+This is essential when running RabbitMQ in a cluster.
+See the Kombu 2.3 changelog for more information.
Fixed 2.5 compatibility issue with use of print_exception.
+Delivery info is no longer passed directly through.
-Fix contributed by Martin Melin.
+-It was discovered that the SQS transport adds objects that can’t +be pickled to the delivery info mapping, so we had to go back +to using the whitelist again.
+Fixing this bug also means that the SQS transport is now working again.
Fixed 2.5 compatibility issue with imports.
+The semaphore was not properly released when a task was revoked (Issue #877).
-Fix contributed by Iurii Kriachko.
+-This could lead to tasks being swallowed and not released until a worker +restart.
+Thanks to Hynek Schlawack for debugging the issue.
All programs now fix up __package__ when called as main.
+Retrying a task now also forwards any linked tasks.
--This fixes compatibility with Python 2.5.
-Fix contributed by Martin Melin.
+-This means that if a task is part of a chain (or linked in some other +way) and that even if the task is retried, then the next task in the chain +will be executed when the retry succeeds.
celeryctl can now be configured on the command line.
+Chords: Now supports setting the interval and other keyword arguments +to the chord unlock task.
+++
- +
The interval can now be set as part of the chord subtasks kwargs:
+++chord(header)(body, interval=10.0) +In addition the chord unlock task now honors the Task.default_retry_delay +option, used when none is specified, which also means that the default +interval can also be changed using annotations:
-Like with celeryd it is now possible to configure celery settings -on the command line for celeryctl:
-+ +$ celeryctl -- broker.pool_limit=30+-CELERY_ANNOTATIONS = { + 'celery.chord_unlock': { + 'default_retry_delay': 10.0, + } +} +Version dependency for python-dateutil fixed to be strict.
+ +New Celery.add_defaults() method can add new default configuration +dicts to the applications configuration.
-diff --git a/userguide/calling.html b/userguide/calling.html index 94ec7a27354..4be35d5f111 100644 --- a/userguide/calling.html +++ b/userguide/calling.html @@ -204,7 +204,7 @@Fix contributed by Thomas Meson.
+-For example:
+++config = {'FOO': 10} + +celery.add_defaults(config) +is the same as celery.conf.update(config) except that data will not be +copied, and that it will not be pickled when the worker spawns child +processes.
+In addition the method accepts a callable:
++def initialize_config(): + # insert heavy stuff that can't be done at import time here. + +celery.add_defaults(initialize_config)+which means the same as the above except that it will not happen +until the celery configuration is actually used.
+As an example, Celery can lazily use the configuration of a Flask app:
++flask_app = Flask() +celery = Celery() +celery.add_defaults(lambda: flask_app.config) +Task.__call__ is now optimized away in the task tracer -rather than when the task class is created.
+Revoked tasks were not marked as revoked in the result backend (Issue #871).
--This fixes a bug where a custom __call__ may mysteriously disappear.
+-Fix contributed by Hynek Schlawack.
Autoreload’s inotify support has been improved.
+- +
Eventloop now properly handles the case when the epoll poller object +has been closed (Issue #882).
+Fixed syntax error in funtests/test_leak.py
--Contributed by Mher Movsisyan.
+-Fix contributed by Catalin Iacob.
The Django broker documentation has been improved.
+- -
group/chunks: Now accepts empty task list (Issue #873).
Removed confusing warning at top of routing user guide.
+New method names:
+++
+- Celery.default_connection() ➠ connection_or_acquire().
+- Celery.default_producer() ➠ producer_or_acquire().
+The old names still work for backward compatibility.
+-2.5.1¶
++-3.0.3¶
-
- release-date: 2012-03-01 01:00 P.M GMT +release-date: 2012-07-20 09:17 P.M BST by: Ask Solem --Fixes¶
-
- Eventlet/Gevent: A small typo caused celeryd to hang when eventlet/gevent -was used, this was because the environment was not monkey patched -early enough.
-- Eventlet/Gevent: Another small typo caused the mediator to be started -with eventlet/gevent, which would make celeryd sometimes hang at shutdown.
-- Mulitprocessing: Fixed an error occurring if the pool was stopped -before it was properly started.
-- Proxy objects now redirects __doc__ and __name__ so help(obj) -works.
-- Internal timer (timer2) now logs exceptions instead of swallowing them -(Issue #626).
-- celeryctl shell: can now be started with --eventlet or ---gevent options to apply their monkey patches.
+- amqplib passes the channel object as part of the delivery_info +and it’s not pickleable, so we now remove it.
--2.5.0¶
--
- -- - - - release-date: 2012-02-24 04:00 P.M GMT -- - by: Ask Solem -Since the changelog has gained considerable size, we decided to -do things differently this time: by having separate “what’s new” -documents for major version changes.
-Bugfix releases will still be found in the changelog.
--@@ -456,7 +456,7 @@2.4.5¶
++-3.0.2¶
- release-date: 2011-12-02 05:00 P.M GMT +release-date: 2012-07-20 04:00 P.M BST by: Ask Solem -
-Periodic task interval schedules were accidentally rounded down, -resulting in some periodic tasks being executed early.
+- -
+
- A bug caused the following task options to not take defaults from the
+- +
configuration (Issue #867 + Issue #858)
+++The following settings were affected:
++
+- CELERY_IGNORE_RESULT
+- CELERYD_SEND_TASK_ERROR_EMAILS
+- CELERY_TRACK_STARTED
+- CElERY_STORE_ERRORS_EVEN_IF_IGNORED
+Fix contributed by John Watson.
+Logging of humanized times in the celerybeat log is now more detailed.
+- -
Task Request: delivery_info is now passed through as-is (Issue #807).
New Brokers section in the Getting Started part of the Documentation
--+This replaces the old Using Celery with Redis/Database as the messaging queue. tutorial, and adds -documentation for MongoDB, Beanstalk and CouchDB.
-- -
The eta argument now supports datetime’s with a timezone set (Issue #855).
-2.4.4¶
--
-- - - - release-date: 2011-11-25 16:00 P.M GMT -- - by: Ask Solem ---Security Fixes¶
--
-[Security: CELERYSA-0001] Daemons would set effective id’s rather than -real id’s when the --uid/--gid arguments to -celeryd-multi, celeryd_detach, -celerybeat and celeryev were used.
-This means privileges weren’t properly dropped, and that it would -be possible to regain supervisor privileges later.
+- -
The worker’s banner displayed the autoscale settings in the wrong order +(Issue #859).
-diff --git a/userguide/application.html b/userguide/application.html index 742f3c3a9e6..810ecb76cbe 100644 --- a/userguide/application.html +++ b/userguide/application.html @@ -403,7 +403,7 @@Fixes¶
--
Processes pool: Fixed rare deadlock at shutdown (Issue #523).
+- +
Extension commands are now loaded after concurrency is set up +so that they don’t interfere with e.g. eventlet patching.
+- +
Fixed bug in the threaded pool (Issue #863)
+The task failure handler mixed up the fields in sys.exc_info().
-Fix contributed by Ionel Maries Christian.
+-Fix contributed by Rinat Shigapov.
Webhook tasks issued the wrong HTTP POST headers (Issue #515).
+Fixed typos and wording in the docs.
-The Content-Type header has been changed from -application/json ⇒ application/x-www-form-urlencoded, -and adds a proper Content-Length header.
-Fix contributed by Mitar.
+-Fix contributed by Paul McMillan
Daemonization tutorial: Adds a configuration example using Django and -virtualenv together (Issue #505).
+New setting: CELERY_WORKER_DIRECT
--Contributed by Juan Ignacio Catalano.
+-If enabled each worker will consume from their own dedicated queue +which can be used to route tasks to specific workers.
generic init scripts now automatically creates log and pid file -directories (Issue #545).
+- +
Fixed several edge case bugs in the add consumer remote control command.
+migrate: Can now filter and move tasks to specific +workers if CELERY_WORKER_DIRECT is enabled.
--Contributed by Chris Streeter.
++Among other improvements, the following functions have been added:
+++
+- move_direct(filterfun, **opts)
+- move_direct_by_id(task_id, worker_hostname, **opts)
+- move_direct_by_idmap({task_id: worker_hostname, ...}, **opts)
+- move_direct_by_taskmap({task_name: worker_hostname, ...}, **opts)
+- +
default_connection() now accepts a pool argument that +if set to false causes a new connection to be created instead of acquiring +one from the pool.
+- +
New signal: celeryd_after_setup.
+Default loader now keeps lowercase attributes from the configuration module.
+-2.4.3¶
++-3.0.1¶
- release-date: 2011-11-22 18:00 P.M GMT +release-date: 2012-07-10 06:00 P.M BST by: Ask Solem -
-Fixes module import typo in celeryctl (Issue #538).
--+Fix contributed by Chris Streeter.
-- -
Now depends on kombu 2.2.5
--2.4.2¶
--
-- - - - release-date: 2011-11-14 12:00 P.M GMT -- - by: Ask Solem --
-- Program module no longer uses relative imports so that it is -possible to do python -m celery.bin.name.
--2.4.1¶
--
-- - - - release-date: 2011-11-07 06:00 P.M GMT -- - by: Ask Solem --
+- celeryctl inspect commands was missing output.
-- processes pool: Decrease polling interval for less idle CPU usage.
-- processes pool: MaybeEncodingError was not wrapped in ExceptionInfo -(Issue #524).
-- celeryd: would silence errors occuring after task consumer started.
-- logging: Fixed a bug where unicode in stdout redirected log messages -couldn’t be written (Issue #522).
-inspect now supports limit argument:
+-myapp.control.inspect(limit=1).ping() +-diff --git a/reference/celery.events.html b/reference/celery.events.html index 8edce43d030..c187e823648 100644 --- a/reference/celery.events.html +++ b/reference/celery.events.html @@ -191,14 +191,8 @@2.4.0¶
--
-- - - - release-date: 2011-11-04 04:00 P.M GMT -- - by: Ask Solem --diff --git a/reference/celery.bin.celery.html b/reference/celery.bin.celery.html index 8c90a7cad12..54f21f2e7fe 100644 --- a/reference/celery.bin.celery.html +++ b/reference/celery.bin.celery.html @@ -109,6 +109,11 @@Important Notes¶
--
- -
Now supports Python 3.
Fixed deadlock in worker process handling (Issue #496).
+- +
Beat: now works with timezone aware datetime’s.
+- +
Task classes inheriting from celery import Task +mistakingly enabled accept_magic_kwargs.
+- +
Fixed bug in inspect scheduled (Issue #829).
+- +
Beat: Now resets the schedule to upgrade to UTC.
+The celery worker command now works with eventlet/gevent.
-diff --git a/reference/celery.app.utils.html b/reference/celery.app.utils.html index 14680f7f6d0..6a13cc1ba16 100644 --- a/reference/celery.app.utils.html +++ b/reference/celery.app.utils.html @@ -106,7 +106,7 @@A deadlock could occur after spawning new child processes because -the logging library’s mutex was not properly reset after fork.
-The symptoms of this bug affecting would be that the worker simply -stops processing tasks, as none of the workers child processes -are functioning. There was a greater chance of this bug occurring -with maxtasksperchild or a time-limit enabled.
-This is a workaround for http://bugs.python.org/issue6721#msg140215.
-Be aware that while this fixes the logging library lock, -there could still be other locks initialized in the parent -process, introduced by custom code.
-Fix contributed by Harm Verhagen.
+-Previously it would not patch the environment early enough.
AMQP Result backend: Now expires results by default.
+The celery command now supports extension commands +using setuptools entry-points.
-diff --git a/reference/celery.app.task.html b/reference/celery.app.task.html index bced4b76280..21773825e15 100644 --- a/reference/celery.app.task.html +++ b/reference/celery.app.task.html @@ -342,7 +342,7 @@The default expiration value is now taken from the -CELERY_TASK_RESULT_EXPIRES setting.
-The old CELERY_AMQP_TASK_RESULT_EXPIRES setting has been -deprecated and will be removed in version 4.0.
-Note that this means that the result backend requires RabbitMQ 1.1.0 or -higher, and that you have to disable expiration if you are running -with an older version. You can do so by disabling the -CELERY_TASK_RESULT_EXPIRES setting:
-+CELERY_TASK_RESULT_EXPIRES = None --Libraries can add additional commands to the celery +command by adding an entry-point like:
++setup( + entry_points=[ + 'celery.commands': [ + 'foo = my.module:Command', + ], +], +...)The command must then support the interface of +celery.bin.base.Command.
- -
Eventlet: Fixed problem with shutdown (Issue #457).
-Broker transports can be now be specified using URLs
--The broker can now be specified as an URL instead. -This URL must have the format:
--transport://user:password@hostname:port/virtual_host-for example the default broker is written as:
--amqp://guest:guest@localhost:5672//-The scheme is required, so that the host is identified -as an URL and not just a host name. -User, password, port and virtual_host are optional and -defaults to the particular transports default value.
---Note
-Note that the path component (virtual_host) always starts with a -forward-slash. This is necessary to distinguish between the virtual -host '' (empty) and '/', which are both acceptable virtual -host names.
-A virtual host of '/' becomes:
+contrib.migrate: New utilities to move tasks from one queue to another.
--amqp://guest:guest@localhost:5672//
-and a virtual host of '' (empty) becomes:
--amqp://guest:guest@localhost:5672/-So the leading slash in the path component is always required.
-In addition the BROKER_URL setting has been added as an alias -to BROKER_HOST. Any broker setting specified in both the URL and in -the configuration will be ignored, if a setting is not provided in the URL -then the value from the configuration will be used as default.
-Also, programs now support the -b|--broker option to specify -a broker URL on the command line:
--$ celeryd -b redis://localhost - -$ celeryctl -b amqp://guest:guest@localhost//e-The environment variable CELERY_BROKER_URL can also be used to -easily override the default broker used.
+-+
- move_tasks()
+- move_task_by_id()
+The deprecated celery.loaders.setup_loader() function has been removed.
+- -
The task-sent event now contains exchange and routing_key +fields.
The CELERY_TASK_ERROR_WHITELIST setting has been replaced -by a more flexible approach (Issue #447).
+Fixes bug with installing on Python 3.
-The error mail sending logic is now available as Task.ErrorMail, -with the implementation (for reference) in celery.utils.mail.
-The error mail class can be sub-classed to gain complete control -of when error messages are sent, thus removing the need for a separate -white-list setting.
-The CELERY_TASK_ERROR_WHITELIST setting has been deprecated, -and will be removed completely in version 4.0.
+-Fix contributed by Jed Smith.
Additional Deprecations
--The following functions has been deprecated and is scheduled for removal in -version 4.0:
--
-- - -- - - - - - Old function
-- Alternative
-- - celery.loaders.current_loader
-- celery.current_app.loader
-- - celery.loaders.load_settings
-- celery.current_app.conf
-- - celery.execute.apply
-- Task.apply
-- - celery.execute.apply_async
-- Task.apply_async
-- - - celery.execute.delay_task
-- celery.execute.send_task
-The following settings has been deprecated and is scheduled for removal -in version 4.0:
--
diff --git a/faq.html b/faq.html index c6b4809ed8d..09a681a7645 100644 --- a/faq.html +++ b/faq.html @@ -638,7 +638,7 @@- - -- - - + + + - Old setting
-- Alternative
-+- - - -3.0.0 (Chiastic Slide)¶
++
-+ - - - CELERYD_LOG_LEVEL
-- celeryd --loglevel=
-- - CELERYD_LOG_FILE
-- celeryd --logfile=
-- - CELERYBEAT_LOG_LEVEL
-- celerybeat --loglevel=
-- - CELERYBEAT_LOG_FILE
-- celerybeat --logfile=
-- CELERYMON_LOG_LEVEL
-+ celerymon --loglevel=
-- release-date: 2012-07-07 01:30 P.M BST - CELERYMON_LOG_FILE
-+ celerymon --logfile=
-by: Ask Solem -- -News¶
--
-- -
No longer depends on pyparsing.
-- -
Now depends on Kombu 1.4.3.
-- -
CELERY_IMPORTS can now be a scalar value (Issue #485).
---It is too easy to forget to add the comma after the sole element of a -tuple, and this is something that often affects newcomers.
-The docs should probably use a list in examples, as using a tuple -for this doesn’t even make sense. Nonetheless, there are many -tutorials out there using a tuple, and this change should be a help -to new users.
-Suggested by jsaxon-cars.
-- -
Fixed a memory leak when using the thread pool (Issue #486).
---Contributed by Kornelijus Survila.
-- -
The statedb was not saved at exit.
---This has now been fixed and it should again remember previously -revoked tasks when a --statedb is enabled.
-- -
Adds EMAIL_USE_TLS to enable secure SMTP connections -(Issue #418).
---Contributed by Stefan Kjartansson.
-- -
Now handles missing fields in task messages as documented in the message -format documentation.
----
-- Missing required field throws InvalidTaskError
-- Missing args/kwargs is assumed empty.
-Contributed by Chris Chamberlin.
-- -
Fixed race condition in celery.events.state (celerymon/celeryev) -where task info would be removed while iterating over it (Issue #501).
-- -
The Cache, Cassandra, MongoDB, Redis and Tyrant backends now respects -the CELERY_RESULT_SERIALIZER setting (Issue #435).
---This means that only the database (django/sqlalchemy) backends -currently does not support using custom serializers.
-Contributed by Steeve Morin
-- -
Logging calls no longer manually formats messages, but delegates -that to the logging system, so tools like Sentry can easier -work with the messages (Issue #445).
---Contributed by Chris Adams.
-- -
celeryd_multi now supports a stop_verify command to wait for -processes to shutdown.
-- -
Cache backend did not work if the cache key was unicode (Issue #504).
---Fix contributed by Neil Chintomby.
-- -
New setting CELERY_RESULT_DB_SHORT_LIVED_SESSIONS added, -which if enabled will disable the caching of SQLAlchemy sessions -(Issue #449).
---Contributed by Leo Dirac.
-- -
All result backends now implements __reduce__ so that they can -be pickled (Issue #441).
---Fix contributed by Remy Noel
-- -
celeryd-multi did not work on Windows (Issue #472).
-- -
New-style CELERY_REDIS_* settings now takes precedence over -the old REDIS_* configuration keys (Issue #508).
---Fix contributed by Joshua Ginsberg
-- -
Generic celerybeat init script no longer sets bash -e (Issue #510).
---Fix contributed by Roger Hu.
-- -
Documented that Chords do not work well with redis-server versions -before 2.2.
---Contributed by Dan McGee.
-- -
The CELERYBEAT_MAX_LOOP_INTERVAL setting was not respected.
-- -
inspect.registered_tasks renamed to inspect.registered for naming -consistency.
---The previous name is still available as an alias.
-Contributed by Mher Movsisyan
-- -
Worker logged the string representation of args and kwargs -without safe guards (Issue #480).
-- -
RHEL init script: Changed celeryd startup priority.
---The default start / stop priorities for MySQL on RHEL are
---# chkconfig: - 64 36
-Therefore, if Celery is using a database as a broker / message store, it -should be started after the database is up and running, otherwise errors -will ensue. This commit changes the priority in the init script to
---# chkconfig: - 85 15
-which are the default recommended settings for 3-rd party applications -and assure that Celery will be started after the database service & shut -down before it terminates.
-Contributed by Yury V. Zaytsev.
-- -
KeyValueStoreBackend.get_many did not respect the timeout argument -(Issue #512).
-- -
celerybeat/celeryev’s –workdir option did not chdir before after -configuration was attempted (Issue #506).
-- -
After deprecating 2.4 support we can now name modules correctly, since we -can take use of absolute imports.
---Therefore the following internal modules have been renamed:
---celery.concurrency.evlet -> celery.concurrency.eventlet -celery.concurrency.evg -> celery.concurrency.gevent
-- -
AUTHORS file is now sorted alphabetically.
---Also, as you may have noticed the contributors of new features/fixes are -now mentioned in the Changelog.
---2.3.4¶
--
-- - - - release-date: 2011-11-25 16:00 P.M GMT -- - by: Ask Solem --- -Security Fixes¶
--
-- -
[Security: CELERYSA-0001] Daemons would set effective id’s rather than -real id’s when the --uid/--gid arguments to -celeryd-multi, celeryd_detach, -celerybeat and celeryev were used.
-This means privileges weren’t properly dropped, and that it would -be possible to regain supervisor privileges later.
---2.3.3¶
--
-- - - - release-date: 2011-16-09 05:00 P.M BST -- - by: Mher Movsisyan --
-- Monkey patching sys.stdout could result in the worker -crashing if the replacing object did not define isatty() -(Issue #477).
-- CELERYD option in /etc/default/celeryd should not -be used with generic init scripts.
--- -2.3.2¶
--
-- - - - - release-date: 2011-10-07 05:00 P.M BST ---News¶
--
-- -
Improved Contributing guide.
---If you’d like to contribute to Celery you should read this -guide: http://celery.github.com/celery/contributing.html
-We are looking for contributors at all skill levels, so don’t -hesitate!
-- -
Now depends on Kombu 1.3.1
-- -
Task.request now contains the current worker host name (Issue #460).
---Available as task.request.hostname.
-- -
-
-- It is now easier for app subclasses to extend how they are pickled.
-- -
(see celery.app.AppPickler).
---Fixes¶
--
-- -
purge/discard_all was not working correctly (Issue #455).
-- -
The coloring of log messages didn’t handle non-ASCII data well -(Issue #427).
-- -
[Windows] the multiprocessing pool tried to import os.kill -even though this is not available there (Issue #450).
-- -
Fixes case where the worker could become unresponsive because of tasks -exceeding the hard time limit.
-- -
The task-sent event was missing from the event reference.
-- -
ResultSet.iterate now returns results as they finish (Issue #459).
---This was not the case previously, even though the documentation -states this was the expected behavior.
-- -
Retries will no longer be performed when tasks are called directly -(using __call__).
---Instead the exception passed to retry will be re-raised.
-- -
Eventlet no longer crashes if autoscale is enabled.
---growing and shrinking eventlet pools is still not supported.
-- -
py24 target removed from tox.ini.
---2.3.0¶
--
-- - - - release-date: 2011-08-05 12:00 P.M BST -- - tested: cPython: 2.5, 2.6, 2.7; PyPy: 1.5; Jython: 2.5.2 ---Important Notes¶
--
-- -
Now requires Kombu 1.2.1
-- -
Results are now disabled by default.
---The AMQP backend was not a good default because often the users were -not consuming the results, resulting in thousands of queues.
-While the queues can be configured to expire if left unused, it was not -possible to enable this by default because this was only available in -recent RabbitMQ versions (2.1.1+)
-With this change enabling a result backend will be a conscious choice, -which will hopefully lead the user to read the documentation and be aware -of any common pitfalls with the particular backend.
-The default backend is now a dummy backend -(celery.backends.base.DisabledBackend). Saving state is simply an -noop operation, and AsyncResult.wait(), .result, .state, etc. will raise -a NotImplementedError telling the user to configure the result backend.
-For help choosing a backend please see Result Backends.
-If you depend on the previous default which was the AMQP backend, then -you have to set this explicitly before upgrading:
---CELERY_RESULT_BACKEND = "amqp" ---Note
-For django-celery users the default backend is still database, -and results are not disabled by default.
-- -
The Debian init scripts have been deprecated in favor of the generic-init.d -init scripts.
---In addition generic init scripts for celerybeat and celeryev has been -added.
---News¶
--
-- -
Automatic connection pool support.
---The pool is used by everything that requires a broker connection. For -example calling tasks, sending broadcast commands, retrieving results -with the AMQP result backend, and so on.
-The pool is disabled by default, but you can enable it by configuring the -BROKER_POOL_LIMIT setting:
---BROKER_POOL_LIMIT = 10 -A limit of 10 means a maximum of 10 simultaneous connections can co-exist. -Only a single connection will ever be used in a single-thread -environment, but in a concurrent environment (threads, greenlets, etc., but -not processes) when the limit has been exceeded, any try to acquire a -connection will block the thread and wait for a connection to be released. -This is something to take into consideration when choosing a limit.
-A limit of None or 0 means no limit, and connections will be -established and closed every time.
-- -
Introducing Chords (taskset callbacks).
---A chord is a task that only executes after all of the tasks in a taskset -has finished executing. It’s a fancy term for “taskset callbacks” -adopted from -Cω).
-It works with all result backends, but the best implementation is -currently provided by the Redis result backend.
-Here’s an example chord:
--->>> chord(add.subtask((i, i)) -... for i in xrange(100))(tsum.subtask()).get() -9900 -Please read the Chords section in the user guide, if you -want to know more.
-- -
Time limits can now be set for individual tasks.
---To set the soft and hard time limits for a task use the time_limit -and soft_time_limit attributes:
---import time - -@task(time_limit=60, soft_time_limit=30) -def sleeptask(seconds): - time.sleep(seconds) -If the attributes are not set, then the workers default time limits -will be used.
-New in this version you can also change the time limits for a task -at runtime using the time_limit() remote control command:
--->>> from celery.task import control ->>> control.time_limit("tasks.sleeptask", -... soft=60, hard=120, reply=True) -[{'worker1.example.com': {'ok': 'time limits set successfully'}}] -Only tasks that starts executing after the time limit change will be affected.
---Note
-Soft time limits will still not work on Windows or other platforms -that do not have the SIGUSR1 signal.
-- -
-
-- Redis backend configuration directive names changed to include the
-- -
CELERY_ prefix.
----
-- - -- - - - - - Old setting name
-- Replace with
-- - REDIS_HOST
-- CELERY_REDIS_HOST
-- - REDIS_PORT
-- CELERY_REDIS_PORT
-- - REDIS_DB
-- CELERY_REDIS_DB
-- - - REDIS_PASSWORD
-- CELERY_REDIS_PASSWORD
-The old names are still supported but pending deprecation.
-- -
PyPy: The default pool implementation used is now multiprocessing -if running on PyPy 1.5.
-- -
celeryd-multi: now supports “pass through” options.
---Pass through options makes it easier to use celery without a -configuration file, or just add last-minute options on the command -line.
-Example use:
----
-- $ celeryd-multi start 4 -c 2 – broker.host=amqp.example.com
-- -
broker.vhost=/ celery.disable_rate_limits=yes
-- -
celerybeat: Now retries establishing the connection (Issue #419).
-- -
celeryctl: New list bindings command.
---Lists the current or all available bindings, depending on the -broker transport used.
-- -
Heartbeat is now sent every 30 seconds (previously every 2 minutes).
-- -
ResultSet.join_native() and iter_native() is now supported by -the Redis and Cache result backends.
---This is an optimized version of join() using the underlying -backends ability to fetch multiple results at once.
-- -
Can now use SSL when sending error e-mails by enabling the -EMAIL_USE_SSL setting.
-- -
events.default_dispatcher(): Context manager to easily obtain -an event dispatcher instance using the connection pool.
-- -
Import errors in the configuration module will not be silenced anymore.
-- -
ResultSet.iterate: Now supports the timeout, propagate and -interval arguments.
-- -
with_default_connection -> with default_connection
-- -
TaskPool.apply_async: Keyword arguments callbacks and errbacks -has been renamed to callback and errback and take a single scalar -value instead of a list.
-- -
No longer propagates errors occurring during process cleanup (Issue #365)
-- -
Added TaskSetResult.delete(), which will delete a previously -saved taskset result.
-- -
Celerybeat now syncs every 3 minutes instead of only at -shutdown (Issue #382).
-- -
Monitors now properly handles unknown events, so user-defined events -are displayed.
-- -
Terminating a task on Windows now also terminates all of the tasks child -processes (Issue #384).
-- -
celeryd: -I|--include option now always searches the current directory -to import the specified modules.
-- -
Cassandra backend: Now expires results by using TTLs.
-- -
Functional test suite in funtests is now actually working properly, and -passing tests.
---Fixes¶
--
-- celeryev was trying to create the pidfile twice.
-- celery.contrib.batches: Fixed problem where tasks failed -silently (Issue #393).
-- Fixed an issue where logging objects would give “<Unrepresentable”, -even though the objects were.
-- CELERY_TASK_ERROR_WHITE_LIST is now properly initialized -in all loaders.
-- celeryd_detach now passes through command-line configuration.
-- Remote control command add_consumer now does nothing if the -queue is already being consumed from.
---2.2.8¶
--
-- - - - release-date: 2011-11-25 16:00 P.M GMT -- - by: Ask Solem ---Security Fixes¶
--
-- -
[Security: CELERYSA-0001] Daemons would set effective id’s rather than -real id’s when the --uid/--gid arguments to -celeryd-multi, celeryd_detach, -celerybeat and celeryev were used.
-This means privileges weren’t properly dropped, and that it would -be possible to regain supervisor privileges later.
---2.2.7¶
--
-- - - - - release-date: 2011-06-13 16:00 P.M BST --
-- -
New signals: after_setup_logger and -after_setup_task_logger
---These signals can be used to augment logging configuration -after Celery has set up logging.
-- -
Redis result backend now works with Redis 2.4.4.
-- -
celeryd_multi: The --gid option now works correctly.
-- -
celeryd: Retry wrongfully used the repr of the traceback instead -of the string representation.
-- -
App.config_from_object: Now loads module, not attribute of module.
-- -
Fixed issue where logging of objects would give “<Unrepresentable: ...>”
---2.2.6¶
--
-- - - - - release-date: 2011-04-15 16:00 P.M CEST ---Important Notes¶
--
-- -
Now depends on Kombu 1.1.2.
-- -
Dependency lists now explicitly specifies that we don’t want python-dateutil -2.x, as this version only supports py3k.
---If you have installed dateutil 2.0 by accident you should downgrade -to the 1.5.0 version:
--pip install -U python-dateutil==1.5.0-or by easy_install:
--easy_install -U python-dateutil==1.5.0---Fixes¶
--
-- -
The new WatchedFileHandler broke Python 2.5 support (Issue #367).
-- -
Task: Don’t use app.main if the task name is set explicitly.
-- -
Sending emails did not work on Python 2.5, due to a bug in -the version detection code (Issue #378).
-- -
Beat: Adds method ScheduleEntry._default_now
---This method can be overridden to change the default value -of last_run_at.
-- -
An error occurring in process cleanup could mask task errors.
-We no longer propagate errors happening at process cleanup, -but log them instead. This way they will not interfere with publishing -the task result (Issue #365).
-- -
Defining tasks did not work properly when using the Django -shell_plus utility (Issue #366).
-- -
-
-- AsyncResult.get did not accept the interval and propagate
-- -
arguments.
-- -
-
-- celeryd: Fixed a bug where celeryd would not shutdown if a
-- -
socket.error was raised.
---2.2.5¶
--
-- - - - - release-date: 2011-03-28 06:00 P.M CEST ---Important Notes¶
--
-- Now depends on Kombu 1.0.7
---News¶
--
-- -
Our documentation is now hosted by Read The Docs -(http://docs.celeryproject.org), and all links have been changed to point to -the new URL.
-- -
Logging: Now supports log rotation using external tools like logrotate.d -(Issue #321)
---This is accomplished by using the WatchedFileHandler, which re-opens -the file if it is renamed or deleted.
--
-- -
-
-- Using Celery with Redis/Database as the messaging queue. now documents how to configure Redis/Database result
-- -
backends.
-- -
gevent: Now supports ETA tasks.
---But gevent still needs CELERY_DISABLE_RATE_LIMITS=True to work.
-- -
TaskSet User Guide: now contains TaskSet callback recipes.
-- -
Eventlet: New signals:
----
-- eventlet_pool_started
-- eventlet_pool_preshutdown
-- eventlet_pool_postshutdown
-- eventlet_pool_apply
-See celery.signals for more information.
-- -
New BROKER_TRANSPORT_OPTIONS setting can be used to pass -additional arguments to a particular broker transport.
-- -
celeryd: worker_pid is now part of the request info as returned by -broadcast commands.
-- -
TaskSet.apply/Taskset.apply_async now accepts an optional taskset_id -argument.
-- -
The taskset_id (if any) is now available in the Task request context.
-- -
SQLAlchemy result backend: taskset_id and taskset_id columns now have a -unique constraint. (Tables need to recreated for this to take affect).
-- -
Task Userguide: Added section about choosing a result backend.
-- -
Removed unused attribute AsyncResult.uuid.
---Fixes¶
--
-- -
multiprocessing.Pool: Fixes race condition when marking job with -WorkerLostError (Issue #268).
---The process may have published a result before it was terminated, -but we have no reliable way to detect that this is the case.
-So we have to wait for 10 seconds before marking the result with -WorkerLostError. This gives the result handler a chance to retrieve the -result.
-- -
multiprocessing.Pool: Shutdown could hang if rate limits disabled.
---There was a race condition when the MainThread was waiting for the pool -semaphore to be released. The ResultHandler now terminates after 5 -seconds if there are unacked jobs, but no worker processes left to start -them (it needs to timeout because there could still be an ack+result -that we haven’t consumed from the result queue. It -is unlikely we will receive any after 5 seconds with no worker processes).
-- -
celerybeat: Now creates pidfile even if the --detach option is not set.
-- -
eventlet/gevent: The broadcast command consumer is now running in a separate -greenthread.
---This ensures broadcast commands will take priority even if there are many -active tasks.
-- -
Internal module celery.worker.controllers renamed to -celery.worker.mediator.
-- -
celeryd: Threads now terminates the program by calling os._exit, as it -is the only way to ensure exit in the case of syntax errors, or other -unrecoverable errors.
-- -
Fixed typo in maybe_timedelta (Issue #352).
-- -
celeryd: Broadcast commands now logs with loglevel debug instead of warning.
-- -
AMQP Result Backend: Now resets cached channel if the connection is lost.
-- -
Polling results with the AMQP result backend was not working properly.
-- -
Rate limits: No longer sleeps if there are no tasks, but rather waits for -the task received condition (Performance improvement).
-- -
ConfigurationView: iter(dict) should return keys, not items (Issue #362).
-- -
celerybeat: PersistentScheduler now automatically removes a corrupted -schedule file (Issue #346).
-- -
Programs that doesn’t support positional command line arguments now provides -a user friendly error message.
-- -
Programs no longer tries to load the configuration file when showing ---version (Issue #347).
-- -
Autoscaler: The “all processes busy” log message is now severity debug -instead of error.
-- -
celeryd: If the message body can’t be decoded, it is now passed through -safe_str when logging.
---This to ensure we don’t get additional decoding errors when trying to log -the failure.
-- -
app.config_from_object/app.config_from_envvar now works for all -loaders.
-- -
Now emits a user-friendly error message if the result backend name is -unknown (Issue #349).
-- -
celery.contrib.batches: Now sets loglevel and logfile in the task -request so task.get_logger works with batch tasks (Issue #357).
-- -
celeryd: An exception was raised if using the amqp transport and the prefetch -count value exceeded 65535 (Issue #359).
---The prefetch count is incremented for every received task with an -ETA/countdown defined. The prefetch count is a short, so can only support -a maximum value of 65535. If the value exceeds the maximum value we now -disable the prefetch count, it is re-enabled as soon as the value is below -the limit again.
-- -
cursesmon: Fixed unbound local error (Issue #303).
-- -
eventlet/gevent is now imported on demand so autodoc can import the modules -without having eventlet/gevent installed.
-- -
celeryd: Ack callback now properly handles AttributeError.
-- -
Task.after_return is now always called after the result has been -written.
-- -
Cassandra Result Backend: Should now work with the latest pycassa -version.
-- -
multiprocessing.Pool: No longer cares if the putlock semaphore is released -too many times. (this can happen if one or more worker processes are -killed).
-- -
SQLAlchemy Result Backend: Now returns accidentally removed date_done again -(Issue #325).
-- -
Task.request contex is now always initialized to ensure calling the task -function directly works even if it actively uses the request context.
-- -
Exception occuring when iterating over the result from TaskSet.apply -fixed.
-- -
eventlet: Now properly schedules tasks with an ETA in the past.
---2.2.4¶
--
-- - - - - release-date: 2011-02-19 12:00 AM CET ---Fixes¶
--
-- celeryd: 2.2.3 broke error logging, resulting in tracebacks not being logged.
-- AMQP result backend: Polling task states did not work properly if there were -more than one result message in the queue.
-- TaskSet.apply_async() and TaskSet.apply() now supports an optional -taskset_id keyword argument (Issue #331).
-- The current taskset id (if any) is now available in the task context as -request.taskset (Issue #329).
-- SQLAlchemy result backend: date_done was no longer part of the results as it had -been accidentally removed. It is now available again (Issue #325).
-- SQLAlchemy result backend: Added unique constraint on Task.id and -TaskSet.taskset_id. Tables needs to be recreated for this to take effect.
-- Fixed exception raised when iterating on the result of TaskSet.apply().
-- Tasks Userguide: Added section on choosing a result backend.
---2.2.3¶
--
-- - - - - release-date: 2011-02-12 04:00 P.M CET ---Fixes¶
--
-- -
Now depends on Kombu 1.0.3
-- -
Task.retry now supports a max_retries argument, used to change the -default value.
-- -
multiprocessing.cpu_count may raise NotImplementedError on -platforms where this is not supported (Issue #320).
-- -
Coloring of log messages broke if the logged object was not a string.
-- -
Fixed several typos in the init script documentation.
-- -
A regression caused Task.exchange and Task.routing_key to no longer -have any effect. This is now fixed.
-- -
Routing Userguide: Fixes typo, routers in CELERY_ROUTES must be -instances, not classes.
-- -
celeryev did not create pidfile even though the ---pidfile argument was set.
-- -
Task logger format was no longer used. (Issue #317).
---The id and name of the task is now part of the log message again.
-- -
A safe version of repr() is now used in strategic places to ensure -objects with a broken __repr__ does not crash the worker, or otherwise -make errors hard to understand (Issue #298).
-- -
Remote control command active_queues: did not account for queues added -at runtime.
---In addition the dictionary replied by this command now has a different -structure: the exchange key is now a dictionary containing the -exchange declaration in full.
-- -
The -Q option to celeryd removed unused queue -declarations, so routing of tasks could fail.
---Queues are no longer removed, but rather app.amqp.queues.consume_from() -is used as the list of queues to consume from.
-This ensures all queues are available for routing purposes.
-- -
celeryctl: Now supports the inspect active_queues command.
---2.2.2¶
--
-- - - - - release-date: 2011-02-03 04:00 P.M CET ---Fixes¶
--
-- -
Celerybeat could not read the schedule properly, so entries in -CELERYBEAT_SCHEDULE would not be scheduled.
-- -
Task error log message now includes exc_info again.
-- -
The eta argument can now be used with task.retry.
---Previously it was overwritten by the countdown argument.
-- -
celeryd-multi/celeryd_detach: Now logs errors occuring when executing -the celeryd command.
-- -
daemonizing tutorial: Fixed typo --time-limit 300 -> ---time-limit=300
-- -
Colors in logging broke non-string objects in log messages.
-- -
setup_task_logger no longer makes assumptions about magic task kwargs.
---2.2.1¶
--
-- - - - - release-date: 2011-02-02 04:00 P.M CET ---Fixes¶
--
-- -
Eventlet pool was leaking memory (Issue #308).
-- -
Deprecated function celery.execute.delay_task was accidentally removed, -now available again.
-- -
BasePool.on_terminate stub did not exist
-- -
-
-- celeryd detach: Adds readable error messages if user/group name does not
-- -
exist.
-- -
Smarter handling of unicode decod errors when logging errors.
---2.2.0¶
--
-- - - - - release-date: 2011-02-01 10:00 AM CET ---Important Notes¶
--
-- -
Carrot has been replaced with Kombu
---Kombu is the next generation messaging framework for Python, -fixing several flaws present in Carrot that was hard to fix -without breaking backwards compatibility.
-Also it adds:
--
-- First-class support for virtual transports; Redis, Django ORM, -SQLAlchemy, Beanstalk, MongoDB, CouchDB and in-memory.
-- Consistent error handling with introspection,
-- The ability to ensure that an operation is performed by gracefully -handling connection and channel errors,
-- Message compression (zlib, bzip2, or custom compression schemes).
-This means that ghettoq is no longer needed as the -functionality it provided is already available in Celery by default. -The virtual transports are also more feature complete with support -for exchanges (direct and topic). The Redis transport even supports -fanout exchanges so it is able to perform worker remote control -commands.
--
-- -
Magic keyword arguments pending deprecation.
---The magic keyword arguments were responsibile for many problems -and quirks: notably issues with tasks and decorators, and name -collisions in keyword arguments for the unaware.
-It wasn’t easy to find a way to deprecate the magic keyword arguments, -but we think this is a solution that makes sense and it will not -have any adverse effects for existing code.
-The path to a magic keyword argument free world is:
----
-- the celery.decorators module is deprecated and the decorators -can now be found in celery.task.
-- The decorators in celery.task disables keyword arguments by -default
-- All examples in the documentation have been changed to use -celery.task.
-This means that the following will have magic keyword arguments -enabled (old style):
-----from celery.decorators import task - -@task() -def add(x, y, **kwargs): - print("In task %s" % kwargs["task_id"]) - return x + y -And this will not use magic keyword arguments (new style):
-----from celery.task import task - -@task() -def add(x, y): - print("In task %s" % add.request.id) - return x + y -In addition, tasks can choose not to accept magic keyword arguments by -setting the task.accept_magic_kwargs attribute.
---Deprecation
-Using the decorators in celery.decorators emits a -PendingDeprecationWarning with a helpful message urging -you to change your code, in version 2.4 this will be replaced with -a DeprecationWarning, and in version 4.0 the -celery.decorators module will be removed and no longer exist.
-Similarly, the task.accept_magic_kwargs attribute will no -longer have any effect starting from version 4.0.
-- -
The magic keyword arguments are now available as task.request
---This is called the context. Using thread-local storage the -context contains state that is related to the current request.
-It is mutable and you can add custom attributes that will only be seen -by the current task request.
-The following context attributes are always available:
--
-- - -- - - - - - Magic Keyword Argument
-- Replace with
-- - kwargs[“task_id”]
-- self.request.id
-- - kwargs[“delivery_info”]
-- self.request.delivery_info
-- - kwargs[“task_retries”]
-- self.request.retries
-- - kwargs[“logfile”]
-- self.request.logfile
-- - kwargs[“loglevel”]
-- self.request.loglevel
-- - kwargs[“task_is_eager
-- self.request.is_eager
-- - NEW
-- self.request.args
-- - - NEW
-- self.request.kwargs
-In addition, the following methods now automatically uses the current -context, so you don’t have to pass kwargs manually anymore:
----
-- task.retry
-- task.get_logger
-- task.update_state
-- -
Eventlet support.
---This is great news for I/O-bound tasks!
-To change pool implementations you use the -P|--pool argument -to celeryd, or globally using the -CELERYD_POOL setting. This can be the full name of a class, -or one of the following aliases: processes, eventlet, gevent.
-For more information please see the Concurrency with Eventlet section -in the User Guide.
---Why not gevent?
-For our first alternative concurrency implementation we have focused -on Eventlet, but there is also an experimental gevent pool -available. This is missing some features, notably the ability to -schedule ETA tasks.
-Hopefully the gevent support will be feature complete by -version 2.3, but this depends on user demand (and contributions).
--
-- -
Python 2.4 support deprecated!
---We’re happy^H^H^H^H^Hsad to announce that this is the last version -to support Python 2.4.
-You are urged to make some noise if you’re currently stuck with -Python 2.4. Complain to your package maintainers, sysadmins and bosses: -tell them it’s time to move on!
-Apart from wanting to take advantage of with-statements, coroutines, -conditional expressions and enhanced try blocks, the code base -now contains so many 2.4 related hacks and workarounds it’s no longer -just a compromise, but a sacrifice.
-If it really isn’t your choice, and you don’t have the option to upgrade -to a newer version of Python, you can just continue to use Celery 2.2. -Important fixes can be backported for as long as there is interest.
-- -
celeryd: Now supports Autoscaling of child worker processes.
---The --autoscale option can be used to configure the minimum -and maximum number of child worker processes:
----autoscale=AUTOSCALE - Enable autoscaling by providing - max_concurrency,min_concurrency. Example: - --autoscale=10,3 (always keep 3 processes, but grow to - 10 if necessary).-- -
Remote Debugging of Tasks
---celery.contrib.rdb is an extended version of pdb that -enables remote debugging of processes that does not have terminal -access.
-Example usage:
--from celery.contrib import rdb - from celery.task import task - - @task() - def add(x, y): - result = x + y - rdb.set_trace() # <- set breakpoint - return result - - -:func:`~celery.contrib.rdb.set_trace` sets a breakpoint at the current -location and creates a socket you can telnet into to remotely debug -your task. - -The debugger may be started by multiple processes at the same time, -so rather than using a fixed port the debugger will search for an -available port, starting from the base port (6900 by default). -The base port can be changed using the environment variable -:envvar:`CELERY_RDB_PORT`. - -By default the debugger will only be available from the local host, -to enable access from the outside you have to set the environment -variable :envvar:`CELERY_RDB_HOST`. - -When `celeryd` encounters your breakpoint it will log the following -information:: - - [INFO/MainProcess] Got task from broker: - tasks.add[d7261c71-4962-47e5-b342-2448bedd20e8] - [WARNING/PoolWorker-1] Remote Debugger:6900: - Please telnet 127.0.0.1 6900. Type `exit` in session to continue. - [2011-01-18 14:25:44,119: WARNING/PoolWorker-1] Remote Debugger:6900: - Waiting for client... - -If you telnet the port specified you will be presented -with a ``pdb`` shell:: - - $ telnet localhost 6900 - Connected to localhost. - Escape character is '^]'. - > /opt/devel/demoapp/tasks.py(128)add() - -> return result - (Pdb) - -Enter ``help`` to get a list of available commands, -It may be a good idea to read the `Python Debugger Manual`_ if -you have never used `pdb` before.--
-- -
Events are now transient and is using a topic exchange (instead of direct).
---The CELERYD_EVENT_EXCHANGE, CELERYD_EVENT_ROUTING_KEY, -CELERYD_EVENT_EXCHANGE_TYPE settings are no longer in use.
-This means events will not be stored until there is a consumer, and the -events will be gone as soon as the consumer stops. Also it means there -can be multiple monitors running at the same time.
-The routing key of an event is the type of event (e.g. worker.started, -worker.heartbeat, task.succeeded, etc. This means a consumer can -filter on specific types, to only be alerted of the events it cares about.
-Each consumer will create a unique queue, meaning it is in effect a -broadcast exchange.
-This opens up a lot of possibilities, for example the workers could listen -for worker events to know what workers are in the neighborhood, and even -restart workers when they go down (or use this information to optimize -tasks/autoscaling).
---Note
-The event exchange has been renamed from “celeryevent” to “celeryev” -so it does not collide with older versions.
-If you would like to remove the old exchange you can do so -by executing the following command:
--$ camqadm exchange.delete celeryevent-- -
celeryd now starts without configuration, and configuration can be -specified directly on the command line.
-Configuration options must appear after the last argument, separated -by two dashes:
--$ celeryd -l info -I tasks -- broker.host=localhost broker.vhost=/app-- -
Configuration is now an alias to the original configuration, so changes -to the original will reflect Celery at runtime.
-- -
celery.conf has been deprecated, and modifying celery.conf.ALWAYS_EAGER -will no longer have any effect.
---The default configuration is now available in the -celery.app.defaults module. The available configuration options -and their types can now be introspected.
-- -
Remote control commands are now provided by kombu.pidbox, the generic -process mailbox.
-- -
Internal module celery.worker.listener has been renamed to -celery.worker.consumer, and .CarrotListener is now .Consumer.
-- -
Previously deprecated modules celery.models and -celery.management.commands have now been removed as per the deprecation -timeline.
-- -
-
-- [Security: Low severity] Removed celery.task.RemoteExecuteTask and
-- -
accompanying functions: dmap, dmap_async, and execute_remote.
-Executing arbitrary code using pickle is a potential security issue if -someone gains unrestricted access to the message broker.
-If you really need this functionality, then you would have to add -this to your own project.
-- -
[Security: Low severity] The stats command no longer transmits the -broker password.
---One would have needed an authenticated broker connection to receive -this password in the first place, but sniffing the password at the -wire level would have been possible if using unencrypted communication.
---News¶
--
-- -
The internal module celery.task.builtins has been removed.
-- -
The module celery.task.schedules is deprecated, and -celery.schedules should be used instead.
---For example if you have:
---from celery.task.schedules import crontab -You should replace that with:
---from celery.schedules import crontab -The module needs to be renamed because it must be possible -to import schedules without importing the celery.task module.
-- -
The following functions have been deprecated and is scheduled for -removal in version 2.3:
----
-- -
celery.execute.apply_async
---Use task.apply_async() instead.
-- -
celery.execute.apply
---Use task.apply() instead.
-- -
celery.execute.delay_task
---Use registry.tasks[name].delay() instead.
-- -
Importing TaskSet from celery.task.base is now deprecated.
---You should use:
--->>> from celery.task import TaskSet -instead.
-- -
New remote control commands:
----
-- -
active_queues
---Returns the queue declarations a worker is currently consuming from.
-- -
Added the ability to retry publishing the task message in -the event of connection loss or failure.
---This is disabled by default but can be enabled using the -CELERY_TASK_PUBLISH_RETRY setting, and tweaked by -the CELERY_TASK_PUBLISH_RETRY_POLICY setting.
-In addition retry, and retry_policy keyword arguments have -been added to Task.apply_async.
---Note
-Using the retry argument to apply_async requires you to -handle the publisher/connection manually.
-- -
Periodic Task classes (@periodic_task/PeriodicTask) will not be -deprecated as previously indicated in the source code.
---But you are encouraged to use the more flexible -CELERYBEAT_SCHEDULE setting.
-- -
Built-in daemonization support of celeryd using celeryd-multi -is no longer experimental and is considered production quality.
---See Generic init scripts if you want to use the new generic init -scripts.
-- -
Added support for message compression using the -CELERY_MESSAGE_COMPRESSION setting, or the compression argument -to apply_async. This can also be set using routers.
-- -
-
-- celeryd: Now logs stacktrace of all threads when receiving the
-- -
SIGUSR1 signal. (Does not work on cPython 2.4, Windows or Jython).
---Inspired by https://gist.github.com/737056
-- -
Can now remotely terminate/kill the worker process currently processing -a task.
---The revoke remote control command now supports a terminate argument -Default signal is TERM, but can be specified using the signal -argument. Signal can be the uppercase name of any signal defined -in the signal module in the Python Standard Library.
-Terminating a task also revokes it.
-Example:
--->>> from celery.task.control import revoke - ->>> revoke(task_id, terminate=True) ->>> revoke(task_id, terminate=True, signal="KILL") ->>> revoke(task_id, terminate=True, signal="SIGKILL") -- -
TaskSetResult.join_native: Backend-optimized version of join().
---If available, this version uses the backends ability to retrieve -multiple results at once, unlike join() which fetches the results -one by one.
-So far only supported by the AMQP result backend. Support for memcached -and Redis may be added later.
-- -
Improved implementations of TaskSetResult.join and AsyncResult.wait.
---An interval keyword argument have been added to both so the -polling interval can be specified (default interval is 0.5 seconds).
---A propagate keyword argument have been added to result.wait(), -errors will be returned instead of raised if this is set to False.
---Warning
-You should decrease the polling interval when using the database -result backend, as frequent polling can result in high database load.
-- -
The PID of the child worker process accepting a task is now sent as a field -with the task-started event.
-- -
The following fields have been added to all events in the worker class:
----
-- sw_ident: Name of worker software (e.g. celeryd).
-- sw_ver: Software version (e.g. 2.2.0).
-- sw_sys: Operating System (e.g. Linux, Windows, Darwin).
-- -
For better accuracy the start time reported by the multiprocessing worker -process is used when calculating task duration.
---Previously the time reported by the accept callback was used.
-- -
-
-- celerybeat: New built-in daemonization support using the –detach
-- -
option.
-- -
-
-- celeryev: New built-in daemonization support using the –detach
-- -
option.
-- -
TaskSet.apply_async: Now supports custom publishers by using the -publisher argument.
-- -
Added CELERY_SEND_TASK_SENT_EVENT setting.
---If enabled an event will be sent with every task, so monitors can -track tasks before the workers receive them.
-- -
-
-- celerybeat: Now reuses the broker connection when calling
-- -
scheduled tasks.
-- -
The configuration module and loader to use can now be specified on -the command line.
---For example:
--$ celeryd --config=celeryconfig.py --loader=myloader.Loader-- -
Added signals: beat_init and beat_embedded_init
----
-- -
celery.signals.beat_init
---Dispatched when celerybeat starts (either standalone or -embedded). Sender is the celery.beat.Service instance.
-- -
celery.signals.beat_embedded_init
---Dispatched in addition to the beat_init signal when -celerybeat is started as an embedded process. Sender -is the celery.beat.Service instance.
-- -
Redis result backend: Removed deprecated settings REDIS_TIMEOUT and -REDIS_CONNECT_RETRY.
-- -
CentOS init script for celeryd now available in extra/centos.
-- -
Now depends on pyparsing version 1.5.0 or higher.
---There have been reported issues using Celery with pyparsing 1.4.x, -so please upgrade to the latest version.
-- -
Lots of new unit tests written, now with a total coverage of 95%.
---Fixes¶
--
-- -
celeryev Curses Monitor: Improved resize handling and UI layout -(Issue #274 + Issue #276)
-- -
AMQP Backend: Exceptions occurring while sending task results are now -propagated instead of silenced.
---celeryd will then show the full traceback of these errors in the log.
-- -
AMQP Backend: No longer deletes the result queue after successful -poll, as this should be handled by the -CELERY_AMQP_TASK_RESULT_EXPIRES setting instead.
-- -
AMQP Backend: Now ensures queues are declared before polling results.
-- -
Windows: celeryd: Show error if running with -B option.
---Running celerybeat embedded is known not to work on Windows, so -users are encouraged to run celerybeat as a separate service instead.
-- -
Windows: Utilities no longer output ANSI color codes on Windows
-- -
camqadm: Now properly handles Ctrl+C by simply exiting instead of showing -confusing traceback.
-- -
Windows: All tests are now passing on Windows.
-- -
Remove bin/ directory, and scripts section from setup.py.
---This means we now rely completely on setuptools entrypoints.
---Experimental¶
--
-- -
Jython: celeryd now runs on Jython using the threaded pool.
---All tests pass, but there may still be bugs lurking around the corners.
-- -
PyPy: celeryd now runs on PyPy.
---It runs without any pool, so to get parallel execution you must start -multiple instances (e.g. using celeryd-multi).
-Sadly an initial benchmark seems to show a 30% performance decrease on -pypy-1.4.1 + JIT. We would like to find out why this is, so stay tuned.
-- -
PublisherPool: Experimental pool of task publishers and -connections to be used with the retry argument to apply_async.
-The example code below will re-use connections and channels, and -retry sending of the task message if the connection is lost.
---from celery import current_app - -# Global pool -pool = current_app().amqp.PublisherPool(limit=10) - -def my_view(request): - with pool.acquire() as publisher: - add.apply_async((2, 2), publisher=publisher, retry=True) ---2.1.4¶
--
-- - - - - release-date: 2010-12-03 12:00 P.M CEST ---Fixes¶
--
-- -
Execution options to apply_async now takes precedence over options -returned by active routers. This was a regression introduced recently -(Issue #244).
-- -
celeryev curses monitor: Long arguments are now truncated so curses -doesn’t crash with out of bounds errors. (Issue #235).
-- -
celeryd: Channel errors occurring while handling control commands no -longer crash the worker but are instead logged with severity error.
-- -
SQLAlchemy database backend: Fixed a race condition occurring when -the client wrote the pending state. Just like the Django database backend, -it does no longer save the pending state (Issue #261 + Issue #262).
-- -
Error email body now uses repr(exception) instead of str(exception), -as the latter could result in Unicode decode errors (Issue #245).
-- -
Error email timeout value is now configurable by using the -EMAIL_TIMEOUT setting.
-- -
celeryev: Now works on Windows (but the curses monitor won’t work without -having curses).
-- -
Unit test output no longer emits non-standard characters.
-- -
celeryd: The broadcast consumer is now closed if the connection is reset.
-- -
celeryd: Now properly handles errors occurring while trying to acknowledge -the message.
-- -
-
-- TaskRequest.on_failure now encodes traceback using the current filesystem
-- -
encoding. (Issue #286).
-- -
EagerResult can now be pickled (Issue #288).
---Documentation¶
--
-- Adding Contributing.
-- Added Optimizing.
-- Added Security section to the FAQ.
---2.1.3¶
--
-- - - - - release-date: 2010-11-09 05:00 P.M CEST --
-- -
Fixed deadlocks in timer2 which could lead to djcelerymon/celeryev -c -hanging.
-- -
EventReceiver: now sends heartbeat request to find workers.
---This means celeryev and friends finds workers immediately -at startup.
-- -
celeryev cursesmon: Set screen_delay to 10ms, so the screen refreshes more -often.
-- -
Fixed pickling errors when pickling AsyncResult on older Python -versions.
-- -
celeryd: prefetch count was decremented by eta tasks even if there -were no active prefetch limits.
---2.1.2¶
--
-- - - - - release-data: TBA ---Fixes¶
--
-- celeryd: Now sends the task-retried event for retried tasks.
-- celeryd: Now honors ignore result for -WorkerLostError and timeout errors.
-- celerybeat: Fixed UnboundLocalError in celerybeat logging -when using logging setup signals.
-- celeryd: All log messages now includes exc_info.
---2.1.1¶
--
-- - - - - release-date: 2010-10-14 02:00 P.M CEST ---Fixes¶
--
-- -
Now working on Windows again.
---Removed dependency on the pwd/grp modules.
-- -
snapshots: Fixed race condition leading to loss of events.
-- -
celeryd: Reject tasks with an eta that cannot be converted to a time stamp.
---See issue #209
-- -
concurrency.processes.pool: The semaphore was released twice for each task -(both at ACK and result ready).
---This has been fixed, and it is now released only once per task.
-- -
docs/configuration: Fixed typo CELERYD_SOFT_TASK_TIME_LIMIT -> -CELERYD_TASK_SOFT_TIME_LIMIT.
---See issue #214
-- -
control command dump_scheduled: was using old .info attribute
-- -
-
-- celeryd-multi: Fixed set changed size during iteration bug
-- -
occurring in the restart command.
-- -
celeryd: Accidentally tried to use additional command line arguments.
---This would lead to an error like:
---got multiple values for keyword argument ‘concurrency’.
-Additional command line arguments are now ignored, and does not -produce this error. However – we do reserve the right to use -positional arguments in the future, so please do not depend on this -behavior.
-- -
celerybeat: Now respects routers and task execution options again.
-- -
celerybeat: Now reuses the publisher instead of the connection.
-- -
Cache result backend: Using float as the expires argument -to cache.set is deprecated by the memcached libraries, -so we now automatically cast to int.
-- -
unit tests: No longer emits logging and warnings in test output.
---News¶
--
-- -
Now depends on carrot version 0.10.7.
-- -
Added CELERY_REDIRECT_STDOUTS, and -CELERYD_REDIRECT_STDOUTS_LEVEL settings.
---CELERY_REDIRECT_STDOUTS is used by celeryd and -celerybeat. All output to stdout and stderr will be -redirected to the current logger if enabled.
-CELERY_REDIRECT_STDOUTS_LEVEL decides the log level used and is -WARNING by default.
-- -
Added CELERYBEAT_SCHEDULER setting.
---This setting is used to define the default for the -S option to -celerybeat.
-Example:
---CELERYBEAT_SCHEDULER = "djcelery.schedulers.DatabaseScheduler" -- -
Added Task.expires: Used to set default expiry time for tasks.
-- -
New remote control commands: add_consumer and cancel_consumer.
----
- -- -add_consumer(queue, exchange, exchange_type, routing_key,
-- -**options)
-Tells the worker to declare and consume from the specified -declaration.
--
- -- -cancel_consumer(queue_name)¶
-Tells the worker to stop consuming from queue (by queue name).
-Commands also added to celeryctl and -inspect.
-Example using celeryctl to start consuming from queue “queue”, in -exchange “exchange”, of type “direct” using binding key “key”:
--$ celeryctl inspect add_consumer queue exchange direct key -$ celeryctl inspect cancel_consumer queue-See celery: Management Command-line Utility for more information about the -celeryctl program.
-Another example using inspect:
--->>> from celery.task.control import inspect ->>> inspect.add_consumer(queue="queue", exchange="exchange", -... exchange_type="direct", -... routing_key="key", -... durable=False, -... auto_delete=True) - ->>> inspect.cancel_consumer("queue") -- -
celerybeat: Now logs the traceback if a message can’t be sent.
-- -
celerybeat: Now enables a default socket timeout of 30 seconds.
-- -
README/introduction/homepage: Added link to Flask-Celery.
---2.1.0¶
--
-- - - - - release-date: 2010-10-08 12:00 P.M CEST ---Important Notes¶
--
-- -
Celery is now following the versioning semantics defined by semver.
---This means we are no longer allowed to use odd/even versioning semantics -By our previous versioning scheme this stable release should have -been version 2.2.
--
-- -
Now depends on Carrot 0.10.7.
-- -
No longer depends on SQLAlchemy, this needs to be installed separately -if the database result backend is used.
-- -
django-celery now comes with a monitor for the Django Admin interface. -This can also be used if you’re not a Django user. See -Django Admin Monitor and Using outside of Django for more information.
-- -
If you get an error after upgrading saying: -AttributeError: ‘module’ object has no attribute ‘system’,
---Then this is because the celery.platform module has been -renamed to celery.platforms to not collide with the built-in -platform module.
-You have to remove the old platform.py (and maybe -platform.pyc) file from your previous Celery installation.
-To do this use python to find the location -of this module:
--$ python ->>> import celery.platform ->>> celery.platform -<module 'celery.platform' from '/opt/devel/celery/celery/platform.pyc'>-Here the compiled module is in /opt/devel/celery/celery/, -to remove the offending files do:
--$ rm -f /opt/devel/celery/celery/platform.py*---News¶
--
-- -
Added support for expiration of AMQP results (requires RabbitMQ 2.1.0)
---The new configuration option CELERY_AMQP_TASK_RESULT_EXPIRES -sets the expiry time in seconds (can be int or float):
---CELERY_AMQP_TASK_RESULT_EXPIRES = 30 * 60 # 30 minutes. -CELERY_AMQP_TASK_RESULT_EXPIRES = 0.80 # 800 ms. -- -
celeryev: Event Snapshots
---If enabled, celeryd sends messages about what the worker is doing. -These messages are called “events”. -The events are used by real-time monitors to show what the -cluster is doing, but they are not very useful for monitoring -over a longer period of time. Snapshots -lets you take “pictures” of the clusters state at regular intervals. -This can then be stored in a database to generate statistics -with, or even monitoring over longer time periods.
-django-celery now comes with a Celery monitor for the Django -Admin interface. To use this you need to run the django-celery -snapshot camera, which stores snapshots to the database at configurable -intervals. See Using outside of Django for information about using -this monitor if you’re not using Django.
-To use the Django admin monitor you need to do the following:
--
-- -
Create the new database tables.
---$ python manage.py syncdb
-- -
Start the django-celery snapshot camera:
--$ python manage.py celerycam-- -
Open up the django admin to monitor your cluster.
-The admin interface shows tasks, worker nodes, and even -lets you perform some actions, like revoking and rate limiting tasks, -and shutting down worker nodes.
-There’s also a Debian init.d script for celeryev available, -see Running the worker as a daemon for more information.
-New command line arguments to celeryev:
----
-- -c|--camera: Snapshot camera class to use.
-- --logfile|-f: Log file
-- --loglevel|-l: Log level
-- --maxrate|-r: Shutter rate limit.
-- --freq|-F: Shutter frequency
-The --camera argument is the name of a class used to take -snapshots with. It must support the interface defined by -celery.events.snapshot.Polaroid.
-Shutter frequency controls how often the camera thread wakes up, -while the rate limit controls how often it will actually take -a snapshot. -The rate limit can be an integer (snapshots/s), or a rate limit string -which has the same syntax as the task rate limit strings (“200/m”, -“10/s”, “1/h”, etc).
-For the Django camera case, this rate limit can be used to control -how often the snapshots are written to the database, and the frequency -used to control how often the thread wakes up to check if there’s -anything new.
-The rate limit is off by default, which means it will take a snapshot -for every --frequency seconds.
---See also
- --
-- -
broadcast(): Added callback argument, this can be -used to process replies immediately as they arrive.
-- -
celeryctl: New command-line utility to manage and inspect worker nodes, -apply tasks and inspect the results of tasks.
-----See also
-The celery: Management Command-line Utility section in the User Guide.
-Some examples:
--$ celeryctl apply tasks.add -a '[2, 2]' --countdown=10 - -$ celeryctl inspect active -$ celeryctl inspect registered_tasks -$ celeryctl inspect scheduled -$ celeryctl inspect --help -$ celeryctl apply --help-- -
Added the ability to set an expiry date and time for tasks.
---Example:
--->>> # Task expires after one minute from now. ->>> task.apply_async(args, kwargs, expires=60) ->>> # Also supports datetime ->>> task.apply_async(args, kwargs, -... expires=datetime.now() + timedelta(days=1) -When a worker receives a task that has been expired it will be -marked as revoked (TaskRevokedError).
-- -
Changed the way logging is configured.
---We now configure the root logger instead of only configuring -our custom logger. In addition we don’t hijack -the multiprocessing logger anymore, but instead use a custom logger name -for different applications:
--
-- - -- - - - - - Application
-- Logger Name
-- - celeryd
-- “celery”
-- - celerybeat
-- “celery.beat”
-- - - celeryev
-- “celery.ev”
-This means that the loglevel and logfile arguments will -affect all registered loggers (even those from 3rd party libraries). -Unless you configure the loggers manually as shown below, that is.
-Users can choose to configure logging by subscribing to the -:signal:`~celery.signals.setup_logging` signal:
---from logging.config import fileConfig -from celery import signals - -@signals.setup_logging.connect -def setup_logging(**kwargs): - fileConfig("logging.conf") -If there are no receivers for this signal, the logging subsystem -will be configured using the --loglevel/--logfile -argument, this will be used for all defined loggers.
-Remember that celeryd also redirects stdout and stderr -to the celery logger, if manually configure logging -you also need to redirect the stdouts manually:
---from logging.config import fileConfig - from celery import log - -def setup_logging(**kwargs): - import logging - fileConfig("logging.conf") - stdouts = logging.getLogger("mystdoutslogger") - log.redirect_stdouts_to_logger(stdouts, loglevel=logging.WARNING) -- -
celeryd: Added command-line option -I/--include:
---A comma separated list of (task) modules to be imported.
-Example:
--$ celeryd -I app1.tasks,app2.tasks-- -
celeryd: now emits a warning if running as the root user (euid is 0).
-- -
celery.messaging.establish_connection(): Ability to override defaults -used using keyword argument “defaults”.
-- -
celeryd: Now uses multiprocessing.freeze_support() so that it should work -with py2exe, PyInstaller, cx_Freeze, etc.
-- -
celeryd: Now includes more metadata for the STARTED state: PID and -host name of the worker that started the task.
---See issue #181
-- -
subtask: Merge additional keyword arguments to subtask() into task keyword -arguments.
---e.g.:
--->>> s = subtask((1, 2), {"foo": "bar"}, baz=1) ->>> s.args -(1, 2) ->>> s.kwargs -{"foo": "bar", "baz": 1} -See issue #182.
-- -
celeryd: Now emits a warning if there is already a worker node using the same -name running on the same virtual host.
-- -
AMQP result backend: Sending of results are now retried if the connection -is down.
-- -
-
-- AMQP result backend: result.get(): Wait for next state if state is not
-- -
in READY_STATES.
-- -
TaskSetResult now supports subscription.
----->>> res = TaskSet(tasks).apply_async() ->>> res[0].get() -- -
Added Task.send_error_emails + Task.error_whitelist, so these can -be configured per task instead of just by the global setting.
-- -
Added Task.store_errors_even_if_ignored, so it can be changed per Task, -not just by the global setting.
-- -
The crontab scheduler no longer wakes up every second, but implements -remaining_estimate (Optimization).
-- -
-
-- celeryd: Store FAILURE result if the
-- -
WorkerLostError exception occurs (worker process -disappeared).
-- -
celeryd: Store FAILURE result if one of the *TimeLimitExceeded -exceptions occurs.
-- -
Refactored the periodic task responsible for cleaning up results.
----
-- -
-
-- The backend cleanup task is now only added to the schedule if
-- -
CELERY_TASK_RESULT_EXPIRES is set.
-- -
If the schedule already contains a periodic task named -“celery.backend_cleanup” it won’t change it, so the behavior of the -backend cleanup task can be easily changed.
-- -
The task is now run every day at 4:00 AM, rather than every day since -the first time it was run (using crontab schedule instead of -run_every)
-- -
-
-- Renamed celery.task.builtins.DeleteExpiredTaskMetaTask
-- -
-> celery.task.builtins.backend_cleanup
-- -
The task itself has been renamed from “celery.delete_expired_task_meta” -to “celery.backend_cleanup”
-See issue #134.
-- -
Implemented AsyncResult.forget for sqla/cache/redis/tyrant backends. -(Forget and remove task result).
---See issue #184.
-- -
TaskSetResult.join: -Added ‘propagate=True’ argument.
-When set to False exceptions occurring in subtasks will -not be re-raised.
-- -
Added Task.update_state(task_id, state, meta) -as a shortcut to task.backend.store_result(task_id, meta, state).
---The backend interface is “private” and the terminology outdated, -so better to move this to Task so it can be -used.
-- -
timer2: Set self.running=False in -stop() so it won’t try to join again on -subsequent calls to stop().
-- -
Log colors are now disabled by default on Windows.
-- -
celery.platform renamed to celery.platforms, so it doesn’t -collide with the built-in platform module.
-- -
Exceptions occurring in Mediator+Pool callbacks are now caught and logged -instead of taking down the worker.
-- -
Redis result backend: Now supports result expiration using the Redis -EXPIRE command.
-- -
unit tests: Don’t leave threads running at tear down.
-- -
celeryd: Task results shown in logs are now truncated to 46 chars.
-- -
-
-- Task.__name__ is now an alias to self.__class__.__name__.
-- -
This way tasks introspects more like regular functions.
-- -
Task.retry: Now raises TypeError if kwargs argument is empty.
---See issue #164.
-- -
timedelta_seconds: Use timedelta.total_seconds if running on Python 2.7
-- -
TokenBucket: Generic Token Bucket algorithm
-- -
celery.events.state: Recording of cluster state can now -be paused and resumed, including support for buffering.
----
- -- -State.freeze(buffer=True)¶
-Pauses recording of the stream.
-If buffer is true, events received while being frozen will be -buffered, and may be replayed later.
--
- -- -State.thaw(replay=True)¶
-Resumes recording of the stream.
-If replay is true, then the recorded buffer will be applied.
--
- -- -State.freeze_while(fun)¶
-With a function to apply, freezes the stream before, -and replays the buffer after the function returns.
-- -
EventReceiver.capture -Now supports a timeout keyword argument.
-- -
celeryd: The mediator thread is now disabled if -CELERY_RATE_LIMITS is enabled, and tasks are directly sent to the -pool without going through the ready queue (Optimization).
---Fixes¶
--
-- -
Pool: Process timed out by TimeoutHandler must be joined by the Supervisor, -so don’t remove it from the internal process list.
---See issue #192.
-- -
TaskPublisher.delay_task now supports exchange argument, so exchange can be -overridden when sending tasks in bulk using the same publisher
---See issue #187.
-- -
celeryd no longer marks tasks as revoked if CELERY_IGNORE_RESULT -is enabled.
---See issue #207.
-- -
AMQP Result backend: Fixed bug with result.get() if -CELERY_TRACK_STARTED enabled.
---result.get() would stop consuming after receiving the -STARTED state.
-- -
Fixed bug where new processes created by the pool supervisor becomes stuck -while reading from the task Queue.
---- -
Fixed timing issue when declaring the remote control command reply queue
---This issue could result in replies being lost, but have now been fixed.
-- -
Backward compatible LoggerAdapter implementation: Now works for Python 2.4.
---Also added support for several new methods: -fatal, makeRecord, _log, log, isEnabledFor, -addHandler, removeHandler.
---Experimental¶
--
-- -
celeryd-multi: Added daemonization support.
---celeryd-multi can now be used to start, stop and restart worker nodes.
---$ celeryd-multi start jerry elaine george kramer
-This also creates PID files and log files (celeryd@jerry.pid, -..., celeryd@jerry.log. To specify a location for these files -use the –pidfile and –logfile arguments with the %n -format:
--$ celeryd-multi start jerry elaine george kramer \ - --logfile=/var/log/celeryd@%n.log \ - --pidfile=/var/run/celeryd@%n.pid-Stopping:
--$ celeryd-multi stop jerry elaine george kramer-Restarting. The nodes will be restarted one by one as the old ones -are shutdown:
--$ celeryd-multi restart jerry elaine george kramer-Killing the nodes (WARNING: Will discard currently executing tasks):
--$ celeryd-multi kill jerry elaine george kramer-See celeryd-multi help for help.
-- -
celeryd-multi: start command renamed to show.
---celeryd-multi start will now actually start and detach worker nodes. -To just generate the commands you have to use celeryd-multi show.
-- -
celeryd: Added –pidfile argument.
---The worker will write its pid when it starts. The worker will -not be started if this file exists and the pid contained is still alive.
-- -
Added generic init.d script using celeryd-multi
-----Documentation¶
--
-- -
Added User guide section: Monitoring
-- -
Added user guide section: Periodic Tasks
---Moved from getting-started/periodic-tasks and updated.
-- -
tutorials/external moved to new section: “community”.
-- -
References has been added to all sections in the documentation.
---This makes it easier to link between documents.
---2.0.3¶
--
-- - - - - release-date: 2010-08-27 12:00 P.M CEST ---Fixes¶
--
-- -
celeryd: Properly handle connection errors happening while -closing consumers.
-- -
celeryd: Events are now buffered if the connection is down, -then sent when the connection is re-established.
-- -
No longer depends on the mailer package.
---This package had a name space collision with django-mailer, -so its functionality was replaced.
-- -
Redis result backend: Documentation typos: Redis doesn’t have -database names, but database numbers. The default database is now 0.
-- -
inspect: -registered_tasks was requesting an invalid command because of a typo.
---See issue #170.
-- -
CELERY_ROUTES: Values defined in the route should now have -precedence over values defined in CELERY_QUEUES when merging -the two.
---With the follow settings:
---CELERY_QUEUES = {"cpubound": {"exchange": "cpubound", - "routing_key": "cpubound"}} - -CELERY_ROUTES = {"tasks.add": {"queue": "cpubound", - "routing_key": "tasks.add", - "serializer": "json"}} -The final routing options for tasks.add will become:
---{"exchange": "cpubound", - "routing_key": "tasks.add", - "serializer": "json"} -This was not the case before: the values -in CELERY_QUEUES would take precedence.
-- -
Worker crashed if the value of CELERY_TASK_ERROR_WHITELIST was -not an iterable
-- -
apply(): Make sure kwargs[“task_id”] is -always set.
-- -
AsyncResult.traceback: Now returns None, instead of raising -KeyError if traceback is missing.
-- -
inspect: Replies did not work correctly -if no destination was specified.
-- -
Can now store result/metadata for custom states.
-- -
celeryd: A warning is now emitted if the sending of task error -emails fails.
-- -
celeryev: Curses monitor no longer crashes if the terminal window -is resized.
---See issue #160.
-- -
celeryd: On OS X it is not possible to run os.exec* in a process -that is threaded.
-----This breaks the SIGHUP restart handler, -and is now disabled on OS X, emitting a warning instead.
-See issue #152.
-- -
celery.execute.trace: Properly handle raise(str), -which is still allowed in Python 2.4.
---See issue #175.
-- -
Using urllib2 in a periodic task on OS X crashed because -of the proxy auto detection used in OS X.
---This is now fixed by using a workaround. -See issue #143.
-- -
Debian init scripts: Commands should not run in a sub shell
---See issue #163.
-- -
Debian init scripts: Use the absolute path of celeryd to allow stat
---See issue #162.
---Documentation¶
--
-- -
getting-started/broker-installation: Fixed typo
---set_permissions “” -> set_permissions ”.*”.
-- -
Tasks User Guide: Added section on database transactions.
---See issue #169.
-- -
Routing User Guide: Fixed typo “feed”: -> {“queue”: “feeds”}.
---See issue #169.
-- -
Documented the default values for the CELERYD_CONCURRENCY -and CELERYD_PREFETCH_MULTIPLIER settings.
-- -
Tasks User Guide: Fixed typos in the subtask example
-- -
celery.signals: Documented worker_process_init.
-- -
Daemonization cookbook: Need to export DJANGO_SETTINGS_MODULE in -/etc/default/celeryd.
-- -
Added some more FAQs from stack overflow
-- -
Daemonization cookbook: Fixed typo CELERYD_LOGFILE/CELERYD_PIDFILE
---to CELERYD_LOG_FILE / CELERYD_PID_FILE
-Also added troubleshooting section for the init scripts.
---2.0.2¶
--
-- - - - - release-date: 2010-07-22 11:31 A.M CEST --
-- -
Routes: When using the dict route syntax, the exchange for a task -could disappear making the task unroutable.
---See issue #158.
-- -
Test suite now passing on Python 2.4
-- -
No longer have to type PYTHONPATH=. to use celeryconfig in the current -directory.
---This is accomplished by the default loader ensuring that the current -directory is in sys.path when loading the config module. -sys.path is reset to its original state after loading.
-Adding the current working directory to sys.path without the user -knowing may be a security issue, as this means someone can drop a Python module in the users -directory that executes arbitrary commands. This was the original reason -not to do this, but if done only when loading the config module, this -means that the behavior will only apply to the modules imported in the -config module, which I think is a good compromise (certainly better than -just explicitly setting PYTHONPATH=. anyway)
-- -
Experimental Cassandra backend added.
-- -
celeryd: SIGHUP handler accidentally propagated to worker pool processes.
---In combination with 7a7c44e39344789f11b5346e9cc8340f5fe4846c -this would make each child process start a new celeryd when -the terminal window was closed :/
-- -
celeryd: Do not install SIGHUP handler if running from a terminal.
---This fixes the problem where celeryd is launched in the background -when closing the terminal.
-- -
celeryd: Now joins threads at shutdown.
---See issue #152.
-- -
Test tear down: Don’t use atexit but nose’s teardown() functionality -instead.
---See issue #154.
-- -
Debian init script for celeryd: Stop now works correctly.
-- -
Task logger: warn method added (synonym for warning)
-- -
Can now define a white list of errors to send error emails for.
---Example:
---CELERY_TASK_ERROR_WHITELIST = ('myapp.MalformedInputError') -See issue #153.
-- -
celeryd: Now handles overflow exceptions in time.mktime while parsing -the ETA field.
-- -
LoggerWrapper: Try to detect loggers logging back to stderr/stdout making -an infinite loop.
-- -
Added celery.task.control.inspect: Inspects a running worker.
---Examples:
--# Inspect a single worker ->>> i = inspect("myworker.example.com") - -# Inspect several workers ->>> i = inspect(["myworker.example.com", "myworker2.example.com"]) - -# Inspect all workers consuming on this vhost. ->>> i = inspect() - -### Methods - -# Get currently executing tasks ->>> i.active() - -# Get currently reserved tasks ->>> i.reserved() - -# Get the current eta schedule ->>> i.scheduled() - -# Worker statistics and info ->>> i.stats() - -# List of currently revoked tasks ->>> i.revoked() - -# List of registered tasks ->>> i.registered_tasks()-- -
Remote control commands dump_active/dump_reserved/dump_schedule -now replies with detailed task requests.
---Containing the original arguments and fields of the task requested.
-In addition the remote control command set_loglevel has been added, -this only changes the log level for the main process.
-- -
Worker control command execution now catches errors and returns their -string representation in the reply.
-- -
Functional test suite added
---celery.tests.functional.case contains utilities to start -and stop an embedded celeryd process, for use in functional testing.
---2.0.1¶
--
-- - - - - release-date: 2010-07-09 03:02 P.M CEST --
-- -
multiprocessing.pool: Now handles encoding errors, so that pickling errors -doesn’t crash the worker processes.
-- -
The remote control command replies was not working with RabbitMQ 1.8.0’s -stricter equivalence checks.
---If you’ve already hit this problem you may have to delete the -declaration:
--$ camqadm exchange.delete celerycrq-or:
--$ python manage.py camqadm exchange.delete celerycrq-- -
A bug sneaked in the ETA scheduler that made it only able to execute -one task per second(!)
---The scheduler sleeps between iterations so it doesn’t consume too much CPU. -It keeps a list of the scheduled items sorted by time, at each iteration -it sleeps for the remaining time of the item with the nearest deadline. -If there are no eta tasks it will sleep for a minimum amount of time, one -second by default.
-A bug sneaked in here, making it sleep for one second for every task -that was scheduled. This has been fixed, so now it should move -tasks like hot knife through butter.
-In addition a new setting has been added to control the minimum sleep -interval; CELERYD_ETA_SCHEDULER_PRECISION. A good -value for this would be a float between 0 and 1, depending -on the needed precision. A value of 0.8 means that when the ETA of a task -is met, it will take at most 0.8 seconds for the task to be moved to the -ready queue.
-- -
Pool: Supervisor did not release the semaphore.
---This would lead to a deadlock if all workers terminated prematurely.
-- -
Added Python version trove classifiers: 2.4, 2.5, 2.6 and 2.7
-- -
Tests now passing on Python 2.7.
-- -
Task.__reduce__: Tasks created using the task decorator can now be pickled.
-- -
setup.py: nose added to tests_require.
-- -
Pickle should now work with SQLAlchemy 0.5.x
-- -
New homepage design by Jan Henrik Helmers: http://celeryproject.org
-- -
New Sphinx theme by Armin Ronacher: http://docs.celeryproject.org/
-- -
Fixed “pending_xref” errors shown in the HTML rendering of the -documentation. Apparently this was caused by new changes in Sphinx 1.0b2.
-- -
Router classes in CELERY_ROUTES are now imported lazily.
---Importing a router class in a module that also loads the Celery -environment would cause a circular dependency. This is solved -by importing it when needed after the environment is set up.
-- -
CELERY_ROUTES was broken if set to a single dict.
---This example in the docs should now work again:
---CELERY_ROUTES = {"feed.tasks.import_feed": "feeds"} -- -
CREATE_MISSING_QUEUES was not honored by apply_async.
-- -
New remote control command: stats
---Dumps information about the worker, like pool process ids, and -total number of tasks executed by type.
-Example reply:
--[{'worker.local': - 'total': {'tasks.sleeptask': 6}, - 'pool': {'timeouts': [None, None], - 'processes': [60376, 60377], - 'max-concurrency': 2, - 'max-tasks-per-child': None, - 'put-guarded-by-semaphore': True}}]-- -
New remote control command: dump_active
---Gives a list of tasks currently being executed by the worker. -By default arguments are passed through repr in case there -are arguments that is not JSON encodable. If you know -the arguments are JSON safe, you can pass the argument safe=True.
-Example reply:
--->>> broadcast("dump_active", arguments={"safe": False}, reply=True) -[{'worker.local': [ - {'args': '(1,)', - 'time_start': 1278580542.6300001, - 'name': 'tasks.sleeptask', - 'delivery_info': { - 'consumer_tag': '30', - 'routing_key': 'celery', - 'exchange': 'celery'}, - 'hostname': 'casper.local', - 'acknowledged': True, - 'kwargs': '{}', - 'id': '802e93e9-e470-47ed-b913-06de8510aca2', - } -]}] -- -
Added experimental support for persistent revokes.
---Use the -S|–statedb argument to celeryd to enable it:
--$ celeryd --statedb=/var/run/celeryd-This will use the file: /var/run/celeryd.db, -as the shelve module automatically adds the .db suffix.
---2.0.0¶
--
-- - - - - release-date: 2010-07-02 02:30 P.M CEST ---Foreword¶
-Celery 2.0 contains backward incompatible changes, the most important -being that the Django dependency has been removed so Celery no longer -supports Django out of the box, but instead as an add-on package -called django-celery.
-We’re very sorry for breaking backwards compatibility, but there’s -also many new and exciting features to make up for the time you lose -upgrading, so be sure to read the News section.
-Quite a lot of potential users have been upset about the Django dependency, -so maybe this is a chance to get wider adoption by the Python community as -well.
-Big thanks to all contributors, testers and users!
---Upgrading for Django-users¶
-Django integration has been moved to a separate package: django-celery.
--
-- -
To upgrade you need to install the django-celery module and change:
---INSTALLED_APPS = "celery" -to:
---INSTALLED_APPS = "djcelery" -- -
If you use mod_wsgi you need to add the following line to your .wsgi -file:
---import os -os.environ["CELERY_LOADER"] = "django" -- -
The following modules has been moved to django-celery:
----
-- - -- - - - - - Module name
-- Replace with
-- - celery.models
-- djcelery.models
-- - celery.managers
-- djcelery.managers
-- - celery.views
-- djcelery.views
-- - celery.urls
-- djcelery.urls
-- - celery.management
-- djcelery.management
-- - celery.loaders.djangoapp
-- djcelery.loaders
-- - celery.backends.database
-- djcelery.backends.database
-- - - celery.backends.cache
-- djcelery.backends.cache
-Importing djcelery will automatically setup Celery to use Django loader. -loader. It does this by setting the CELERY_LOADER environment variable to -“django” (it won’t change it if a loader is already set.)
-When the Django loader is used, the “database” and “cache” result backend -aliases will point to the djcelery backends instead of the built-in backends, -and configuration will be read from the Django settings.
---Upgrading for others¶
---Database result backend¶
-The database result backend is now using SQLAlchemy instead of the -Django ORM, see Supported Databases for a table of supported databases.
-The DATABASE_* settings has been replaced by a single setting: -CELERY_RESULT_DBURI. The value here should be an -SQLAlchemy Connection String, some examples include:
---# sqlite (filename) -CELERY_RESULT_DBURI = "sqlite:///celerydb.sqlite" - -# mysql -CELERY_RESULT_DBURI = "mysql://scott:tiger@localhost/foo" - -# postgresql -CELERY_RESULT_DBURI = "postgresql://scott:tiger@localhost/mydatabase" - -# oracle -CELERY_RESULT_DBURI = "oracle://scott:tiger@127.0.0.1:1521/sidname" -See SQLAlchemy Connection Strings for more information about connection -strings.
-To specify additional SQLAlchemy database engine options you can use -the CELERY_RESULT_ENGINE_OPTIONS setting:
---# echo enables verbose logging from SQLAlchemy. -CELERY_RESULT_ENGINE_OPTIONS = {"echo": True} ---Cache result backend¶
-The cache result backend is no longer using the Django cache framework, -but it supports mostly the same configuration syntax:
---CELERY_CACHE_BACKEND = "memcached://A.example.com:11211;B.example.com" -To use the cache backend you must either have the pylibmc or -python-memcached library installed, of which the former is regarded -as the best choice.
-The support backend types are memcached:// and memory://, -we haven’t felt the need to support any of the other backends -provided by Django.
---Backward incompatible changes¶
--
-- -
Default (python) loader now prints warning on missing celeryconfig.py -instead of raising ImportError.
---celeryd raises ImproperlyConfigured if the configuration -is not set up. This makes it possible to use –help etc., without having a -working configuration.
-Also this makes it possible to use the client side of celery without being -configured:
--->>> from carrot.connection import BrokerConnection ->>> conn = BrokerConnection("localhost", "guest", "guest", "/") ->>> from celery.execute import send_task ->>> r = send_task("celery.ping", args=(), kwargs={}, connection=conn) ->>> from celery.backends.amqp import AMQPBackend ->>> r.backend = AMQPBackend(connection=conn) ->>> r.get() -'pong' -- -
The following deprecated settings has been removed (as scheduled by -the deprecation timeline):
----
-- - -- - - - - - Setting name
-- Replace with
-- - CELERY_AMQP_CONSUMER_QUEUES
-- CELERY_QUEUES
-- - CELERY_AMQP_EXCHANGE
-- CELERY_DEFAULT_EXCHANGE
-- - CELERY_AMQP_EXCHANGE_TYPE
-- CELERY_DEFAULT_EXCHANGE_TYPE
-- - CELERY_AMQP_CONSUMER_ROUTING_KEY
-- CELERY_QUEUES
-- - - CELERY_AMQP_PUBLISHER_ROUTING_KEY
-- CELERY_DEFAULT_ROUTING_KEY
--
-- -
The celery.task.rest module has been removed, use celery.task.http -instead (as scheduled by the deprecation timeline).
-- -
It’s no longer allowed to skip the class name in loader names. -(as scheduled by the deprecation timeline):
---Assuming the implicit Loader class name is no longer supported, -if you use e.g.:
---CELERY_LOADER = "myapp.loaders" -You need to include the loader class name, like this:
---CELERY_LOADER = "myapp.loaders.Loader" -- -
CELERY_TASK_RESULT_EXPIRES now defaults to 1 day.
---Previous default setting was to expire in 5 days.
-- -
AMQP backend: Don’t use different values for auto_delete.
---This bug became visible with RabbitMQ 1.8.0, which no longer -allows conflicting declarations for the auto_delete and durable settings.
-If you’ve already used celery with this backend chances are you -have to delete the previous declaration:
--$ camqadm exchange.delete celeryresults-- -
Now uses pickle instead of cPickle on Python versions <= 2.5
---cPickle is broken in Python <= 2.5.
-It unsafely and incorrectly uses relative instead of absolute imports, -so e.g.:
---exceptions.KeyError -becomes:
---celery.exceptions.KeyError -Your best choice is to upgrade to Python 2.6, -as while the pure pickle version has worse performance, -it is the only safe option for older Python versions.
---News¶
--
-- -
celeryev: Curses Celery Monitor and Event Viewer.
---This is a simple monitor allowing you to see what tasks are -executing in real-time and investigate tracebacks and results of ready -tasks. It also enables you to set new rate limits and revoke tasks.
-Screenshot:
-- --If you run celeryev with the -d switch it will act as an event -dumper, simply dumping the events it receives to standard out:
--$ celeryev -d --> celeryev: starting capture... -casper.local [2010-06-04 10:42:07.020000] heartbeat -casper.local [2010-06-04 10:42:14.750000] task received: - tasks.add(61a68756-27f4-4879-b816-3cf815672b0e) args=[2, 2] kwargs={} - eta=2010-06-04T10:42:16.669290, retries=0 -casper.local [2010-06-04 10:42:17.230000] task started - tasks.add(61a68756-27f4-4879-b816-3cf815672b0e) args=[2, 2] kwargs={} -casper.local [2010-06-04 10:42:17.960000] task succeeded: - tasks.add(61a68756-27f4-4879-b816-3cf815672b0e) - args=[2, 2] kwargs={} result=4, runtime=0.782663106918 - -The fields here are, in order: *sender hostname*, *timestamp*, *event type* and -*additional event fields*.-- -
AMQP result backend: Now supports .ready(), .successful(), -.result, .status, and even responds to changes in task state
-- -
New user guides:
---- -
celeryd: Standard out/error is now being redirected to the log file.
-- -
billiard has been moved back to the celery repository.
----
-- - -- - - - - - Module name
-- celery equivalent
-- - billiard.pool
-- celery.concurrency.processes.pool
-- - billiard.serialization
-- celery.serialization
-- - - billiard.utils.functional
-- celery.utils.functional
-The billiard distribution may be maintained, depending on interest.
-- -
now depends on carrot >= 0.10.5
-- -
now depends on pyparsing
-- -
celeryd: Added –purge as an alias to –discard.
-- -
celeryd: Ctrl+C (SIGINT) once does warm shutdown, hitting Ctrl+C twice -forces termination.
-- -
Added support for using complex crontab-expressions in periodic tasks. For -example, you can now use:
--->>> crontab(minute="*/15") -or even:
--->>> crontab(minute="*/30", hour="8-17,1-2", day_of_week="thu-fri") -See Periodic Tasks.
-- -
celeryd: Now waits for available pool processes before applying new -tasks to the pool.
---This means it doesn’t have to wait for dozens of tasks to finish at shutdown -because it has applied prefetched tasks without having any pool -processes available to immediately accept them.
-See issue #122.
-- -
New built-in way to do task callbacks using -subtask.
-See Canvas: Designing Workflows for more information.
-- -
TaskSets can now contain several types of tasks.
-TaskSet has been refactored to use -a new syntax, please see Canvas: Designing Workflows for more information.
-The previous syntax is still supported, but will be deprecated in -version 1.4.
-- -
TaskSet failed() result was incorrect.
---See issue #132.
-- -
Now creates different loggers per task class.
---See issue #129.
-- -
Missing queue definitions are now created automatically.
-----You can disable this using the CELERY_CREATE_MISSING_QUEUES -setting.
-The missing queues are created with the following options:
--CELERY_QUEUES[name] = {"exchange": name, - "exchange_type": "direct", - "routing_key": "name}-This feature is added for easily setting up routing using the -Q -option to celeryd:
--$ celeryd -Q video, image-See the new routing section of the User Guide for more information: -Routing Tasks.
-- -
New Task option: Task.queue
---If set, message options will be taken from the corresponding entry -in CELERY_QUEUES. exchange, exchange_type and routing_key -will be ignored
-- -
Added support for task soft and hard time limits.
---New settings added:
--
-- -
---Hard time limit. The worker processing the task will be killed and -replaced with a new one when this is exceeded.
-- -
CELERYD_SOFT_TASK_TIME_LIMIT
---Soft time limit. The SoftTimeLimitExceeded -exception will be raised when this is exceeded. The task can catch -this to e.g. clean up before the hard time limit comes.
-New command line arguments to celeryd added: -–time-limit and –soft-time-limit.
-What’s left?
-This won’t work on platforms not supporting signals (and specifically -the SIGUSR1 signal) yet. So an alternative the ability to disable -the feature all together on nonconforming platforms must be implemented.
-Also when the hard time limit is exceeded, the task result should -be a TimeLimitExceeded exception.
-- -
Test suite is now passing without a running broker, using the carrot -in-memory backend.
-- -
Log output is now available in colors.
----
-- - -- - - - - - Log level
-- Color
-- - DEBUG
-- Blue
-- - WARNING
-- Yellow
-- - CRITICAL
-- Magenta
-- - - ERROR
-- Red
-This is only enabled when the log output is a tty. -You can explicitly enable/disable this feature using the -CELERYD_LOG_COLOR setting.
-- -
Added support for task router classes (like the django multi-db routers)
----
-- New setting: CELERY_ROUTES
-This is a single, or a list of routers to traverse when -sending tasks. Dictionaries in this list converts to a -celery.routes.MapRoute instance.
-Examples:
--->>> CELERY_ROUTES = {"celery.ping": "default", - "mytasks.add": "cpu-bound", - "video.encode": { - "queue": "video", - "exchange": "media" - "routing_key": "media.video.encode"}} --->>> CELERY_ROUTES = ("myapp.tasks.Router", - {"celery.ping": "default}) -Where myapp.tasks.Router could be:
---class Router(object): - - def route_for_task(self, task, args=None, kwargs=None): - if task == "celery.ping": - return "default" -route_for_task may return a string or a dict. A string then means -it’s a queue name in CELERY_QUEUES, a dict means it’s a custom route.
-When sending tasks, the routers are consulted in order. The first -router that doesn’t return None is the route to use. The message options -is then merged with the found route settings, where the routers settings -have priority.
-Example if apply_async() has these arguments:
--->>> Task.apply_async(immediate=False, exchange="video", -... routing_key="video.compress") -and a router returns:
---{"immediate": True, - "exchange": "urgent"} -the final message options will be:
---immediate=True, exchange="urgent", routing_key="video.compress" -(and any default message options defined in the -Task class)
-- -
New Task handler called after the task returns: -after_return().
-- -
-
-- ExceptionInfo now passed to
-- -
on_retry()/ -on_failure() as einfo keyword argument.
-- -
celeryd: Added CELERYD_MAX_TASKS_PER_CHILD / ---maxtasksperchild
---Defines the maximum number of tasks a pool worker can process before -the process is terminated and replaced by a new one.
-- -
Revoked tasks now marked with state REVOKED, and result.get() -will now raise TaskRevokedError.
-- -
celery.task.control.ping() now works as expected.
-- -
apply(throw=True) / CELERY_EAGER_PROPAGATES_EXCEPTIONS: -Makes eager execution re-raise task errors.
-- -
New signal: ~celery.signals.worker_process_init: Sent inside the -pool worker process at init.
-- -
celeryd -Q option: Ability to specify list of queues to use, -disabling other configured queues.
---For example, if CELERY_QUEUES defines four -queues: image, video, data and default, the following -command would make celeryd only consume from the image and video -queues:
--$ celeryd -Q image,video-- -
celeryd: New return value for the revoke control command:
---Now returns:
---{"ok": "task $id revoked"} -instead of True.
-- -
celeryd: Can now enable/disable events using remote control
---Example usage:
--->>> from celery.task.control import broadcast ->>> broadcast("enable_events") ->>> broadcast("disable_events") -- -
Removed top-level tests directory. Test config now in celery.tests.config
---This means running the unit tests doesn’t require any special setup. -celery/tests/__init__ now configures the CELERY_CONFIG_MODULE -and CELERY_LOADER environment variables, so when nosetests -imports that, the unit test environment is all set up.
-Before you run the tests you need to install the test requirements:
--$ pip install -r requirements/test.txt-Running all tests:
--$ nosetests-Specifying the tests to run:
--$ nosetests celery.tests.test_task-Producing HTML coverage:
--$ nosetests --with-coverage3-The coverage output is then located in celery/tests/cover/index.html.
-- -
celeryd: New option –version: Dump version info and exit.
-- -
celeryd-multi: Tool for shell scripts -to start multiple workers.
---Some examples:
--# Advanced example with 10 workers: -# * Three of the workers processes the images and video queue -# * Two of the workers processes the data queue with loglevel DEBUG -# * the rest processes the default' queue. -$ celeryd-multi start 10 -l INFO -Q:1-3 images,video -Q:4,5:data - -Q default -L:4,5 DEBUG - -# get commands to start 10 workers, with 3 processes each -$ celeryd-multi start 3 -c 3 -celeryd -n celeryd1.myhost -c 3 -celeryd -n celeryd2.myhost -c 3 -celeryd- n celeryd3.myhost -c 3 - -# start 3 named workers -$ celeryd-multi start image video data -c 3 -celeryd -n image.myhost -c 3 -celeryd -n video.myhost -c 3 -celeryd -n data.myhost -c 3 - -# specify custom hostname -$ celeryd-multi start 2 -n worker.example.com -c 3 -celeryd -n celeryd1.worker.example.com -c 3 -celeryd -n celeryd2.worker.example.com -c 3 - -# Additionl options are added to each celeryd', -# but you can also modify the options for ranges of or single workers - -# 3 workers: Two with 3 processes, and one with 10 processes. -$ celeryd-multi start 3 -c 3 -c:1 10 -celeryd -n celeryd1.myhost -c 10 -celeryd -n celeryd2.myhost -c 3 -celeryd -n celeryd3.myhost -c 3 - -# can also specify options for named workers -$ celeryd-multi start image video data -c 3 -c:image 10 -celeryd -n image.myhost -c 10 -celeryd -n video.myhost -c 3 -celeryd -n data.myhost -c 3 - -# ranges and lists of workers in options is also allowed: -# (-c:1-3 can also be written as -c:1,2,3) -$ celeryd-multi start 5 -c 3 -c:1-3 10 -celeryd-multi -n celeryd1.myhost -c 10 -celeryd-multi -n celeryd2.myhost -c 10 -celeryd-multi -n celeryd3.myhost -c 10 -celeryd-multi -n celeryd4.myhost -c 3 -celeryd-multi -n celeryd5.myhost -c 3 - -# lists also works with named workers -$ celeryd-multi start foo bar baz xuzzy -c 3 -c:foo,bar,baz 10 -celeryd-multi -n foo.myhost -c 10 -celeryd-multi -n bar.myhost -c 10 -celeryd-multi -n baz.myhost -c 10 -celeryd-multi -n xuzzy.myhost -c 3--
-- The worker now calls the result backends process_cleanup method -after task execution instead of before.
-- AMQP result backend now supports Pika.
---1.0.6¶
--
-- - - - - release-date: 2010-06-30 09:57 A.M CEST --
-- -
RabbitMQ 1.8.0 has extended their exchange equivalence tests to -include auto_delete and durable. This broke the AMQP backend.
-If you’ve already used the AMQP backend this means you have to -delete the previous definitions:
--$ camqadm exchange.delete celeryresults-or:
--$ python manage.py camqadm exchange.delete celeryresults---1.0.5¶
--
-- - - - - release-date: 2010-06-01 02:36 P.M CEST ---Critical¶
--
-- -
SIGINT/Ctrl+C killed the pool, abruptly terminating the currently executing -tasks.
---Fixed by making the pool worker processes ignore SIGINT.
-- -
Should not close the consumers before the pool is terminated, just cancel -the consumers.
---See issue #122.
-- -
Now depends on billiard >= 0.3.1
-- -
celeryd: Previously exceptions raised by worker components could stall startup, -now it correctly logs the exceptions and shuts down.
-- -
celeryd: Prefetch counts was set too late. QoS is now set as early as possible, -so celeryd can’t slurp in all the messages at start-up.
---Changes¶
--
-- -
celery.contrib.abortable: Abortable tasks.
---Tasks that defines steps of execution, the task can then -be aborted after each step has completed.
-- -
EventDispatcher: No longer creates AMQP channel -if events are disabled
-- -
Added required RPM package names under [bdist_rpm] section, to support building RPMs -from the sources using setup.py
-- -
Running unit tests: NOSE_VERBOSE environment var now enables verbose output from Nose.
-- -
celery.execute.apply(): Pass log file/log level arguments as task kwargs.
---See issue #110.
-- -
celery.execute.apply: Should return exception, not ExceptionInfo -on error.
---See issue #111.
-- -
Added new entries to the FAQs:
----
-- Should I use retry or acks_late?
-- Can I call a task by name?
---1.0.4¶
--
-- - - - - release-date: 2010-05-31 09:54 A.M CEST --
-- Changelog merged with 1.0.5 as the release was never announced.
---1.0.3¶
--
-- - - - - release-date: 2010-05-15 03:00 P.M CEST ---Important notes¶
--
-- -
Messages are now acknowledged just before the task function is executed.
---This is the behavior we’ve wanted all along, but couldn’t have because of -limitations in the multiprocessing module. -The previous behavior was not good, and the situation worsened with the -release of 1.0.1, so this change will definitely improve -reliability, performance and operations in general.
-For more information please see http://bit.ly/9hom6T
-- -
Database result backend: result now explicitly sets null=True as -django-picklefield version 0.1.5 changed the default behavior -right under our noses :(
---See: http://bit.ly/d5OwMr
-This means those who created their celery tables (via syncdb or -celeryinit) with picklefield versions >= 0.1.5 has to alter their tables to -allow the result field to be NULL manually.
-MySQL:
--ALTER TABLE celery_taskmeta MODIFY result TEXT NULL-PostgreSQL:
--ALTER TABLE celery_taskmeta ALTER COLUMN result DROP NOT NULL-- -
Removed Task.rate_limit_queue_type, as it was not really useful -and made it harder to refactor some parts.
-- -
Now depends on carrot >= 0.10.4
-- -
Now depends on billiard >= 0.3.0
---News¶
--
-- -
AMQP backend: Added timeout support for result.get() / -result.wait().
-- -
New task option: Task.acks_late (default: CELERY_ACKS_LATE)
---Late ack means the task messages will be acknowledged after the task -has been executed, not just before, which is the default behavior.
---Note
-This means the tasks may be executed twice if the worker -crashes in mid-execution. Not acceptable for most -applications, but desirable for others.
-- -
Added crontab-like scheduling to periodic tasks.
---Like a cron job, you can specify units of time of when -you would like the task to execute. While not a full implementation -of cron’s features, it should provide a fair degree of common scheduling -needs.
-You can specify a minute (0-59), an hour (0-23), and/or a day of the -week (0-6 where 0 is Sunday, or by names: sun, mon, tue, wed, thu, fri, -sat).
-Examples:
---from celery.schedules import crontab -from celery.decorators import periodic_task - -@periodic_task(run_every=crontab(hour=7, minute=30)) -def every_morning(): - print("Runs every morning at 7:30a.m") - -@periodic_task(run_every=crontab(hour=7, minute=30, day_of_week="mon")) -def every_monday_morning(): - print("Run every monday morning at 7:30a.m") - -@periodic_task(run_every=crontab(minutes=30)) -def every_hour(): - print("Runs every hour on the clock. e.g. 1:30, 2:30, 3:30 etc.") ---Note
-This a late addition. While we have unittests, due to the -nature of this feature we haven’t been able to completely test this -in practice, so consider this experimental.
-- -
TaskPool.apply_async: Now supports the accept_callback argument.
-- -
apply_async: Now raises ValueError if task args is not a list, -or kwargs is not a tuple (Issue #95).
-- -
Task.max_retries can now be None, which means it will retry forever.
-- -
Celerybeat: Now reuses the same connection when publishing large -sets of tasks.
-- -
Modified the task locking example in the documentation to use -cache.add for atomic locking.
-- -
Added experimental support for a started status on tasks.
---If Task.track_started is enabled the task will report its status -as “started” when the task is executed by a worker.
-The default value is False as the normal behaviour is to not -report that level of granularity. Tasks are either pending, finished, -or waiting to be retried. Having a “started” status can be useful for -when there are long running tasks and there is a need to report which -task is currently running.
-The global default can be overridden by the CELERY_TRACK_STARTED -setting.
-- -
User Guide: New section Tips and Best Practices.
---Contributions welcome!
---Remote control commands¶
--
-- -
Remote control commands can now send replies back to the caller.
---Existing commands has been improved to send replies, and the client -interface in celery.task.control has new keyword arguments: reply, -timeout and limit. Where reply means it will wait for replies, -timeout is the time in seconds to stop waiting for replies, and limit -is the maximum number of replies to get.
-By default, it will wait for as many replies as possible for one second.
--
-- -
rate_limit(task_name, destination=all, reply=False, timeout=1, limit=0)
---Worker returns {“ok”: message} on success, -or {“failure”: message} on failure.
--->>> from celery.task.control import rate_limit ->>> rate_limit("tasks.add", "10/s", reply=True) -[{'worker1': {'ok': 'new rate limit set successfully'}}, - {'worker2': {'ok': 'new rate limit set successfully'}}] -- -
ping(destination=all, reply=False, timeout=1, limit=0)
---Worker returns the simple message “pong”.
--->>> from celery.task.control import ping ->>> ping(reply=True) -[{'worker1': 'pong'}, - {'worker2': 'pong'}, -- -
revoke(destination=all, reply=False, timeout=1, limit=0)
---Worker simply returns True.
--->>> from celery.task.control import revoke ->>> revoke("419e46eb-cf6a-4271-86a8-442b7124132c", reply=True) -[{'worker1': True}, - {'worker2'; True}] -- -
You can now add your own remote control commands!
---Remote control commands are functions registered in the command -registry. Registering a command is done using -celery.worker.control.Panel.register():
---from celery.task.control import Panel - -@Panel.register -def reset_broker_connection(panel, **kwargs): - panel.consumer.reset_connection() - return {"ok": "connection re-established"} -With this module imported in the worker, you can launch the command -using celery.task.control.broadcast:
--->>> from celery.task.control import broadcast ->>> broadcast("reset_broker_connection", reply=True) -[{'worker1': {'ok': 'connection re-established'}, - {'worker2': {'ok': 'connection re-established'}}] -TIP You can choose the worker(s) to receive the command -by using the destination argument:
--->>> broadcast("reset_broker_connection", destination=["worker1"]) -[{'worker1': {'ok': 'connection re-established'}] -- -
New remote control command: dump_reserved
---Dumps tasks reserved by the worker, waiting to be executed:
--->>> from celery.task.control import broadcast ->>> broadcast("dump_reserved", reply=True) -[{'myworker1': [<TaskRequest ....>]}] -- -
New remote control command: dump_schedule
---Dumps the workers currently registered ETA schedule. -These are tasks with an eta (or countdown) argument -waiting to be executed by the worker.
--->>> from celery.task.control import broadcast ->>> broadcast("dump_schedule", reply=True) -[{'w1': []}, - {'w3': []}, - {'w2': ['0. 2010-05-12 11:06:00 pri0 <TaskRequest - {name:"opalfeeds.tasks.refresh_feed_slice", - id:"95b45760-4e73-4ce8-8eac-f100aa80273a", - args:"(<Feeds freq_max:3600 freq_min:60 - start:2184.0 stop:3276.0>,)", - kwargs:"{'page': 2}"}>']}, - {'w4': ['0. 2010-05-12 11:00:00 pri0 <TaskRequest - {name:"opalfeeds.tasks.refresh_feed_slice", - id:"c053480b-58fb-422f-ae68-8d30a464edfe", - args:"(<Feeds freq_max:3600 freq_min:60 - start:1092.0 stop:2184.0>,)", - kwargs:"{\'page\': 1}"}>', - '1. 2010-05-12 11:12:00 pri0 <TaskRequest - {name:"opalfeeds.tasks.refresh_feed_slice", - id:"ab8bc59e-6cf8-44b8-88d0-f1af57789758", - args:"(<Feeds freq_max:3600 freq_min:60 - start:3276.0 stop:4365>,)", - kwargs:"{\'page\': 3}"}>']}] ---Fixes¶
--
-- -
Mediator thread no longer blocks for more than 1 second.
---With rate limits enabled and when there was a lot of remaining time, -the mediator thread could block shutdown (and potentially block other -jobs from coming in).
-- -
Remote rate limits was not properly applied (Issue #98).
-- -
Now handles exceptions with Unicode messages correctly in -TaskRequest.on_failure.
-- -
Database backend: TaskMeta.result: default value should be None -not empty string.
---1.0.2¶
--
-- - - - - release-date: 2010-03-31 12:50 P.M CET --
-- -
Deprecated: CELERY_BACKEND, please use -CELERY_RESULT_BACKEND instead.
-- -
We now use a custom logger in tasks. This logger supports task magic -keyword arguments in formats.
---The default format for tasks (CELERYD_TASK_LOG_FORMAT) now -includes the id and the name of tasks so the origin of task log messages -can easily be traced.
--
-- Example output::
-- -
-
-- [2010-03-25 13:11:20,317: INFO/PoolWorker-1]
-- -
[tasks.add(a6e1c5ad-60d9-42a0-8b24-9e39363125a4)] Hello from add
-To revert to the previous behavior you can set:
---CELERYD_TASK_LOG_FORMAT = """ - [%(asctime)s: %(levelname)s/%(processName)s] %(message)s -""".strip() -- -
Unit tests: Don’t disable the django test database tear down, -instead fixed the underlying issue which was caused by modifications -to the DATABASE_NAME setting (Issue #82).
-- -
Django Loader: New config CELERY_DB_REUSE_MAX (max number of -tasks to reuse the same database connection)
---The default is to use a new connection for every task. -We would very much like to reuse the connection, but a safe number of -reuses is not known, and we don’t have any way to handle the errors -that might happen, which may even be database dependent.
-See: http://bit.ly/94fwdd
-- -
celeryd: The worker components are now configurable: CELERYD_POOL, -CELERYD_CONSUMER, CELERYD_MEDIATOR, and -CELERYD_ETA_SCHEDULER.
---The default configuration is as follows:
---CELERYD_POOL = "celery.concurrency.processes.TaskPool" -CELERYD_MEDIATOR = "celery.worker.controllers.Mediator" -CELERYD_ETA_SCHEDULER = "celery.worker.controllers.ScheduleController" -CELERYD_CONSUMER = "celery.worker.consumer.Consumer" -The CELERYD_POOL setting makes it easy to swap out the -multiprocessing pool with a threaded pool, or how about a -twisted/eventlet pool?
-Consider the competition for the first pool plug-in started!
-- -
Debian init scripts: Use -a not && (Issue #82).
-- -
Debian init scripts: Now always preserves $CELERYD_OPTS from the -/etc/default/celeryd and /etc/default/celerybeat.
-- -
celery.beat.Scheduler: Fixed a bug where the schedule was not properly -flushed to disk if the schedule had not been properly initialized.
-- -
celerybeat: Now syncs the schedule to disk when receiving the SIGTERM -and SIGINT signals.
-- -
Control commands: Make sure keywords arguments are not in Unicode.
-- -
ETA scheduler: Was missing a logger object, so the scheduler crashed -when trying to log that a task had been revoked.
-- -
management.commands.camqadm: Fixed typo camqpadm -> camqadm -(Issue #83).
-- -
PeriodicTask.delta_resolution: Was not working for days and hours, now fixed -by rounding to the nearest day/hour.
-- -
Fixed a potential infinite loop in BaseAsyncResult.__eq__, although -there is no evidence that it has ever been triggered.
-- -
celeryd: Now handles messages with encoding problems by acking them and -emitting an error message.
---1.0.1¶
--
-- - - - - release-date: 2010-02-24 07:05 P.M CET --
-- -
Tasks are now acknowledged early instead of late.
---This is done because messages can only be acknowledged within the same -connection channel, so if the connection is lost we would have to refetch -the message again to acknowledge it.
-This might or might not affect you, but mostly those running tasks with a -really long execution time are affected, as all tasks that has made it -all the way into the pool needs to be executed before the worker can -safely terminate (this is at most the number of pool workers, multiplied -by the CELERYD_PREFETCH_MULTIPLIER setting.)
-We multiply the prefetch count by default to increase the performance at -times with bursts of tasks with a short execution time. If this doesn’t -apply to your use case, you should be able to set the prefetch multiplier -to zero, without sacrificing performance.
---Note
-A patch to multiprocessing is currently being -worked on, this patch would enable us to use a better solution, and is -scheduled for inclusion in the 2.0.0 release.
-- -
celeryd now shutdowns cleanly when receiving the SIGTERM signal.
-- -
celeryd now does a cold shutdown if the SIGINT signal is received (Ctrl+C), -this means it tries to terminate as soon as possible.
-- -
Caching of results now moved to the base backend classes, so no need -to implement this functionality in the base classes.
-- -
Caches are now also limited in size, so their memory usage doesn’t grow -out of control.
---You can set the maximum number of results the cache -can hold using the CELERY_MAX_CACHED_RESULTS setting (the -default is five thousand results). In addition, you can refetch already -retrieved results using backend.reload_task_result + -backend.reload_taskset_result (that’s for those who want to send -results incrementally).
-- -
celeryd now works on Windows again.
-----Warning
-If you’re using Celery with Django, you can’t use project.settings -as the settings module name, but the following should work:
--$ python manage.py celeryd --settings=settings-- -
Execution: .messaging.TaskPublisher.send_task now -incorporates all the functionality apply_async previously did.
---Like converting countdowns to eta, so celery.execute.apply_async() is -now simply a convenient front-end to -celery.messaging.TaskPublisher.send_task(), using -the task classes default options.
-Also celery.execute.send_task() has been -introduced, which can apply tasks using just the task name (useful -if the client does not have the destination task in its task registry).
-Example:
--->>> from celery.execute import send_task ->>> result = send_task("celery.ping", args=[], kwargs={}) ->>> result.get() -'pong' -- -
camqadm: This is a new utility for command line access to the AMQP API.
---Excellent for deleting queues/bindings/exchanges, experimentation and -testing:
--$ camqadm -1> help-Gives an interactive shell, type help for a list of commands.
-When using Django, use the management command instead:
--$ python manage.py camqadm -1> help-- -
Redis result backend: To conform to recent Redis API changes, the following -settings has been deprecated:
------
-- REDIS_TIMEOUT
-- REDIS_CONNECT_RETRY
-These will emit a DeprecationWarning if used.
-A REDIS_PASSWORD setting has been added, so you can use the new -simple authentication mechanism in Redis.
-- -
The redis result backend no longer calls SAVE when disconnecting, -as this is apparently better handled by Redis itself.
-- -
If settings.DEBUG is on, celeryd now warns about the possible -memory leak it can result in.
-- -
The ETA scheduler now sleeps at most two seconds between iterations.
-- -
The ETA scheduler now deletes any revoked tasks it might encounter.
---As revokes are not yet persistent, this is done to make sure the task -is revoked even though it’s currently being hold because its eta is e.g. -a week into the future.
-- -
The task_id argument is now respected even if the task is executed -eagerly (either using apply, or CELERY_ALWAYS_EAGER).
-- -
The internal queues are now cleared if the connection is reset.
-- -
New magic keyword argument: delivery_info.
---Used by retry() to resend the task to its original destination using the same -exchange/routing_key.
-- -
Events: Fields was not passed by .send() (fixes the UUID key errors -in celerymon)
-- -
Added –schedule/-s option to celeryd, so it is possible to -specify a custom schedule filename when using an embedded celerybeat -server (the -B/–beat) option.
-- -
Better Python 2.4 compatibility. The test suite now passes.
-- -
task decorators: Now preserve docstring as cls.__doc__, (was previously -copied to cls.run.__doc__)
-- -
The testproj directory has been renamed to tests and we’re now using -nose + django-nose for test discovery, and unittest2 for test -cases.
-- -
New pip requirements files available in requirements.
-- -
TaskPublisher: Declarations are now done once (per process).
-- -
Added Task.delivery_mode and the CELERY_DEFAULT_DELIVERY_MODE -setting.
---These can be used to mark messages non-persistent (i.e. so they are -lost if the broker is restarted).
-- -
Now have our own ImproperlyConfigured exception, instead of using the -Django one.
-- -
Improvements to the Debian init scripts: Shows an error if the program is -not executable. Does not modify CELERYD when using django with -virtualenv.
---1.0.0¶
--
-- - - - - release-date: 2010-02-10 04:00 P.M CET ---Backward incompatible changes¶
--
-- -
Celery does not support detaching anymore, so you have to use the tools -available on your platform, or something like Supervisord to make -celeryd/celerybeat/celerymon into background processes.
---We’ve had too many problems with celeryd daemonizing itself, so it was -decided it has to be removed. Example startup scripts has been added to -the extra/ directory:
--
-- -
Debian, Ubuntu, (start-stop-daemon)
---extra/debian/init.d/celeryd -extra/debian/init.d/celerybeat
-- -
Mac OS X launchd
---extra/mac/org.celeryq.celeryd.plist -extra/mac/org.celeryq.celerybeat.plist -extra/mac/org.celeryq.celerymon.plist
-- -
Supervisord (http://supervisord.org)
---extra/supervisord/supervisord.conf
-In addition to –detach, the following program arguments has been -removed: –uid, –gid, –workdir, –chroot, –pidfile, -–umask. All good daemonization tools should support equivalent -functionality, so don’t worry.
-Also the following configuration keys has been removed: -CELERYD_PID_FILE, CELERYBEAT_PID_FILE, CELERYMON_PID_FILE.
-- -
Default celeryd loglevel is now WARN, to enable the previous log level -start celeryd with –loglevel=INFO.
-- -
Tasks are automatically registered.
---This means you no longer have to register your tasks manually. -You don’t have to change your old code right away, as it doesn’t matter if -a task is registered twice.
-If you don’t want your task to be automatically registered you can set -the abstract attribute
---class MyTask(Task): - abstract = True -By using abstract only tasks subclassing this task will be automatically -registered (this works like the Django ORM).
-If you don’t want subclasses to be registered either, you can set the -autoregister attribute to False.
-Incidentally, this change also fixes the problems with automatic name -assignment and relative imports. So you also don’t have to specify a task name -anymore if you use relative imports.
-- -
You can no longer use regular functions as tasks.
---This change was added -because it makes the internals a lot more clean and simple. However, you can -now turn functions into tasks by using the @task decorator:
---from celery.decorators import task - -@task() -def add(x, y): - return x + y ---See also
-Tasks for more information about the task decorators.
-- -
The periodic task system has been rewritten to a centralized solution.
---This means celeryd no longer schedules periodic tasks by default, -but a new daemon has been introduced: celerybeat.
-To launch the periodic task scheduler you have to run celerybeat:
--$ celerybeat-Make sure this is running on one server only, if you run it twice, all -periodic tasks will also be executed twice.
-If you only have one worker server you can embed it into celeryd like this:
--$ celeryd --beat # Embed celerybeat in celeryd.-- -
The supervisor has been removed.
---This means the -S and –supervised options to celeryd is -no longer supported. Please use something like http://supervisord.org -instead.
-- -
TaskSet.join has been removed, use TaskSetResult.join instead.
-- -
The task status “DONE” has been renamed to “SUCCESS”.
-- -
AsyncResult.is_done has been removed, use AsyncResult.successful -instead.
-- -
The worker no longer stores errors if Task.ignore_result is set, to -revert to the previous behaviour set -CELERY_STORE_ERRORS_EVEN_IF_IGNORED to True.
-- -
The statistics functionality has been removed in favor of events, -so the -S and –statistics` switches has been removed.
-- -
The module celery.task.strategy has been removed.
-- -
celery.discovery has been removed, and it’s autodiscover function is -now in celery.loaders.djangoapp. Reason: Internal API.
-- -
The CELERY_LOADER environment variable now needs loader class name -in addition to module name,
---E.g. where you previously had: “celery.loaders.default”, you now need -“celery.loaders.default.Loader”, using the previous syntax will result -in a DeprecationWarning.
-- -
Detecting the loader is now lazy, and so is not done when importing -celery.loaders.
---To make this happen celery.loaders.settings has -been renamed to load_settings and is now a function returning the -settings object. celery.loaders.current_loader is now also -a function, returning the current loader.
-So:
---loader = current_loader -needs to be changed to:
---loader = current_loader() ---Deprecations¶
--
-- -
The following configuration variables has been renamed and will be -deprecated in v2.0:
----
-- CELERYD_DAEMON_LOG_FORMAT -> CELERYD_LOG_FORMAT
-- CELERYD_DAEMON_LOG_LEVEL -> CELERYD_LOG_LEVEL
-- CELERY_AMQP_CONNECTION_TIMEOUT -> CELERY_BROKER_CONNECTION_TIMEOUT
-- CELERY_AMQP_CONNECTION_RETRY -> CELERY_BROKER_CONNECTION_RETRY
-- CELERY_AMQP_CONNECTION_MAX_RETRIES -> CELERY_BROKER_CONNECTION_MAX_RETRIES
-- SEND_CELERY_TASK_ERROR_EMAILS -> CELERY_SEND_TASK_ERROR_EMAILS
-- -
The public API names in celery.conf has also changed to a consistent naming -scheme.
-- -
We now support consuming from an arbitrary number of queues.
---To do this we had to rename the configuration syntax. If you use any of -the custom AMQP routing options (queue/exchange/routing_key, etc.), you -should read the new FAQ entry: http://bit.ly/aiWoH.
-The previous syntax is deprecated and scheduled for removal in v2.0.
-- -
TaskSet.run has been renamed to TaskSet.apply_async.
---TaskSet.run has now been deprecated, and is scheduled for -removal in v2.0.
---News¶
--
-- -
Rate limiting support (per task type, or globally).
-- -
New periodic task system.
-- -
Automatic registration.
-- -
New cool task decorator syntax.
-- -
celeryd now sends events if enabled with the -E argument.
---Excellent for monitoring tools, one is already in the making -(http://github.com/celery/celerymon).
-Current events include: worker-heartbeat, -task-[received/succeeded/failed/retried], -worker-online, worker-offline.
-- -
You can now delete (revoke) tasks that has already been applied.
-- -
You can now set the hostname celeryd identifies as using the –hostname -argument.
-- -
Cache backend now respects the CELERY_TASK_RESULT_EXPIRES setting.
-- -
Message format has been standardized and now uses ISO-8601 format -for dates instead of datetime.
-- -
celeryd now responds to the SIGHUP signal by restarting itself.
-- -
Periodic tasks are now scheduled on the clock.
---I.e. timedelta(hours=1) means every hour at :00 minutes, not every -hour from the server starts. To revert to the previous behaviour you -can set PeriodicTask.relative = True.
-- -
Now supports passing execute options to a TaskSets list of args, e.g.:
--->>> ts = TaskSet(add, [([2, 2], {}, {"countdown": 1}), -... ([4, 4], {}, {"countdown": 2}), -... ([8, 8], {}, {"countdown": 3})]) ->>> ts.run() -- -
Got a 3x performance gain by setting the prefetch count to four times the -concurrency, (from an average task round-trip of 0.1s to 0.03s!).
---A new setting has been added: CELERYD_PREFETCH_MULTIPLIER, which -is set to 4 by default.
-- -
Improved support for webhook tasks.
---celery.task.rest is now deprecated, replaced with the new and shiny -celery.task.http. With more reflective names, sensible interface, -and it’s possible to override the methods used to perform HTTP requests.
-- -
The results of task sets are now cached by storing it in the result -backend.
--- -Changes¶
--
-- -
Now depends on carrot >= 0.8.1
-- -
New dependencies: billiard, python-dateutil, django-picklefield
-- -
No longer depends on python-daemon
-- -
The uuid distribution is added as a dependency when running Python 2.4.
-- -
Now remembers the previously detected loader by keeping it in -the CELERY_LOADER environment variable.
---This may help on windows where fork emulation is used.
-- -
ETA no longer sends datetime objects, but uses ISO 8601 date format in a -string for better compatibility with other platforms.
-- -
No longer sends error mails for retried tasks.
-- -
Task can now override the backend used to store results.
-- -
Refactored the ExecuteWrapper, apply and CELERY_ALWAYS_EAGER -now also executes the task callbacks and signals.
-- -
Now using a proper scheduler for the tasks with an ETA.
---This means waiting eta tasks are sorted by time, so we don’t have -to poll the whole list all the time.
-- -
Now also imports modules listed in CELERY_IMPORTS when running -with django (as documented).
-- -
Log level for stdout/stderr changed from INFO to ERROR
-- -
ImportErrors are now properly propagated when autodiscovering tasks.
-- -
You can now use celery.messaging.establish_connection to establish a -connection to the broker.
-- -
When running as a separate service the periodic task scheduler does some -smart moves to not poll too regularly.
---If you need faster poll times you can lower the value -of CELERYBEAT_MAX_LOOP_INTERVAL.
-- -
You can now change periodic task intervals at runtime, by making -run_every a property, or subclassing PeriodicTask.is_due.
-- -
The worker now supports control commands enabled through the use of a -broadcast queue, you can remotely revoke tasks or set the rate limit for -a task type. See celery.task.control.
-- -
The services now sets informative process names (as shown in ps -listings) if the setproctitle module is installed.
-- -
NotRegistered now inherits from KeyError, -and TaskRegistry.__getitem__`+`pop raises NotRegistered instead
-- -
You can set the loader via the CELERY_LOADER environment variable.
-- -
You can now set CELERY_IGNORE_RESULT to ignore task results by -default (if enabled, tasks doesn’t save results or errors to the backend used).
-- -
celeryd now correctly handles malformed messages by throwing away and -acknowledging the message, instead of crashing.
---Documentation¶
--
-- Reference now split into two sections; API reference and internal module -reference.
---0.8.4¶
--
-- - - - - release-date: 2010-02-05 01:52 P.M CEST --
-- Now emits a warning if the –detach argument is used. -–detach should not be used anymore, as it has several not easily fixed -bugs related to it. Instead, use something like start-stop-daemon, -Supervisord or launchd (os x).
-- Make sure logger class is process aware, even if running Python >= 2.6.
-- Error emails are not sent anymore when the task is retried.
---0.8.3¶
--
-- - - - - release-date: 2009-12-22 09:43 A.M CEST --
-- Fixed a possible race condition that could happen when storing/querying -task results using the database backend.
-- Now has console script entry points in the setup.py file, so tools like -Buildout will correctly install the programs celeryd and celeryinit.
---0.8.2¶
--
-- - - - - release-date: 2009-11-20 03:40 P.M CEST --
-- QOS Prefetch count was not applied properly, as it was set for every message -received (which apparently behaves like, “receive one more”), instead of only -set when our wanted value changed.
---0.8.1¶
--
-- - - - - release-date: 2009-11-16 05:21 P.M CEST ---Very important note¶
-This release (with carrot 0.8.0) enables AMQP QoS (quality of service), which -means the workers will only receive as many messages as it can handle at a -time. As with any release, you should test this version upgrade on your -development servers before rolling it out to production!
---Important changes¶
--
-- -
If you’re using Python < 2.6 and you use the multiprocessing backport, then -multiprocessing version 2.6.2.1 is required.
-- -
All AMQP_* settings has been renamed to BROKER_*, and in addition -AMQP_SERVER has been renamed to BROKER_HOST, so before where you had:
---AMQP_SERVER = "localhost" -AMQP_PORT = 5678 -AMQP_USER = "myuser" -AMQP_PASSWORD = "mypassword" -AMQP_VHOST = "celery" -You need to change that to:
---BROKER_HOST = "localhost" -BROKER_PORT = 5678 -BROKER_USER = "myuser" -BROKER_PASSWORD = "mypassword" -BROKER_VHOST = "celery" -- -
Custom carrot backends now need to include the backend class name, so before -where you had:
---CARROT_BACKEND = "mycustom.backend.module" -you need to change it to:
---CARROT_BACKEND = "mycustom.backend.module.Backend" -where Backend is the class name. This is probably “Backend”, as -that was the previously implied name.
-- -
New version requirement for carrot: 0.8.0
---Changes¶
--
-- Incorporated the multiprocessing backport patch that fixes the -processName error.
-- Ignore the result of PeriodicTask’s by default.
-- Added a Redis result store backend
-- Allow /etc/default/celeryd to define additional options for the celeryd init -script.
-- MongoDB periodic tasks issue when using different time than UTC fixed.
-- Windows specific: Negate test for available os.fork (thanks miracle2k)
-- Now tried to handle broken PID files.
-- Added a Django test runner to contrib that sets -CELERY_ALWAYS_EAGER = True for testing with the database backend.
-- Added a CELERY_CACHE_BACKEND setting for using something other -than the django-global cache backend.
-- Use custom implementation of functools.partial (curry) for Python 2.4 support -(Probably still problems with running on 2.4, but it will eventually be -supported)
-- Prepare exception to pickle when saving RETRY status for all backends.
-- SQLite no concurrency limit should only be effective if the database backend -is used.
---0.8.0¶
--
-- - - - - release-date: 2009-09-22 03:06 P.M CEST ---Backward incompatible changes¶
--
-- -
Add traceback to result value on failure.
-----Note
-If you use the database backend you have to re-create the -database table celery_taskmeta.
-Contact the Mailing list or IRC channel -for help doing this.
-- -
Database tables are now only created if the database backend is used, -so if you change back to the database backend at some point, -be sure to initialize tables (django: syncdb, python: celeryinit).
---Note
-This is only applies if using Django version 1.1 or higher.
-- -
Now depends on carrot version 0.6.0.
-- -
Now depends on python-daemon 1.4.8
---Important changes¶
--
-- -
Celery can now be used in pure Python (outside of a Django project).
---This means celery is no longer Django specific.
-For more information see the FAQ entry -Is Celery for Django only?.
-- -
Celery now supports task retries.
---See Cookbook: Retrying Tasks for more information.
--
-- -
We now have an AMQP result store backend.
---It uses messages to publish task return value and status. And it’s -incredibly fast!
-See issue #6 for more info!
-- -
AMQP QoS (prefetch count) implemented:
---This to not receive more messages than we can handle.
-- -
Now redirects stdout/stderr to the celeryd log file when detached
-- -
-
-- Now uses inspect.getargspec to only pass default arguments
-- -
the task supports.
-- -
-
-- Add Task.on_success, .on_retry, .on_failure handlers
-- -
-
-- See celery.task.base.Task.on_success(),
-- -
celery.task.base.Task.on_retry(), -celery.task.base.Task.on_failure(),
-- -
-
-- celery.utils.gen_unique_id: Workaround for
-- -
-- -
-
-- You can now customize what happens at worker start, at process init, etc.,
-- -
by creating your own loaders. (see celery.loaders.default, -celery.loaders.djangoapp, celery.loaders.)
-- -
Support for multiple AMQP exchanges and queues.
---This feature misses documentation and tests, so anyone interested -is encouraged to improve this situation.
-- -
celeryd now survives a restart of the AMQP server!
-Automatically re-establish AMQP broker connection if it’s lost.
-New settings:
----
-- -
-
-- AMQP_CONNECTION_RETRY
-- -
Set to True to enable connection retries.
-- -
-
-- AMQP_CONNECTION_MAX_RETRIES.
-- -
Maximum number of restarts before we give up. Default: 100.
---News¶
--
-- -
-
-- Fix an incompatibility between python-daemon and multiprocessing,
-- -
which resulted in the [Errno 10] No child processes problem when -detaching.
-- -
-
-- Fixed a possible DjangoUnicodeDecodeError being raised when saving pickled
-- -
data to Django`s memcached cache backend.
-- -
Better Windows compatibility.
-- -
-
-- New version of the pickled field (taken from
-- -
-- -
-
-- New signals introduced: task_sent, task_prerun and
-- -
task_postrun, see celery.signals for more information.
-- -
-
-- TaskSetResult.join caused TypeError when timeout=None.
-- -
Thanks Jerzy Kozera. Closes #31
-- -
-
-- views.apply should return HttpResponse instance.
-- -
Thanks to Jerzy Kozera. Closes #32
-- -
-
-- PeriodicTask: Save conversion of run_every from int
-- -
to timedelta to the class attribute instead of on the instance.
-- -
-
-- Exceptions has been moved to celery.exceptions, but are still
-- -
available in the previous module.
-- -
-
-- Try to rollback transaction and retry saving result if an error happens
-- -
while setting task status with the database backend.
-- -
jail() refactored into celery.execute.ExecuteWrapper.
-- -
views.apply now correctly sets mime-type to “application/json”
-- -
views.task_status now returns exception if state is RETRY
-- -
-- -
Documented default task arguments.
-- -
Add a sensible __repr__ to ExceptionInfo for easier debugging
-- -
-
-- Fix documentation typo .. import map -> .. import dmap.
-- -
Thanks to mikedizon
---0.6.0¶
--
-- - - - - release-date: 2009-08-07 06:54 A.M CET ---Important changes¶
--
-- -
-
-- Fixed a bug where tasks raising unpickleable exceptions crashed pool
-- -
workers. So if you’ve had pool workers mysteriously disappearing, or -problems with celeryd stopping working, this has been fixed in this -version.
-- -
Fixed a race condition with periodic tasks.
-- -
-
-- The task pool is now supervised, so if a pool worker crashes,
-- -
goes away or stops responding, it is automatically replaced with -a new one.
-- -
-
-- Task.name is now automatically generated out of class module+name, e.g.
-- -
“djangotwitter.tasks.UpdateStatusesTask”. Very convenient. No idea why -we didn’t do this before. Some documentation is updated to not manually -specify a task name.
---News¶
--
-- -
Tested with Django 1.1
-- -
New Tutorial: Creating a click counter using carrot and celery
-- -
-
-- Database entries for periodic tasks are now created at celeryd
-- -
startup instead of for each check (which has been a forgotten TODO/XXX -in the code for a long time)
-- -
-
-- New settings variable: CELERY_TASK_RESULT_EXPIRES
-- -
Time (in seconds, or a datetime.timedelta object) for when after -stored task results are deleted. For the moment this only works for the -database backend.
-- -
-
-- celeryd now emits a debug log message for which periodic tasks
-- -
has been launched.
-- -
-
-- The periodic task table is now locked for reading while getting
-- -
periodic task status. (MySQL only so far, seeking patches for other -engines)
-- -
-
-- A lot more debugging information is now available by turning on the
-- -
DEBUG log level (–loglevel=DEBUG).
-- -
Functions/methods with a timeout argument now works correctly.
-- -
-
-- New: celery.strategy.even_time_distribution:
-- -
With an iterator yielding task args, kwargs tuples, evenly distribute -the processing of its tasks throughout the time window available.
-- -
Log message Unknown task ignored... now has log level ERROR
-- -
-
-- Log message “Got task from broker” is now emitted for all tasks, even if
-- -
the task has an ETA (estimated time of arrival). Also the message now -includes the ETA for the task (if any).
-- -
-
-- Acknowledgement now happens in the pool callback. Can’t do ack in the job
-- -
target, as it’s not pickleable (can’t share AMQP connection, etc.)).
-- -
Added note about .delay hanging in README
-- -
Tests now passing in Django 1.1
-- -
Fixed discovery to make sure app is in INSTALLED_APPS
-- -
-
-- Previously overridden pool behavior (process reap, wait until pool worker
-- -
available, etc.) is now handled by multiprocessing.Pool itself.
-- -
Convert statistics data to Unicode for use as kwargs. Thanks Lucy!
---0.4.1¶
--
-- - - - - release-date: 2009-07-02 01:42 P.M CET --
-- Fixed a bug with parsing the message options (mandatory, -routing_key, priority, immediate)
---0.4.0¶
--
-- - - - - release-date: 2009-07-01 07:29 P.M CET --
-- Adds eager execution. celery.execute.apply`|`Task.apply executes the -function blocking until the task is done, for API compatibility it -returns an celery.result.EagerResult instance. You can configure -celery to always run tasks locally by setting the -CELERY_ALWAYS_EAGER setting to True.
-- Now depends on anyjson.
-- 99% coverage using python coverage 3.0.
---0.3.20¶
--
-- - - - - release-date: 2009-06-25 08:42 P.M CET --
-- -
New arguments to apply_async (the advanced version of -delay_task), countdown and eta;
--->>> # Run 10 seconds into the future. ->>> res = apply_async(MyTask, countdown=10); --->>> # Run 1 day from now ->>> res = apply_async(MyTask, -... eta=datetime.now() + timedelta(days=1)) -- -
Now unlinks stale PID files
-- -
Lots of more tests.
-- -
Now compatible with carrot >= 0.5.0.
-- -
IMPORTANT The subtask_ids attribute on the TaskSetResult -instance has been removed. To get this information instead use:
--->>> subtask_ids = [subtask.id for subtask in ts_res.subtasks] -- -
Taskset.run() now respects extra message options from the task class.
-- -
Task: Add attribute ignore_result: Don’t store the status and -return value. This means you can’t use the -celery.result.AsyncResult to check if the task is -done, or get its return value. Only use if you need the performance -and is able live without these features. Any exceptions raised will -store the return value/status as usual.
-- -
Task: Add attribute disable_error_emails to disable sending error -emails for that task.
-- -
Should now work on Windows (although running in the background won’t -work, so using the –detach argument results in an exception -being raised.)
-- -
Added support for statistics for profiling and monitoring. -To start sending statistics start celeryd with the -–statistics option. Then after a while you can dump the results -by running `python manage.py celerystats. See -celery.monitoring for more information.
-- -
The celery daemon can now be supervised (i.e. it is automatically -restarted if it crashes). To use this start celeryd with the -–supervised` option (or alternatively -S).
-- -
views.apply: View calling a task. Example
----http://e.com/celery/apply/task_name/arg1/arg2//?kwarg1=a&kwarg2=b---Warning
-Use with caution! Do not expose this URL to the public -without first ensuring that your code is safe!
-- -
Refactored celery.task. It’s now split into three modules:
----
-- -
celery.task
---Contains apply_async, delay_task, discard_all, and task -shortcuts, plus imports objects from celery.task.base and -celery.task.builtins
-- -
celery.task.base
---Contains task base classes: Task, PeriodicTask, -TaskSet, AsynchronousMapTask, ExecuteRemoteTask.
-- -
celery.task.builtins
---Built-in tasks: PingTask, DeleteExpiredTaskMetaTask.
---0.3.7¶
--
-- - - - - release-date: 2008-06-16 11:41 P.M CET --
-- -
IMPORTANT Now uses AMQP`s basic.consume instead of -basic.get. This means we’re no longer polling the broker for -new messages.
-- -
IMPORTANT Default concurrency limit is now set to the number of CPUs -available on the system.
-- -
IMPORTANT tasks.register: Renamed task_name argument to -name, so
--->>> tasks.register(func, task_name="mytask") -has to be replaced with:
--->>> tasks.register(func, name="mytask") -- -
The daemon now correctly runs if the pidlock is stale.
-- -
Now compatible with carrot 0.4.5
-- -
Default AMQP connection timeout is now 4 seconds.
-- -
AsyncResult.read() was always returning True.
-- -
Only use README as long_description if the file exists so easy_install -doesn’t break.
-- -
celery.view: JSON responses now properly set its mime-type.
-- -
apply_async now has a connection keyword argument so you -can re-use the same AMQP connection if you want to execute -more than one task.
-- -
Handle failures in task_status view such that it won’t throw 500s.
-- -
Fixed typo AMQP_SERVER in documentation to AMQP_HOST.
-- -
Worker exception emails sent to administrators now works properly.
-- -
No longer depends on django, so installing celery won’t affect -the preferred Django version installed.
-- -
Now works with PostgreSQL (psycopg2) again by registering the -PickledObject field.
-- -
celeryd: Added –detach option as an alias to –daemon, and -it’s the term used in the documentation from now on.
-- -
Make sure the pool and periodic task worker thread is terminated -properly at exit. (So Ctrl-C works again).
-- -
Now depends on python-daemon.
-- -
Removed dependency to simplejson
-- -
Cache Backend: Re-establishes connection for every task process -if the Django cache backend is memcached/libmemcached.
-- -
Tyrant Backend: Now re-establishes the connection for every task -executed.
---0.3.3¶
--
-- - - - - release-date: 2009-06-08 01:07 P.M CET --
-- The PeriodicWorkController now sleeps for 1 second between checking -for periodic tasks to execute.
---0.3.2¶
--
-- - - - - release-date: 2009-06-08 01:07 P.M CET --
-- celeryd: Added option –discard: Discard (delete!) all waiting -messages in the queue.
-- celeryd: The –wakeup-after option was not handled as a float.
---0.3.1¶
--
-- - - - - release-date: 2009-06-08 01:07 P.M CET --
-- The PeriodicTask worker is now running in its own thread instead -of blocking the TaskController loop.
-- Default QUEUE_WAKEUP_AFTER has been lowered to 0.1 (was 0.3)
---0.3.0¶
--
-- - - - - release-date: 2009-06-08 12:41 P.M CET ---Warning
-This is a development version, for the stable release, please -see versions 0.2.x.
-VERY IMPORTANT: Pickle is now the encoder used for serializing task -arguments, so be sure to flush your task queue before you upgrade.
--
-- -
IMPORTANT TaskSet.run() now returns a celery.result.TaskSetResult -instance, which lets you inspect the status and return values of a -taskset as it was a single entity.
-- -
IMPORTANT Celery now depends on carrot >= 0.4.1.
-- -
The celery daemon now sends task errors to the registered admin emails. -To turn off this feature, set SEND_CELERY_TASK_ERROR_EMAILS to -False in your settings.py. Thanks to Grégoire Cachet.
-- -
You can now run the celery daemon by using manage.py:
--$ python manage.py celeryd-Thanks to Grégoire Cachet.
-- -
Added support for message priorities, topic exchanges, custom routing -keys for tasks. This means we have introduced -celery.task.apply_async, a new way of executing tasks.
-You can use celery.task.delay and celery.Task.delay like usual, but -if you want greater control over the message sent, you want -celery.task.apply_async and celery.Task.apply_async.
-This also means the AMQP configuration has changed. Some settings has -been renamed, while others are new:
---CELERY_AMQP_EXCHANGE -CELERY_AMQP_PUBLISHER_ROUTING_KEY -CELERY_AMQP_CONSUMER_ROUTING_KEY -CELERY_AMQP_CONSUMER_QUEUE -CELERY_AMQP_EXCHANGE_TYPE -See the entry Can I send some tasks to only some servers? in the -FAQ for more information.
--
-- Task errors are now logged using log level ERROR instead of INFO, -and stacktraces are dumped. Thanks to Grégoire Cachet.
-- Make every new worker process re-establish it’s Django DB connection, -this solving the “MySQL connection died?” exceptions. -Thanks to Vitaly Babiy and Jirka Vejrazka.
-- IMPORTANT Now using pickle to encode task arguments. This means you -now can pass complex python objects to tasks as arguments.
-- Removed dependency to yadayada.
-- Added a FAQ, see docs/faq.rst.
-- Now converts any Unicode keys in task kwargs to regular strings. -Thanks Vitaly Babiy.
-- Renamed the TaskDaemon to WorkController.
-- celery.datastructures.TaskProcessQueue is now renamed to -celery.pool.TaskPool.
-- The pool algorithm has been refactored for greater performance and -stability.
---0.2.0¶
--
-- - - - - release-date: 2009-05-20 05:14 P.M CET --
-- Final release of 0.2.0
-- Compatible with carrot version 0.4.0.
-- Fixes some syntax errors related to fetching results -from the database backend.
---0.2.0-pre3¶
--
-- - - - - release-date: 2009-05-20 05:14 P.M CET --
-- Internal release. Improved handling of unpickleable exceptions, -get_result now tries to recreate something looking like the -original exception.
---0.2.0-pre2¶
--
-- - - - - release-date: 2009-05-20 01:56 P.M CET --
-- Now handles unpickleable exceptions (like the dynamically generated -subclasses of django.core.exception.MultipleObjectsReturned).
---0.2.0-pre1¶
--
-- - - - - release-date: 2009-05-20 12:33 P.M CET --
-- It’s getting quite stable, with a lot of new features, so bump -version to 0.2. This is a pre-release.
-- celery.task.mark_as_read() and celery.task.mark_as_failure() has -been removed. Use celery.backends.default_backend.mark_as_read(), -and celery.backends.default_backend.mark_as_failure() instead.
---0.1.15¶
--
-- - - - - release-date: 2009-05-19 04:13 P.M CET --
-- The celery daemon was leaking AMQP connections, this should be fixed, -if you have any problems with too many files open (like emfile -errors in rabbit.log, please contact us!
---0.1.14¶
--
-- - - - - release-date: 2009-05-19 01:08 P.M CET --
-- Fixed a syntax error in the TaskSet class. (No such variable -TimeOutError).
---0.1.13¶
--
-- - - - - release-date: 2009-05-19 12:36 P.M CET --
-- -
Forgot to add yadayada to install requirements.
-- -
Now deletes all expired task results, not just those marked as done.
-- -
Able to load the Tokyo Tyrant backend class without django -configuration, can specify tyrant settings directly in the class -constructor.
-- -
Improved API documentation
-- -
Now using the Sphinx documentation system, you can build -the html documentation by doing
--$ cd docs -$ make html-and the result will be in docs/.build/html.
---0.1.12¶
--
-- - - - - release-date: 2009-05-18 04:38 P.M CET --
-- -
delay_task() etc. now returns celery.task.AsyncResult object, -which lets you check the result and any failure that might have -happened. It kind of works like the multiprocessing.AsyncResult -class returned by multiprocessing.Pool.map_async.
-- -
Added dmap() and dmap_async(). This works like the -multiprocessing.Pool versions except they are tasks -distributed to the celery server. Example:
--->>> from celery.task import dmap ->>> import operator ->>> dmap(operator.add, [[2, 2], [4, 4], [8, 8]]) ->>> [4, 8, 16] --->>> from celery.task import dmap_async ->>> import operator ->>> result = dmap_async(operator.add, [[2, 2], [4, 4], [8, 8]]) ->>> result.ready() -False ->>> time.sleep(1) ->>> result.ready() -True ->>> result.result -[4, 8, 16] -- -
Refactored the task metadata cache and database backends, and added -a new backend for Tokyo Tyrant. You can set the backend in your django -settings file. E.g.:
---CELERY_RESULT_BACKEND = "database"; # Uses the database -CELERY_RESULT_BACKEND = "cache"; # Uses the django cache framework -CELERY_RESULT_BACKEND = "tyrant"; # Uses Tokyo Tyrant -TT_HOST = "localhost"; # Hostname for the Tokyo Tyrant server. -TT_PORT = 6657; # Port of the Tokyo Tyrant server. ---0.1.11¶
--
-- - - - - release-date: 2009-05-12 02:08 P.M CET --
-- The logging system was leaking file descriptors, resulting in -servers stopping with the EMFILES (too many open files) error. (fixed)
---0.1.10¶
--
-- - - - - release-date: 2009-05-11 12:46 P.M CET --
-- Tasks now supports both positional arguments and keyword arguments.
-- Requires carrot 0.3.8.
-- The daemon now tries to reconnect if the connection is lost.
---0.1.8¶
--
-- - - - - release-date: 2009-05-07 12:27 P.M CET --
-- Better test coverage
-- More documentation
-- celeryd doesn’t emit Queue is empty message if -settings.CELERYD_EMPTY_MSG_EMIT_EVERY is 0.
---0.1.7¶
--
-- - - - - release-date: 2009-04-30 01:50 P.M CET --
-- Added some unit tests
-- Can now use the database for task metadata (like if the task has -been executed or not). Set settings.CELERY_TASK_META
-- Can now run python setup.py test to run the unit tests from -within the tests project.
-- Can set the AMQP exchange/routing key/queue using -settings.CELERY_AMQP_EXCHANGE, settings.CELERY_AMQP_ROUTING_KEY, -and settings.CELERY_AMQP_CONSUMER_QUEUE.
--- diff --git a/configuration.html b/configuration.html index c460e112aa5..9a22c3a550e 100644 --- a/configuration.html +++ b/configuration.html @@ -174,7 +174,7 @@0.1.6¶
--
-- - - - - release-date: 2009-04-28 02:13 P.M CET --
-- -
Introducing TaskSet. A set of subtasks is executed and you can -find out how many, or if all them, are done (excellent for progress -bars and such)
-- -
Now catches all exceptions when running Task.__call__, so the -daemon doesn’t die. This doesn’t happen for pure functions yet, only -Task classes.
-- -
autodiscover() now works with zipped eggs.
-- -
celeryd: Now adds current working directory to sys.path for -convenience.
-- -
The run_every attribute of PeriodicTask classes can now be a -datetime.timedelta() object.
-- -
celeryd: You can now set the DJANGO_PROJECT_DIR variable -for celeryd and it will add that to sys.path for easy launching.
-- -
Can now check if a task has been executed or not via HTTP.
-- -
You can do this by including the celery urls.py into your project,
--->>> url(r'^celery/$', include("celery.urls")) -then visiting the following url,:
--http://mysite/celery/$task_id/done/-this will return a JSON dictionary like e.g:
-->>> {"task": {"id": $task_id, "executed": true}}-- -
delay_task now returns string id, not uuid.UUID instance.
-- -
Now has PeriodicTasks, to have cron like functionality.
-- -
Project changed name from crunchy to celery. The details of -the name change request is in docs/name_change_request.txt.
-Configuration Directiveson_failure handler:
+@@ -576,6 +576,27 @@def my_on_failure(self, exc, task_id, args, kwargs, einfo): - print("Oh no! Task failed: %r" % (exc, )) + print("Oh no! Task failed: {0!r}".format(exc)) CELERY_ANNOTATIONS = {"*": {"on_failure": my_on_failure}}Example configurationRouters for more information.
+CELERY_WORKER_DIRECT¶
+This option enables so that every worker has a dedicated queue, +so that tasks can be routed to specific workers.
+The queue name for each worker is automatically generated based on +the worker hostname and a .dq suffix, using the C.dq exchange.
+For example the queue name for the worker with hostname w1.example.com +becomes:
+++w1.example.com.dq +Then you can route the task to the task by specifying the hostname +as the routung key and the C.dq exchange:
+++CELERY_ROUTES = { + 'tasks.add': {'exchange': 'C.dq', 'routing_key': 'w1.example.com'} +} +This setting is mandatory if you want to use the move_to_worker features +of celery.contrib.migrate.
+CELERY_CREATE_MISSING_QUEUES¶
If enabled (default), any queues specified that is not defined in @@ -650,6 +671,29 @@
Example configuration +
BROKER_HEARTBEAT¶
++
++ + + + transports supported: + + pyamqp +It’s not always possible to detect connection loss in a timely +manner using TCP/IP alone, so AMQP defines something called heartbeats +that’s is used both by the client and the broker to detect if +a connection was closed.
+Heartbeats are currently only supported by the pyamqp:// transport, +and this requires the amqp module:
++$ pip install amqp+The default heartbeat value is 10 seconds, +the heartbeat will then be monitored at double the rate of the heartbeat value +(so for the default 10 seconds, the heartbeat is checked every 5 seconds).
+@@ -637,7 +637,8 @@BROKER_USE_SSL¶
Use SSL to connect to the broker. Off by default. This may not be supported diff --git a/contributing.html b/contributing.html index 5e4ed56e76b..27626a22629 100644 --- a/contributing.html +++ b/contributing.html @@ -477,7 +477,7 @@
Forking and setting up the repository
If you only want to test specific Python versions use the -e option:
-$ tox -e py25,py26+$ tox -e py26API reference -
If the module uses the with statement it must also enable that:
+If the module uses the with statement and must be compatible +with Python 2.5 (celery is not) then it must also enable that:
diff --git a/django/index.html b/django/index.html index d261c601024..da4ceddecaa 100644 --- a/django/index.html +++ b/django/index.html @@ -74,7 +74,7 @@from __future__ import with_statementNavigation
- Release: 3.1 Date: July 07, 2012 +Date: July 28, 2012 Can I use decorators with tasks?@celery.task(ignore_result=True) def log_result(result): - logger.info("log_result got: %r" % (result, )) + logger.info("log_result got: %r", result)
Invocation:
diff --git a/genindex.html b/genindex.html index 343eae70cc8..6a08eb587f1 100644 --- a/genindex.html +++ b/genindex.html @@ -697,6 +697,16 @@A
+- add_defaults() (celery.Celery method) +
+ +- +
- add_events() (celery.worker.autoreload.KQueueMonitor method)
@@ -729,6 +739,10 @@A
+- add_task_queue() (celery.worker.consumer.Consumer method) +
+ +- add_unlock_chord_task() (in module celery.app.builtins)
@@ -814,17 +828,21 @@A
- AlreadyRegistered
+ +- - +
- AlwaysEagerIgnored
+- AMQHEARTBEAT_RATE (in module celery.worker.consumer) +
+ +- amqp (celery.bin.camqadm.AMQShell attribute), [1]
@@ -1514,6 +1532,17 @@B
- + BROKER_HEARTBEAT +
+ +- +
+ +
- setting +
+ +- BROKER_HOST (celery.app.utils.Settings attribute)
@@ -1672,12 +1701,6 @@C
- callbacks (celery.backends.amqp.AMQPBackend.Consumer attribute)
-- -
- (celery.worker.job.Request attribute) -
- -- calling
@@ -1778,7 +1801,7 @@C
-- cancel_consumer() +
- cancel_consumer()
- +
@@ -1796,6 +1819,10 @@
C
- cancel_task_queue() (celery.worker.consumer.Consumer method) +
+ +- cancelled (celery.concurrency.base.BasePool.Timer.Entry attribute)
@@ -2537,7 +2564,7 @@C
-- CELERY_BROKER_URL +
- CELERY_BROKER_URL
@@ -2563,7 +2590,7 @@C
-- CELERY_CONFIG_MODULE, [1] +
- CELERY_CONFIG_MODULE, [1]
@@ -2721,7 +2748,7 @@C
-- CELERY_LOADER, [1], [2], [3], [4], [5] +
- CELERY_LOADER, [1], [2], [3], [4], [5]
@@ -3066,6 +3093,17 @@C
+- + CELERY_WORKER_DIRECT +
+ +- +
+ +
- setting +
+ +- CELERYBEAT_MAX_LOOP_INTERVAL
@@ -3114,6 +3152,17 @@C
+- + celeryd_after_setup +
+ +- +
+ +
- signal +
+ +- CELERYD_AUTORELOADER
@@ -3372,16 +3421,6 @@C
-- chain_from_iterable() (in module celery.utils.compat) -
- -- -
- -
- (in module celery.worker.buckets) -
- -- chan (celery.bin.camqadm.AMQShell attribute)
@@ -3821,6 +3860,10 @@C
+- conf() (celery.app.control.Inspect method) +
+ +- config_from_envvar() (celery.Celery method)
@@ -3905,6 +3948,10 @@C
+- connection_or_acquire() (celery.Celery method) +
+ +- construct() (celery.app.utils.AppPickler method)
@@ -3947,10 +3994,6 @@C
-- consumer() (celery.events.EventReceiver method) -
- -- Consumer() (celery.worker.consumer.Component method)
@@ -4332,10 +4375,6 @@D
-- default_connection() (celery.Celery method) -
- -- default_dispatcher() (celery.events.Events method)
@@ -4489,12 +4528,12 @@D
- deserialize() (celery.security.serialization.SecureSerializer method)
-+ -
- detailed_mode (celery.backends.cassandra.CassandraBackend attribute)
@@ -4656,12 +4695,6 @@D
- drain_events() (celery.backends.amqp.AMQPBackend method)
-- -
- (celery.events.EventReceiver method) -
- -- draw() (celery.events.cursesmon.CursesMonitor method)
@@ -4683,6 +4716,10 @@D
+- dump_conf() (in module celery.worker.control) +
+ +- dump_message() (in module celery.bin.camqadm)
@@ -5027,15 +5064,15 @@E
-- CELERY_BROKER_URL +
- CELERY_BROKER_URL
-- CELERY_CONFIG_MODULE, [1] +
-- CELERY_CONFIG_MODULE, [1]
-- CELERY_LOADER, [1], [2], [3], [4], [5] +
-- CELERY_LOADER, [1], [2], [3], [4], [5]
@@ -5063,7 +5100,7 @@E
- NOSE_VERBOSE +
-- NOSE_VERBOSE
@@ -5080,10 +5117,6 @@E
- errbacks (celery.worker.job.Request attribute) -
- -- Error
@@ -5106,10 +5139,6 @@E
- error_whitelist (celery.utils.mail.ErrorMail attribute) -
- -- ErrorMail (class in celery.utils.mail)
@@ -5143,16 +5172,12 @@E
- evdump() (in module celery.events.dumper)
-+ +
- Event() (in module celery.events)
@@ -5377,6 +5402,10 @@E
+- expand_dest() (in module celery.contrib.migrate) +
+ +- expand_destination() (celery.app.routes.Router method)
@@ -5494,10 +5523,18 @@F
+- filter_status() (in module celery.contrib.migrate) +
+ +- filter_types() (celery.app.registry.TaskRegistry method)
+- filtered (celery.contrib.migrate.State attribute) +
+ +- finalize() (celery.Celery method)
@@ -5614,6 +5651,14 @@F
+- fmt_empty (celery.bin.celery.purge attribute) +
+ + +- fmt_purged (celery.bin.celery.purge attribute) +
+ +- force_execv (celery.apps.worker.Worker.WorkController attribute)
@@ -5724,7 +5769,7 @@F
-- freeze() (State method) +
- freeze() (State method)
@@ -5733,7 +5778,7 @@F
- @@ -5884,6 +5929,10 @@
G
+- get_consumers() (celery.events.EventReceiver method) +
+ +- get_current_app() (in module celery._state)
@@ -5957,12 +6006,12 @@G
- get_leaf() (celery.result.AsyncResult method)
+- + +
- get_logger() (in module celery.utils.log)
@@ -6854,6 +6903,10 @@I
+- is_naive() (in module celery.utils.timeutils) +
+ +- isatty() (celery.utils.log.LoggingProxy method)
@@ -6997,10 +7050,14 @@J
- join_native() (celery.result.ResultSet method) +
+@@ -7096,7 +7153,7 @@ L
-- leaf (celery.bin.celery.Command attribute) +
+- leaf (celery.bin.base.Command attribute)
@@ -7128,6 +7185,10 @@L
- load_extension_commands() (in module celery.bin.celery) +
+ +- load_modules() (celery.worker.bootsteps.Namespace method)
@@ -7425,6 +7486,10 @@M
+- maybe_patch_concurrency() (celery.bin.base.Command method) +
+ +- maybe_reraise() (in module celery.utils)
@@ -7452,8 +7517,6 @@M
- Mediator (class in celery.worker.mediator)
- -+ +
- mediator_cls (celery.apps.worker.Worker.WorkController attribute)
@@ -7464,6 +7527,8 @@M
+ +
- mem_rss() (in module celery.utils.debug)
@@ -7601,6 +7666,18 @@M
+- move() (in module celery.contrib.migrate) +
+ + +- move_by_idmap() (in module celery.contrib.migrate) +
+ + +- move_by_taskmap() (in module celery.contrib.migrate) +
+ +- move_selection() (celery.events.cursesmon.CursesMonitor method)
@@ -7613,11 +7690,11 @@M
-- MP_LOG +
- move_task_by_id() (in module celery.contrib.migrate)
-- MP_MAIN_FILE (in module celery.utils) +
-- MP_LOG
@@ -7899,7 +7976,7 @@N
- NOSE_VERBOSE +
- NOSE_VERBOSE
@@ -8061,6 +8138,20 @@O
- on_concurrency_setup() (celery.bin.base.Command method) +
+ +- + +
+ +
- (celery.bin.celery.CeleryCommand method) +
+ +- on_consume_ready() (celery.events.EventReceiver method) +
+ +- on_consumer_ready() (celery.apps.worker.Worker method)
@@ -8194,6 +8285,8 @@O
- on_retried() (celery.events.state.Task method)
+- -
- on_retry()
@@ -8208,8 +8301,6 @@O
-
- on_return (celery.backends.amqp.AMQPBackend.Producer attribute)
@@ -8709,12 +8800,12 @@P
- PRECEDENCE (in module celery.states)
-+ - +
- PREFETCH_COUNT_MAX (in module celery.worker.consumer)
@@ -8778,6 +8869,10 @@P
- prepare_queues() (in module celery.contrib.migrate) +
+ +- prepare_value() (celery.backends.base.BaseBackend method)
@@ -8876,6 +8971,10 @@P
+- producer_or_acquire() (celery.Celery method) +
+ +- prog_name (celery.bin.celery.CeleryCommand attribute)
@@ -8886,6 +8985,10 @@P
+- progress_fmt (celery.bin.celery.migrate attribute) +
+ +- prompt (celery.bin.camqadm.AMQShell attribute)
@@ -9486,6 +9589,10 @@R
+- republish() (in module celery.contrib.migrate) +
+ +- request
@@ -10105,14 +10212,6 @@S
- (celery.events.dumper.Dumper method)
- -- (in module celery.bin.camqadm) -
- - -- (in module celery.events.dumper) -
-- say_chat() (celery.bin.celery.Command method) @@ -10502,6 +10601,10 @@
+S
- set_tz() (in module celery.utils.timeutils) +
+ +- setdefault() (celery.datastructures.ConfigurationView method)
@@ -10550,6 +10653,10 @@S
+- BROKER_HEARTBEAT +
+ +- BROKER_POOL_LIMIT
@@ -10898,6 +11005,10 @@S
+- CELERY_WORKER_DIRECT +
+ +- EMAIL_HOST
@@ -10999,12 +11110,12 @@S
- setup_settings() (celery.loaders.default.Loader method)
-+ + +
- shared_task() (in module celery.app.builtins)
@@ -11040,6 +11151,16 @@S
+- should_use_eventloop() (celery.apps.worker.Worker.WorkController method) +
+ +- +
+ +
- (celery.worker.WorkController method) +
+ +- show() (celery.bin.celeryd_multi.MultiTool method)
@@ -11135,6 +11256,10 @@S
+- celeryd_after_setup +
+ +- celeryd_init
@@ -11240,6 +11365,10 @@S
+- simple_format() (celery.bin.base.Command method) +
+ +- SimpleRequest (class in celery.contrib.batches)
@@ -11258,72 +11387,6 @@S
-- sortpri (celery.bin.celery.amqp attribute) -
- -- -
- -
- (celery.bin.celery.beat attribute) -
- - -- (celery.bin.celery.call attribute) -
- - -- (celery.bin.celery.control attribute) -
- - -- (celery.bin.celery.events attribute) -
- - -- (celery.bin.celery.help attribute) -
- - -- (celery.bin.celery.inspect attribute) -
- - -- (celery.bin.celery.list_ attribute) -
- - -- (celery.bin.celery.migrate attribute) -
- - -- (celery.bin.celery.multi attribute) -
- - -- (celery.bin.celery.purge attribute) -
- - -- (celery.bin.celery.report attribute) -
- - -- (celery.bin.celery.result attribute) -
- - -- (celery.bin.celery.shell attribute) -
- - -- (celery.bin.celery.status attribute) -
- - -- (celery.bin.celery.worker attribute) -
- -- Spec (class in celery.bin.camqadm)
@@ -11428,6 +11491,10 @@S
- start_filter() (in module celery.contrib.migrate) +
+ +- start_scheduler() (celery.apps.beat.Beat method)
@@ -11594,6 +11661,10 @@S
+- status_string (celery.events.state.Worker attribute) +
+ +- stop() (celery.apps.beat.Beat.Service method)
@@ -11704,6 +11775,10 @@S
+- StopFiltering +
+ +- storage (celery.worker.state.Persistent attribute)
@@ -11867,10 +11942,6 @@S
-- supports_timeout (celery.utils.mail.Mailer attribute) -
- -- symbol_by_name() (celery.bin.base.Command method)
@@ -12006,6 +12077,14 @@T
+- task_id_eq() (in module celery.contrib.migrate) +
+ + +- task_id_in() (in module celery.contrib.migrate) +
+ +- task_keyprefix (celery.backends.base.KeyValueStoreBackend attribute)
@@ -12234,12 +12313,12 @@T
- tasks_by_timestamp() (celery.events.state.State method)
+- -
- tasks_by_worker() (celery.events.state.State method)
@@ -12339,11 +12418,7 @@T
- thaw() (State method) -
- - -- Thread (class in celery.utils.threads) +
+- thaw() (State method)
@@ -12489,6 +12564,10 @@T
- to_utc() (in module celery.utils.timeutils) +
+ +- TokenBucketQueue (class in celery.worker.buckets)
@@ -12868,6 +12947,20 @@W
+- with_pool_option() (celery.bin.base.Command method) +
+ +- +
- without_defaults() (celery.app.utils.Settings method)
@@ -12910,6 +13003,10 @@W
+- worker_direct() (in module celery.utils) +
+ +- worker_event() (celery.events.state.State method)
diff --git a/getting-started/brokers/index.html b/getting-started/brokers/index.html index f0340fa8559..d16795f1253 100644 --- a/getting-started/brokers/index.html +++ b/getting-started/brokers/index.html @@ -76,7 +76,7 @@Navigation
- Release: 3.1 Date: July 07, 2012 +diff --git a/getting-started/brokers/redis.html b/getting-started/brokers/redis.html index de3538817ad..ebc626dcc7b 100644 --- a/getting-started/brokers/redis.html +++ b/getting-started/brokers/redis.html @@ -87,8 +87,10 @@ Date: July 28, 2012 Navigation
Where the URL is in the format of:
-diff --git a/internals/reference/celery.utils.log.html b/internals/reference/celery.utils.log.html index fd0b943e802..1776be1e702 100644 --- a/internals/reference/celery.utils.log.html +++ b/internals/reference/celery.utils.log.html @@ -85,8 +85,7 @@redis://userid:password@hostname:port/db_number++redis://:password@hostname:port/db_numberall fields after the scheme are optional, and will default to localhost on port 6379, +using database 0.
diff --git a/internals/guide.html b/internals/guide.html index 6d689916f31..5d388b1ad6a 100644 --- a/internals/guide.html +++ b/internals/guide.html @@ -180,7 +180,7 @@Results¶
If you also want to store the state and return values of tasks in Redis, diff --git a/getting-started/index.html b/getting-started/index.html index 60446a40c98..0196e545939 100644 --- a/getting-started/index.html +++ b/getting-started/index.html @@ -74,7 +74,7 @@
Getting Started
- Release: 3.1 Date: July 07, 2012 +diff --git a/getting-started/introduction.html b/getting-started/introduction.html index fb490ed4bac..e0ebc6996e2 100644 --- a/getting-started/introduction.html +++ b/getting-started/introduction.html @@ -229,9 +229,9 @@ Date: July 28, 2012 Features
-
Monitoring
--The stream of monitoring events emitted by the worker are used -by built-in and external tools to tell you what your cluster -is doing in real-time.
+diff --git a/glossary.html b/glossary.html index 5abc269b2e8..0067400aeb8 100644 --- a/glossary.html +++ b/glossary.html @@ -26,7 +26,7 @@ - + diff --git a/internals/deprecation.html b/internals/deprecation.html index 473546d2ad7..b59d1a4cee6 100644 --- a/internals/deprecation.html +++ b/internals/deprecation.html @@ -187,12 +187,12 @@A stream of monitoring events is emitted by workers and +is used by built-in and external tools to tell you what +your cluster is doing – in real-time.
Magic keyword argumentsprint("My task id is %r" % (task_id, ))
must be rewritten into:
+should be rewritten into:
@@ -308,9 +308,6 @@from celery import task @task() def add(x, y): - print("My task id is %r" % (add.request.id, )) + print("My task id is {0.request.id}".format(add))
BROKER_VHOST BROKER_URL BROKER_INSIST -no alternative -Default valuesExample:
diff --git a/internals/reference/celery.events.snapshot.html b/internals/reference/celery.events.snapshot.html index a68e52dc49c..3888a8d4f82 100644 --- a/internals/reference/celery.events.snapshot.html +++ b/internals/reference/celery.events.snapshot.html @@ -138,7 +138,7 @@class Producer(object): active = True - serializer = "json" + serializer = 'json' def __init__(self, serializer=None): self.serializer = serializer or self.serializer @@ -191,11 +191,11 @@Default values
A subclass can change the default value:
TaskProducer(Producer): - serializer = "pickle" + serializer = 'pickle'and the value can be set at instantiation:
-diff --git a/internals/index.html b/internals/index.html index 1993c37113b..76e360c1b8b 100644 --- a/internals/index.html +++ b/internals/index.html @@ -74,7 +74,7 @@@@ -289,7 +289,7 @@>>> producer = TaskProducer(serializer="msgpack") +>>> producer = TaskProducer(serializer='msgpack')Applications vs. “single mode”
from celery import Celery celery = Celery() -celery.config_from_object(BROKER_URL="amqp://") +celery.config_from_object(BROKER_URL='amqp://')Navigation
- Release: 3.1 Date: July 07, 2012 +diff --git a/internals/protocol.html b/internals/protocol.html index e70f57fc510..36c16d7c54f 100644 --- a/internals/protocol.html +++ b/internals/protocol.html @@ -190,6 +190,23 @@ Date: July 28, 2012 Message format +
+
+- timeouts
+- +
+
++ + + + + tuple: + +New in version 2.7.
+Task execution timeouts. This is a tuple of hard and soft timeouts. +Timeout values are int or float.
+diff --git a/internals/reference/celery._state.html b/internals/reference/celery._state.html index ee664983f1b..b8b11189187 100644 --- a/internals/reference/celery._state.html +++ b/internals/reference/celery._state.html @@ -27,7 +27,7 @@ - + @@ -41,7 +41,7 @@Navigation
modules |- - next |
- celery._stateThis module shouldn’t be used directly.
@@ -95,7 +95,7 @@
- -celery._state.current_app = <Celery __main__:0x101b79410>¶
+celery._state.current_app = <Celery __main__:0x101af6950>¶Proxy to current app.
celery._state
- -celery._state.default_app = <Celery default:0x101b79390>¶
+celery._state.default_app = <Celery default:0x101af68d0>¶- @@ -139,8 +139,8 @@
Global default app used when no current app.
Previous topic
Next topic
- +This Page
celery.events.snapshot
- -timer = <module 'celery.utils.timer2' from '/opt/devel/celery/celery/utils/timer2.py'>¶
+timer = <module 'celery.utils.timer2' from '/Users/mher/Projects/Celery/celery/celery/utils/timer2.py'>¶ diff --git a/internals/reference/celery.platforms.html b/internals/reference/celery.platforms.html index 5389452848d..d4b1319122b 100644 --- a/internals/reference/celery.platforms.html +++ b/internals/reference/celery.platforms.html @@ -133,8 +133,7 @@celery.platforms
- path = None¶
-- +
Path to the pid lock file.
-
- @@ -415,7 +414,7 @@
celery.platforms
- -celery.platforms.shellsplit(s, posix=True)¶
+celery.platforms.shellsplit(s)¶diff --git a/internals/reference/celery.utils.compat.html b/internals/reference/celery.utils.compat.html index 284b21a6c11..36cc68ea13a 100644 --- a/internals/reference/celery.utils.compat.html +++ b/internals/reference/celery.utils.compat.html @@ -80,14 +80,6 @@
celery.utils.compatcelery.utils.compat¶
Compatibility implementations of features only available in newer Python versions.
--
-- -celery.utils.compat.chain_from_iterable()¶
-chain.from_iterable(iterable) –> chain object
-Alternate chain() contructor taking a single iterable argument -that evaluates lazily.
-
- celery.utils.compat.format_d(i)¶
diff --git a/internals/reference/celery.utils.functional.html b/internals/reference/celery.utils.functional.html index 41d2595fa47..c5743a7273c 100644 --- a/internals/reference/celery.utils.functional.html +++ b/internals/reference/celery.utils.functional.html @@ -179,7 +179,7 @@celery.utils.functional
- -celery.utils.functional.memoize(maxsize=None, Cache=<class celery.utils.functional.LRUCache at 0x1019d58d8>)¶
+celery.utils.functional.memoize(maxsize=None, Cache=<class celery.utils.functional.LRUCache at 0x101a9fe88>)¶diff --git a/internals/reference/celery.utils.html b/internals/reference/celery.utils.html index 08e235fdc02..6abba2c310c 100644 --- a/internals/reference/celery.utils.html +++ b/internals/reference/celery.utils.html @@ -79,15 +79,6 @@
celery.utils
celery.utils¶
Utility functions.
--
-- -celery.utils.MP_MAIN_FILE = None¶
-Billiard sets this when execv is enabled. -We use it to find out the name of the original __main__ -module, so that we can properly rewrite the name of the -task to be that of App.main.
-+
- celery.utils.cry()¶
@@ -148,6 +139,12 @@celery.utilscelery.utils.isatty(fh)¶
+
+- +celery.utils.jsonify(obj)¶
+Transforms object making it suitable for json serialization
++
- celery.utils.lpmerge(L, R)¶
@@ -172,6 +169,11 @@celery.utilscelery.utils.warn_deprecated(description=None, deprecation=None, removal=None, alternative=None)¶
+
+- +celery.utils.worker_direct(hostname)¶
+celery.utils.log
+
- COLORS = {'blue': <bound method colored.blue of ''>, 'black': <bound method colored.black of ''>, 'yellow': <bound method colored.yellow of ''>, 'cyan': <bound method colored.cyan of ''>, 'green': <bound method colored.green of ''>, 'magenta': <bound method colored.magenta of ''>, 'white': <bound method colored.white of ''>, 'red': <bound method colored.red of ''>}¶
-Loglevel -> Color mapping.
-+
- diff --git a/internals/reference/celery.utils.serialization.html b/internals/reference/celery.utils.serialization.html index 39dd9c9dcf9..9bf8bc0f3b8 100644 --- a/internals/reference/celery.utils.serialization.html +++ b/internals/reference/celery.utils.serialization.html @@ -99,7 +99,7 @@
celery.utils.serialization
diff --git a/internals/reference/celery.worker.consumer.html b/internals/reference/celery.worker.consumer.html index 2c222121a8d..11fd12cc897 100644 --- a/internals/reference/celery.worker.consumer.html +++ b/internals/reference/celery.worker.consumer.html @@ -139,9 +139,15 @@>>> try: ... something_raising_unpickleable_exc() ->>> except Exception, e: +>>> except Exception as e: ... exc = UnpickleableException(e.__class__.__module__, ... e.__class__.__name__, ... e.args) diff --git a/internals/reference/celery.utils.threads.html b/internals/reference/celery.utils.threads.html index 7d194fa3075..ee53a2f9a16 100644 --- a/internals/reference/celery.utils.threads.html +++ b/internals/reference/celery.utils.threads.html @@ -79,11 +79,6 @@celery.utils.threads
celery.utils.threads¶
Threading utilities.
--
-- -class celery.utils.threads.Event(verbose=None)¶
--
- class celery.utils.threads.LocalStack¶
@@ -94,11 +89,6 @@celery.utils.threads -
- -class celery.utils.threads.Thread(group=None, target=None, name=None, args=(), kwargs=None, verbose=None)¶
-+
- class celery.utils.threads.bgThread(name=None, **kwargs)¶
diff --git a/internals/reference/celery.utils.timeutils.html b/internals/reference/celery.utils.timeutils.html index c547796b549..3f9a2836546 100644 --- a/internals/reference/celery.utils.timeutils.html +++ b/internals/reference/celery.utils.timeutils.html @@ -96,6 +96,13 @@celery.utils.timeutils +
- +celery.utils.timeutils.is_naive(dt)¶
+Returns True if the datetime is naive +(does not have timezone information).
++
- celery.utils.timeutils.maybe_iso8601(dt)¶
@@ -139,6 +146,12 @@celery.utils.timeutils +
- +celery.utils.timeutils.set_tz(dt, tz)¶
+Sets the timezone for a datetime object.
++
- celery.utils.timeutils.timedelta_seconds(delta)¶
@@ -146,6 +159,12 @@celery.utils.timeutils +
- +celery.utils.timeutils.to_utc(dt)¶
+Converts naive datetime to UTC
+-
- celery.utils.timeutils.weekday(name)¶
diff --git a/internals/reference/celery.worker.buckets.html b/internals/reference/celery.worker.buckets.html index 515fbe431bb..77cf6a728df 100644 --- a/internals/reference/celery.worker.buckets.html +++ b/internals/reference/celery.worker.buckets.html @@ -359,14 +359,6 @@celery.worker.buckets -
- -celery.worker.buckets.chain_from_iterable()¶
-chain.from_iterable(iterable) –> chain object
-Alternate chain() contructor taking a single iterable argument -that evaluates lazily.
-celery.worker.consumer +
- +celery.worker.consumer.AMQHEARTBEAT_RATE = 2.0¶
+Heartbeat check is called every heartbeat_seconds’ / rate’.
+diff --git a/internals/reference/index.html b/internals/reference/index.html index bf1cc4501a1..8a45de0ecd1 100644 --- a/internals/reference/index.html +++ b/internals/reference/index.html @@ -76,7 +76,7 @@
- -class celery.worker.consumer.BlockingConsumer(ready_queue, init_callback=<function noop at 0x101b18488>, send_events=False, hostname=None, initial_prefetch_count=2, pool=None, app=None, timer=None, controller=None, hub=None, **kwargs)¶
+class celery.worker.consumer.BlockingConsumer(ready_queue, init_callback=<function noop at 0x101a9bde8>, send_events=False, hostname=None, initial_prefetch_count=2, pool=None, app=None, timer=None, controller=None, hub=None, amqheartbeat=None, **kwargs)¶diff --git a/internals/reference/celery.worker.state.html b/internals/reference/celery.worker.state.html index 3529482a3e7..7997689d1bc 100644 --- a/internals/reference/celery.worker.state.html +++ b/internals/reference/celery.worker.state.html @@ -181,7 +181,7 @@
- consume_messages()¶
@@ -181,7 +187,7 @@celery.worker.consumer
- -class celery.worker.consumer.Consumer(ready_queue, init_callback=<function noop at 0x101b18488>, send_events=False, hostname=None, initial_prefetch_count=2, pool=None, app=None, timer=None, controller=None, hub=None, **kwargs)¶
+class celery.worker.consumer.Consumer(ready_queue, init_callback=<function noop at 0x101a9bde8>, send_events=False, hostname=None, initial_prefetch_count=2, pool=None, app=None, timer=None, controller=None, hub=None, amqheartbeat=None, **kwargs)¶Listen for messages received from the broker and move them to the ready queue for task processing.
celery.worker.state
- -celery.worker.state.total_count = defaultdict(<function <lambda> at 0x1058b7aa0>, {})¶
+celery.worker.state.total_count = defaultdict(<function <lambda> at 0x1082d57d0>, {})¶count of tasks executed by the worker, sorted by type.
Internal Module Reference
- Release: 3.1 Date: July 07, 2012 +diff --git a/objects.inv b/objects.inv index 066827be7d5..bdc8449e9a6 100644 Binary files a/objects.inv and b/objects.inv differ diff --git a/reference/celery.app.control.html b/reference/celery.app.control.html index 3e8514e39e5..5216468f20e 100644 --- a/reference/celery.app.control.html +++ b/reference/celery.app.control.html @@ -185,6 +185,8 @@ Date: July 28, 2012 celery.app.controlkombu.entitiy.Queue.from_dict(). @@ -370,7 +372,7 @@
celery.app.control
- -class celery.app.control.Inspect(destination=None, timeout=1, callback=None, connection=None, app=None)¶
+class celery.app.control.Inspect(destination=None, timeout=1, callback=None, connection=None, app=None, limit=None)¶- diff --git a/reference/celery.app.html b/reference/celery.app.html index 4dbc06dbbc4..a17f85cf542 100644 --- a/reference/celery.app.html +++ b/reference/celery.app.html @@ -82,7 +82,7 @@
+
- active(safe=False)¶
@@ -386,6 +388,11 @@celery.app.controlapp = None¶
+
+- +conf()¶
+
- ping()¶
@@ -393,12 +400,12 @@celery.app.control
- -registered()¶
+registered(*taskinfoitems)¶diff --git a/reference/celery.app.defaults.html b/reference/celery.app.defaults.html index e6af02e9091..5430ecaaf7b 100644 --- a/reference/celery.app.defaults.html +++ b/reference/celery.app.defaults.html @@ -103,7 +103,7 @@
celery.app.defaults
- -typemap = {'bool': <function strtobool at 0x101b18f50>, 'string': <type 'str'>, 'tuple': <type 'tuple'>, 'int': <type 'int'>, 'dict': <type 'dict'>, 'float': <type 'float'>, 'any': <function <lambda> at 0x101b5cc80>}¶
+typemap = {'bool': <function strtobool at 0x101aa3938>, 'string': <type 'str'>, 'tuple': <type 'tuple'>, 'int': <type 'int'>, 'dict': <type 'dict'>, 'float': <type 'float'>, 'any': <function <lambda> at 0x101ad4398>}¶celery.appProxies¶
celery.app.task
- -Task.backend = <celery.backends.cache.CacheBackend object at 0x107306a10>¶
+Task.backend = <celery.backends.cache.CacheBackend object at 0x1060ed050>¶- @@ -543,6 +543,8 @@
The result store backend used for this task.
celery.app.tasketa – Explicit time and date to run the retry at (must be a datetime instance).
- max_retries – If set, overrides the default retry limit.
+- timeout – If set, overrides the default timeout.
+- soft_timeout – If set, overrides the default soft timeout.
- **options – Any extra options to pass on to meth:apply_async.
- throw – If this is False, do not raise the @@ -569,7 +571,7 @@
celery.app.task... twitter = Twitter(oauth=auth) ... try: ... twitter.post_status_update(message) -... except twitter.FailWhale, exc: +... except twitter.FailWhale as exc: ... # Retry in 5 minutes. ... raise tweet.retry(countdown=60 * 5, exc=exc)
celery.app.utils
- -celery.app.utils.BUGREPORT_INFO = '\nsoftware -> celery:%(celery_v)s kombu:%(kombu_v)s py:%(py_v)s\n billiard:%(billiard_v)s %(driver_v)s\nplatform -> system:%(system)s arch:%(arch)s imp:%(py_i)s\nloader -> %(loader)s\nsettings -> transport:%(transport)s results:%(results)s\n\n%(human_settings)s\n'¶
+celery.app.utils.BUGREPORT_INFO = '\nsoftware -> celery:{celery_v} kombu:{kombu_v} py:{py_v}\n billiard:{billiard_v} {driver_v}\nplatform -> system:{system} arch:{arch} imp:{py_i}\nloader -> {loader}\nsettings -> transport:{transport} results:{results}\n\n{human_settings}\n'¶- diff --git a/reference/celery.apps.worker.html b/reference/celery.apps.worker.html index de4472b4649..c449337c2a8 100644 --- a/reference/celery.apps.worker.html +++ b/reference/celery.apps.worker.html @@ -86,7 +86,7 @@
Format used to generate bugreport information.
celery.apps.workerclass celery.apps.worker.Worker(hostname=None, purge=False, beat=False, queues=None, include=None, app=None, pidfile=None, autoscale=None, autoreload=False, no_execv=False, **kwargs)¶
- +
- -class WorkController(loglevel=None, hostname=None, ready_callback=<function noop at 0x101b18488>, queues=None, app=None, pidfile=None, **kwargs)¶
+class WorkController(loglevel=None, hostname=None, ready_callback=<function noop at 0x101a9bde8>, queues=None, app=None, pidfile=None, **kwargs)¶Unmanaged worker instance.
+
- @@ -204,6 +204,11 @@
celery.apps.workersend_events = None¶
+
+- +should_use_eventloop()¶
++
- signal_consumer_close()¶
diff --git a/reference/celery.bin.base.html b/reference/celery.bin.base.html index 0eb34832560..616118d44a6 100644 --- a/reference/celery.bin.base.html +++ b/reference/celery.bin.base.html @@ -169,8 +169,7 @@celery.bin.base
- args = ''¶
-Arg list used in help.
-+
- @@ -185,8 +184,7 @@
celery.bin.base
- description = ''¶
-Text to print in –help before option list.
-+
- @@ -206,14 +204,12 @@
celery.bin.base
- enable_config_from_cmdline = False¶
-Enable if the application should support config from the cmdline.
-+
- epilog = None¶
-Text to print at end of –help
-
- @@ -272,17 +268,30 @@
celery.bin.baseargv contains positional arguments.
+
+ +- +leaf = True¶
++
+- +maybe_patch_concurrency(argv, short_opts=None, long_opts=None)¶
++ + +
- namespace = 'celery'¶
-Default configuration namespace.
-+
- +on_concurrency_setup()¶
++
- option_list = ()¶
-List of options (without preload options).
-+preload_options = (<Option at 0x1089dabd8: -A/--app>, <Option at 0x102ab8cb0: -b/--broker>, <Option at 0x1089e0ef0: --loader>, <Option at 0x108d18ef0: --config>)¶ +
- @@ -302,9 +311,8 @@
celery.bin.base
- -preload_options = (<Option at 0x1058cbea8: -A/--app>, <Option at 0x10b323b90: -b/--broker>, <Option at 0x1093cd560: --loader>, <Option at 0x10b380a28: --config>)¶
-List of options to parse before parsing other options.
-+
- @@ -340,12 +348,15 @@
celery.bin.basesetup_app_from_commandline(argv)¶
+
+- +simple_format(s, match=<_sre.SRE_Pattern object at 0x108606be0>, expand='\1', **keys)¶
++
- supports_args = True¶
-If false the parser will raise an exception if positional -args are provided.
-+ +
- @@ -361,7 +372,18 @@
celery.bin.base
- version = '3.1.0a1 (DEVEL)'¶
-Application version.
++
diff --git a/reference/celery.bin.camqadm.html b/reference/celery.bin.camqadm.html index 81e78883ea0..6b68b1f2beb 100644 --- a/reference/celery.bin.camqadm.html +++ b/reference/celery.bin.camqadm.html @@ -134,7 +134,7 @@- +with_pool_option(argv)¶
+Returns tuple of (short_opts, long_opts) if the command +supports a pool argument, and used to monkey patch eventlet/gevent +environments as early as possible.
++
- E.g::
+- has_pool_option = ([‘-P’], [‘–pool’])
+celery.bin.camqadm
- -amqp = {'queue.declare': <celery.bin.camqadm.Spec object at 0x10a216250>, 'queue.purge': <celery.bin.camqadm.Spec object at 0x10a216790>, 'exchange.delete': <celery.bin.camqadm.Spec object at 0x10a6e4f50>, 'basic.publish': <celery.bin.camqadm.Spec object at 0x10a2166d0>, 'basic.ack': <celery.bin.camqadm.Spec object at 0x10a216810>, 'exchange.declare': <celery.bin.camqadm.Spec object at 0x1093e4210>, 'queue.delete': <celery.bin.camqadm.Spec object at 0x10a216990>, 'queue.bind': <celery.bin.camqadm.Spec object at 0x10a2161d0>, 'basic.get': <celery.bin.camqadm.Spec object at 0x10a2167d0>}
+amqp = {'queue.declare': <celery.bin.camqadm.Spec object at 0x10820e250>, 'queue.purge': <celery.bin.camqadm.Spec object at 0x10820ecd0>, 'exchange.delete': <celery.bin.camqadm.Spec object at 0x10820e610>, 'basic.publish': <celery.bin.camqadm.Spec object at 0x10820e950>, 'basic.ack': <celery.bin.camqadm.Spec object at 0x10820e390>, 'exchange.declare': <celery.bin.camqadm.Spec object at 0x1076c7590>, 'queue.delete': <celery.bin.camqadm.Spec object at 0x10820edd0>, 'queue.bind': <celery.bin.camqadm.Spec object at 0x10820e210>, 'basic.get': <celery.bin.camqadm.Spec object at 0x10820ead0>}@@ -226,7 +226,7 @@
celery.bin.camqadm
- -inc_counter = <method-wrapper 'next' of itertools.count object at 0x10b4e6638>¶
+inc_counter = <method-wrapper 'next' of itertools.count object at 0x108d885a8>¶@@ -273,7 +273,7 @@
celery.bin.camqadm
- -prompt_fmt = '%d> '¶
+prompt_fmt = '{self.counter}> '¶@@ -368,11 +368,6 @@
-celery.bin.camqadmcelery.bin.camqadm.main()¶
-
-- -celery.bin.camqadm.say(m, fh=<open file '<stderr>', mode 'w' at 0x100282270>)¶
-celery.bin.celeryclassmethod list_commands(indent=0)¶ +
+
+- +on_concurrency_setup()¶
++
- prog_name = 'celery'¶
@@ -119,11 +124,16 @@celery.bin.celeryremove_options_at_beginning(argv, index=0)¶
+
+- +with_pool_option(argv)¶
+
- -class celery.bin.celery.Command(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.Command(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶- -
-
-- -leaf = True¶
-
- -option_list = (<Option at 0x10b4f63f8: -q/--quiet>, <Option at 0x10b4f6c20: -C/--no-color>)¶
+option_list = (<Option at 0x102f0aa70: -q/--quiet>, <Option at 0x102db39e0: -C/--no-color>)¶@@ -261,11 +266,6 @@
-celery.bin.celeryCommand = 'celery.bin.camqadm:AMQPAdminCommand'¶
-
-- -sortpri = 30¶
-@@ -282,16 +282,11 @@
-celery.bin.celeryCommand = 'celery.bin.celerybeat:BeatCommand'¶
-
-- -sortpri = 20¶
-
- -class celery.bin.celery.call(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.call(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Call a task by name.
Examples:
diff --git a/reference/celery.contrib.rdb.html b/reference/celery.contrib.rdb.html index 6ecf8a7f3d9..bb4068facc3 100644 --- a/reference/celery.contrib.rdb.html +++ b/reference/celery.contrib.rdb.html @@ -114,7 +114,7 @@celery call tasks.add --args='[2, 2]' @@ -304,7 +299,7 @@celery.bin.celery
- -option_list = (<Option at 0x10b4f63f8: -q/--quiet>, <Option at 0x10b4f6c20: -C/--no-color>, <Option at 0x10b63b830: -a/--args>, <Option at 0x10b37ef80: -k/--kwargs>, <Option at 0x10b4e7128: --eta>, <Option at 0x1029a8878: --countdown>, <Option at 0x10b634440: --expires>, <Option at 0x10b6349e0: --serializer>, <Option at 0x10b634bd8: --queue>, <Option at 0x10b638ea8: --exchange>, <Option at 0x10b6380e0: --routing-key>)¶
+option_list = (<Option at 0x102f0aa70: -q/--quiet>, <Option at 0x102db39e0: -C/--no-color>, <Option at 0x102db3488: -a/--args>, <Option at 0x102db3998: -k/--kwargs>, <Option at 0x10926a6c8: --eta>, <Option at 0x10926a638: --countdown>, <Option at 0x10926a3b0: --expires>, <Option at 0x108d91c68: --serializer>, <Option at 0x108ed26c8: --queue>, <Option at 0x108ddf830: --exchange>, <Option at 0x10927d488: --routing-key>)¶@@ -312,21 +307,16 @@
-celery.bin.celeryrun(name, *_, **kw)¶
-
-- -sortpri = 0¶
--
- -class celery.bin.celery.control(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.control(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Workers remote control.
Availability: RabbitMQ (amqp), Redis, and MongoDB transports.
Examples:
@@ -390,11 +380,6 @@celery.bin.celery -
- -sortpri = 0¶
--
- time_limit(method, task_name, soft, hard=None, **kwargs)¶
@@ -431,27 +416,17 @@celery.bin.celeryCommand = 'celery.bin.celeryev:EvCommand'¶
-
-- -sortpri = 10¶
-
- -class celery.bin.celery.help(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.help(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Show help screen and exit.
-
- run(*args, **kwargs)¶
-
-- -sortpri = 0¶
--
- usage(command)¶
@@ -461,7 +436,7 @@celery.bin.celery
- -class celery.bin.celery.inspect(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.inspect(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Inspect the worker at runtime.
Availability: RabbitMQ (amqp), Redis, and MongoDB transports.
Examples:
@@ -484,16 +459,11 @@celery.bin.celeryname = 'inspect'¶
-
-- -sortpri = 0¶
-+
- -class celery.bin.celery.list_(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.list_(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Get info from broker.
Examples:
celery list bindings@@ -514,13 +484,13 @@celery.bin.celeryrun(what=None, *_, **kw)¶ -
-
- +- -sortpri = 0¶
-+
+- +celery.bin.celery.load_extension_commands(namespace='celery.commands')¶
+
- celery.bin.celery.main()¶
@@ -528,7 +498,7 @@celery.bin.celery
- -class celery.bin.celery.migrate(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.migrate(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Migrate tasks from one broker to another.
Examples:
celery migrate redis://localhost amqp://guest@localhost// @@ -550,7 +520,12 @@celery.bin.celery
- -option_list = (<Option at 0x10b4f63f8: -q/--quiet>, <Option at 0x10b4f6c20: -C/--no-color>, <Option at 0x10b6385a8: -n/--limit>, <Option at 0x10b638518: -t/--timeout>, <Option at 0x10b635680: -a/--ack-messages>, <Option at 0x10b635320: -T/--tasks>, <Option at 0x10b635638: -Q/--queues>, <Option at 0x10b635200: -F/--forever>)¶
+option_list = (<Option at 0x102f0aa70: -q/--quiet>, <Option at 0x102db39e0: -C/--no-color>, <Option at 0x10927d6c8: -n/--limit>, <Option at 0x109268680: -t/--timeout>, <Option at 0x109268710: -a/--ack-messages>, <Option at 0x109268b00: -T/--tasks>, <Option at 0x1092685a8: -Q/--queues>, <Option at 0x109260c20: -F/--forever>)¶ + + ++
- +progress_fmt = 'Migrating task {state.count}/{state.strtotal}: {body[task]}[{body[id]}]'¶
@@ -558,16 +533,11 @@
-celery.bin.celeryrun(*args, **kwargs)¶
-
-- -sortpri = 0¶
-
- -class celery.bin.celery.multi(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.multi(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Start multiple worker instances.
-
- @@ -579,49 +549,44 @@
celery.bin.celeryrun_from_argv(prog_name, argv)¶
-
-- -sortpri = 0¶
-
- -class celery.bin.celery.purge(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.purge(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Erase all messages from all known task queues.
WARNING: There is no undo operation for this command.
-
- -class celery.bin.celery.report(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.report(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Shows information useful to include in bugreports.
-
- run(*args, **kwargs)¶
-
-- -sortpri = 0¶
-
- -class celery.bin.celery.result(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.result(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Gives the return value for a given task id.
Examples:
diff --git a/reference/celery.bin.celerybeat.html b/reference/celery.bin.celerybeat.html index 1cf4a0555f7..86c089d5d0d 100644 --- a/reference/celery.bin.celerybeat.html +++ b/reference/celery.bin.celerybeat.html @@ -86,7 +86,7 @@celery result 8f511516-e2f5-4da4-9d2f-0fb83a86e500 @@ -635,7 +600,7 @@celery.bin.celery
- -option_list = (<Option at 0x10b4f63f8: -q/--quiet>, <Option at 0x10b4f6c20: -C/--no-color>, <Option at 0x10b638560: -t/--task>, <Option at 0x10b638a70: --traceback>)¶
+option_list = (<Option at 0x102f0aa70: -q/--quiet>, <Option at 0x102db39e0: -C/--no-color>, <Option at 0x10927dfc8: -t/--task>, <Option at 0x10927ddd0: --traceback>)¶@@ -643,16 +608,11 @@
-celery.bin.celeryrun(task_id, *args, **kwargs)¶
-
-- -sortpri = 0¶
-
- -class celery.bin.celery.shell(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.shell(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Start shell session with convenient access to celery symbols.
The following symbols will be added to the main globals:
@@ -695,7 +655,7 @@celery.bin.celery
- -option_list = (<Option at 0x10b4f63f8: -q/--quiet>, <Option at 0x10b4f6c20: -C/--no-color>, <Option at 0x10b635908: -I/--ipython>, <Option at 0x10b635128: -B/--bpython>, <Option at 0x10b635758: -P/--python>, <Option at 0x10b635b48: -T/--without-tasks>, <Option at 0x10b635cb0: --eventlet>, <Option at 0x10b6351b8: --gevent>)¶
+option_list = (<Option at 0x102f0aa70: -q/--quiet>, <Option at 0x102db39e0: -C/--no-color>, <Option at 0x1092607a0: -I/--ipython>, <Option at 0x109260200: -B/--bpython>, <Option at 0x109260170: -P/--python>, <Option at 0x109289d88: -T/--without-tasks>, <Option at 0x1092895a8: --eventlet>, <Option at 0x109289248: --gevent>)¶@@ -703,20 +663,15 @@
-celery.bin.celeryrun(force_ipython=False, force_bpython=False, force_python=False, without_tasks=False, eventlet=False, gevent=False, **kwargs)¶
-
-- -sortpri = 0¶
-
- -class celery.bin.celery.status(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002821e0>, stderr=<open file '<stderr>', mode 'w' at 0x100282270>, show_reply=True)¶
+class celery.bin.celery.status(app=None, no_color=False, stdout=<open file '<stdout>', mode 'w' at 0x1002811e0>, stderr=<open file '<stderr>', mode 'w' at 0x100281270>, show_reply=True)¶Show list of workers that are online.
- -option_list = (<Option at 0x10b4f63f8: -q/--quiet>, <Option at 0x10b4f6c20: -C/--no-color>, <Option at 0x10b638b00: -t/--timeout>, <Option at 0x10b638c20: -d/--destination>)¶
+option_list = (<Option at 0x102f0aa70: -q/--quiet>, <Option at 0x102db39e0: -C/--no-color>, <Option at 0x10927dcb0: -t/--timeout>, <Option at 0x10927d098: -d/--destination>)¶@@ -724,11 +679,6 @@
-celery.bin.celeryrun(*args, **kwargs)¶
-
-- -sortpri = 0¶
-@@ -749,11 +699,6 @@
-celery.bin.celeryCommand = 'celery.bin.celeryd:WorkerCommand'¶
-
-- -sortpri = 1¶
-celery.bin.celerybeat-s, --schedule¶
Path to the schedule database. Defaults to celerybeat-schedule. The extension ‘.db’ may be appended to the filename. -Default is %(default)s.
+Default is {default}.@@ -120,7 +120,7 @@
diff --git a/reference/celery.contrib.batches.html b/reference/celery.contrib.batches.html index 7c1a52db6a7..de4191ddb08 100644 --- a/reference/celery.contrib.batches.html +++ b/reference/celery.contrib.batches.html @@ -83,7 +83,7 @@celery.bin.celerybeatclass celery.bin.celerybeat.BeatCommand(app=None, get_app=None)¶
- -doc = "\n\nThe :program:`celery beat` command.\n\n.. program:: celery beat\n\n.. seealso::\n\n See :ref:`preload-options` and :ref:`daemon-options`.\n\n.. cmdoption:: --detach\n\n Detach and run in the background as a daemon.\n\n.. cmdoption:: -s, --schedule\n\n Path to the schedule database. Defaults to `celerybeat-schedule`.\n The extension '.db' may be appended to the filename.\n Default is %(default)s.\n\n.. cmdoption:: -S, --scheduler\n\n Scheduler class to use.\n Default is :class:`celery.beat.PersistentScheduler`.\n\n.. cmdoption:: max-interval\n\n Max seconds to sleep between schedule iterations.\n\n.. cmdoption:: -f, --logfile\n\n Path to log file. If no logfile is specified, `stderr` is used.\n\n.. cmdoption:: -l, --loglevel\n\n Logging level, choose between `DEBUG`, `INFO`, `WARNING`,\n `ERROR`, `CRITICAL`, or `FATAL`.\n\n"¶
+doc = "\n\nThe :program:`celery beat` command.\n\n.. program:: celery beat\n\n.. seealso::\n\n See :ref:`preload-options` and :ref:`daemon-options`.\n\n.. cmdoption:: --detach\n\n Detach and run in the background as a daemon.\n\n.. cmdoption:: -s, --schedule\n\n Path to the schedule database. Defaults to `celerybeat-schedule`.\n The extension '.db' may be appended to the filename.\n Default is {default}.\n\n.. cmdoption:: -S, --scheduler\n\n Scheduler class to use.\n Default is :class:`celery.beat.PersistentScheduler`.\n\n.. cmdoption:: max-interval\n\n Max seconds to sleep between schedule iterations.\n\n.. cmdoption:: -f, --logfile\n\n Path to log file. If no logfile is specified, `stderr` is used.\n\n.. cmdoption:: -l, --loglevel\n\n Logging level, choose between `DEBUG`, `INFO`, `WARNING`,\n `ERROR`, `CRITICAL`, or `FATAL`.\n\n"¶diff --git a/reference/celery.bin.celeryd.html b/reference/celery.bin.celeryd.html index 182f6e49f8a..be9290f0c54 100644 --- a/reference/celery.bin.celeryd.html +++ b/reference/celery.bin.celeryd.html @@ -105,7 +105,8 @@
celery.bin.celeryd
- -n, --hostname¶
-Set custom hostname, e.g. ‘foo.example.com’.
+Set custom hostname, e.g. ‘w1.%h’. Expands: %h (hostname), +%n (name) and %d, (domain).
@@ -148,7 +149,7 @@
celery.bin.celeryd -S, --statedb¶
Path to the state database. The extension ‘.db’ may -be appended to the filename. Default: %(default)s
+be appended to the filename. Default: {default}@@ -221,7 +222,7 @@
celery.bin.celerydclass celery.bin.celeryd.WorkerCommand(app=None, get_app=None)¶
- -doc = '\n\nThe :program:`celery worker` command (previously known as ``celeryd``)\n\n.. program:: celery worker\n\n.. seealso::\n\n See :ref:`preload-options`.\n\n.. cmdoption:: -c, --concurrency\n\n Number of child processes processing the queue. The default\n is the number of CPUs available on your system.\n\n.. cmdoption:: -P, --pool\n\n Pool implementation:\n\n processes (default), eventlet, gevent, solo or threads.\n\n.. cmdoption:: -f, --logfile\n\n Path to log file. If no logfile is specified, `stderr` is used.\n\n.. cmdoption:: -l, --loglevel\n\n Logging level, choose between `DEBUG`, `INFO`, `WARNING`,\n `ERROR`, `CRITICAL`, or `FATAL`.\n\n.. cmdoption:: -n, --hostname\n\n Set custom hostname, e.g. \'foo.example.com\'.\n\n.. cmdoption:: -B, --beat\n\n Also run the `celerybeat` periodic task scheduler. Please note that\n there must only be one instance of this service.\n\n.. cmdoption:: -Q, --queues\n\n List of queues to enable for this worker, separated by comma.\n By default all configured queues are enabled.\n Example: `-Q video,image`\n\n.. cmdoption:: -I, --include\n\n Comma separated list of additional modules to import.\n Example: -I foo.tasks,bar.tasks\n\n.. cmdoption:: -s, --schedule\n\n Path to the schedule database if running with the `-B` option.\n Defaults to `celerybeat-schedule`. The extension ".db" may be\n appended to the filename.\n\n.. cmdoption:: --scheduler\n\n Scheduler class to use. Default is celery.beat.PersistentScheduler\n\n.. cmdoption:: -S, --statedb\n\n Path to the state database. The extension \'.db\' may\n be appended to the filename. Default: %(default)s\n\n.. cmdoption:: -E, --events\n\n Send events that can be captured by monitors like :program:`celeryev`,\n `celerymon`, and others.\n\n.. cmdoption:: --purge\n\n Purges all waiting tasks before the daemon is started.\n **WARNING**: This is unrecoverable, and the tasks will be\n deleted from the messaging server.\n\n.. cmdoption:: --time-limit\n\n Enables a hard time limit (in seconds int/float) for tasks.\n\n.. cmdoption:: --soft-time-limit\n\n Enables a soft time limit (in seconds int/float) for tasks.\n\n.. cmdoption:: --maxtasksperchild\n\n Maximum number of tasks a pool worker can execute before it\'s\n terminated and replaced by a new worker.\n\n.. cmdoption:: --pidfile\n\n Optional file used to store the workers pid.\n\n The worker will not start if this file already exists\n and the pid is still alive.\n\n.. cmdoption:: --autoscale\n\n Enable autoscaling by providing\n max_concurrency, min_concurrency. Example::\n\n --autoscale=10,3\n\n (always keep 3 processes, but grow to 10 if necessary)\n\n.. cmdoption:: --autoreload\n\n Enable autoreloading.\n\n.. cmdoption:: --no-execv\n\n Don\'t do execv after multiprocessing child fork.\n\n'¶
+doc = '\n\nThe :program:`celery worker` command (previously known as ``celeryd``)\n\n.. program:: celery worker\n\n.. seealso::\n\n See :ref:`preload-options`.\n\n.. cmdoption:: -c, --concurrency\n\n Number of child processes processing the queue. The default\n is the number of CPUs available on your system.\n\n.. cmdoption:: -P, --pool\n\n Pool implementation:\n\n processes (default), eventlet, gevent, solo or threads.\n\n.. cmdoption:: -f, --logfile\n\n Path to log file. If no logfile is specified, `stderr` is used.\n\n.. cmdoption:: -l, --loglevel\n\n Logging level, choose between `DEBUG`, `INFO`, `WARNING`,\n `ERROR`, `CRITICAL`, or `FATAL`.\n\n.. cmdoption:: -n, --hostname\n\n Set custom hostname, e.g. \'w1.%h\'. Expands: %h (hostname),\n %n (name) and %d, (domain).\n\n.. cmdoption:: -B, --beat\n\n Also run the `celerybeat` periodic task scheduler. Please note that\n there must only be one instance of this service.\n\n.. cmdoption:: -Q, --queues\n\n List of queues to enable for this worker, separated by comma.\n By default all configured queues are enabled.\n Example: `-Q video,image`\n\n.. cmdoption:: -I, --include\n\n Comma separated list of additional modules to import.\n Example: -I foo.tasks,bar.tasks\n\n.. cmdoption:: -s, --schedule\n\n Path to the schedule database if running with the `-B` option.\n Defaults to `celerybeat-schedule`. The extension ".db" may be\n appended to the filename.\n\n.. cmdoption:: --scheduler\n\n Scheduler class to use. Default is celery.beat.PersistentScheduler\n\n.. cmdoption:: -S, --statedb\n\n Path to the state database. The extension \'.db\' may\n be appended to the filename. Default: {default}\n\n.. cmdoption:: -E, --events\n\n Send events that can be captured by monitors like :program:`celeryev`,\n `celerymon`, and others.\n\n.. cmdoption:: --purge\n\n Purges all waiting tasks before the daemon is started.\n **WARNING**: This is unrecoverable, and the tasks will be\n deleted from the messaging server.\n\n.. cmdoption:: --time-limit\n\n Enables a hard time limit (in seconds int/float) for tasks.\n\n.. cmdoption:: --soft-time-limit\n\n Enables a soft time limit (in seconds int/float) for tasks.\n\n.. cmdoption:: --maxtasksperchild\n\n Maximum number of tasks a pool worker can execute before it\'s\n terminated and replaced by a new worker.\n\n.. cmdoption:: --pidfile\n\n Optional file used to store the workers pid.\n\n The worker will not start if this file already exists\n and the pid is still alive.\n\n.. cmdoption:: --autoscale\n\n Enable autoscaling by providing\n max_concurrency, min_concurrency. Example::\n\n --autoscale=10,3\n\n (always keep 3 processes, but grow to 10 if necessary)\n\n.. cmdoption:: --autoreload\n\n Enable autoreloading.\n\n.. cmdoption:: --no-execv\n\n Don\'t do execv after multiprocessing child fork.\n\n'¶@@ -246,7 +247,7 @@
celery.bin.celeryd
- -run(*args, **kwargs)¶
+run(hostname=None, pool_cls=None, loglevel=None, app=None, **kwargs)¶@@ -254,6 +255,11 @@
+celery.bin.celerydsupports_args = False¶
+
+- +with_pool_option(argv)¶
+diff --git a/reference/celery.bin.celeryd_multi.html b/reference/celery.bin.celeryd_multi.html index 8693230491e..6037efbce9d 100644 --- a/reference/celery.bin.celeryd_multi.html +++ b/reference/celery.bin.celeryd_multi.html @@ -291,7 +291,7 @@
Examples
- -waitexec(argv, path='/Users/asksol/.virtualenvs/def/bin/python')¶
+waitexec(argv, path='/Library/Frameworks/Python.framework/Versions/2.7/Resources/Python.app/Contents/MacOS/Python')¶diff --git a/reference/celery.contrib.abortable.html b/reference/celery.contrib.abortable.html index 0cddfe3b040..b112cf53743 100644 --- a/reference/celery.contrib.abortable.html +++ b/reference/celery.contrib.abortable.html @@ -225,7 +225,7 @@
Usage example
- -request_stack = <celery.utils.threads.LocalStack object at 0x1029afef0>¶
+request_stack = <celery.utils.threads.LocalStack object at 0x10994a8d8>¶celery.contrib.batchesfrom collections import Counter count = Counter(request.kwargs['url'] for request in requests) for url, count in count.items(): - print('>>> Clicks: %s -> %s' % (url, count)) + print('>>> Clicks: {0} -> {1}'.format(url, count))
Registering the click is done as follows:
diff --git a/reference/celery.contrib.migrate.html b/reference/celery.contrib.migrate.html index c40fdb70209..a932e6f863c 100644 --- a/reference/celery.contrib.migrate.html +++ b/reference/celery.contrib.migrate.html @@ -86,6 +86,11 @@celery.contrib.migratecount = 0¶
+
+- +filtered = 0¶
++ +
- strtotal¶
@@ -98,19 +103,172 @@celery.contrib.migrate +
- +exception celery.contrib.migrate.StopFiltering¶
++
+- +celery.contrib.migrate.expand_dest(ret, exchange, routing_key)¶
++
- celery.contrib.migrate.filter_callback(callback, tasks)¶
+
+- +celery.contrib.migrate.filter_status(state, body, message, **kwargs)¶
+
- -celery.contrib.migrate.migrate_task(producer, body_, message, queues=None, remove_props=['application_headers', 'content_type', 'content_encoding', 'headers'])¶
+celery.contrib.migrate.migrate_task(producer, body_, message, queues=None)¶+ +
- -celery.contrib.migrate.migrate_tasks(source, dest, limit=None, timeout=1.0, ack_messages=False, app=None, migrate=<function migrate_task at 0x10ba780c8>, tasks=None, queues=None, callback=None, forever=False, **kwargs)¶
+celery.contrib.migrate.migrate_tasks(source, dest, migrate=<function migrate_task at 0x1099f7410>, app=None, queues=None, **kwargs)¶ ++
+ +- +celery.contrib.migrate.move(predicate, connection=None, exchange=None, routing_key=None, source=None, app=None, callback=None, limit=None, transform=None, **kwargs)¶
+Find tasks by filtering them and move the tasks to a new queue.
++
++ + + + + Parameters: + +
+- predicate –
+Filter function used to decide which messages +to move. Must accept the standard signature of (body, message) +used by Kombu consumer callbacks. If the predicate wants the message +to be moved it must return either:
++++
+- a tuple of (exchange, routing_key), or
+- a Queue instance, or
+- any other true value which means the specified +exchange and routing_key arguments will be used.
+- connection – Custom connection to use.
+- source – Optional list of source queues to use instead of the +default (which is the queues in CELERY_QUEUES). +This list can also contain new Queue instances.
+- exchange – Default destination exchange.
+- routing_key – Default destination routing key.
+- limit – Limit number of messages to filter.
+- callback – Callback called after message moved, +with signature (state, body, message).
+- transform – Optional function to transform the return +value (destination) of the filter function.
+Also supports the same keyword arguments as start_filter().
+To demonstrate, the move_task_by_id() operation can be implemented +like this:
+++def is_wanted_task(body, message): + if body['id'] == wanted_id: + return Queue('foo', exchange=Exchange('foo'), + routing_key='foo') + +move(is_wanted_task) +or with a transform:
+++def transform(value): + if isinstance(value, basestring): + return Queue(value, Exchange(value), value) + return value + +move(is_wanted_task, transform=transform) +The predicate may also return a tuple of (exchange, routing_key) +to specify the destination to where the task should be moved, +or a Queue instance. +Any other true value means that the task will be moved to the +default exchange/routing_key.
++
+ +- +celery.contrib.migrate.move_by_idmap(map, **kwargs)¶
+Moves tasks by matching from a task_id: queue mapping, +where queue is a queue to move the task to.
+Example:
+++>>> reroute_idmap({ +... '5bee6e82-f4ac-468e-bd3d-13e8600250bc': Queue(...), +... 'ada8652d-aef3-466b-abd2-becdaf1b82b3': Queue(...), +... '3a2b140d-7db1-41ba-ac90-c36a0ef4ab1f': Queue(...)}, +... queues=['hipri']) ++
+ +- +celery.contrib.migrate.move_by_taskmap(map, **kwargs)¶
+Moves tasks by matching from a task_name: queue mapping, +where queue is the queue to move the task to.
+Example:
+++>>> reroute_idmap({ +... 'tasks.add': Queue(...), +... 'tasks.mul': Queue(...), +... }) ++
+ +- +celery.contrib.migrate.move_task_by_id(task_id, dest, **kwargs)¶
+Find a task by id and move it to another queue.
++
++ + + + + Parameters: + +
+- task_id – Id of task to move.
+- dest – Destination queue.
+Also supports the same keyword arguments as move().
++
+ +- +celery.contrib.migrate.prepare_queues(queues)¶
++
+ +- +celery.contrib.migrate.republish(producer, message, exchange=None, routing_key=None, remove_props=['application_headers', 'content_type', 'content_encoding', 'headers'])¶
++
+ +- +celery.contrib.migrate.start_filter(app, conn, filter, limit=None, timeout=1.0, ack_messages=False, tasks=None, queues=None, callback=None, forever=False, on_declare_queue=None, consume_from=None, state=None, **kwargs)¶
++
+ +- +celery.contrib.migrate.task_id_eq(task_id, body, message)¶
++
- +celery.contrib.migrate.task_id_in(ids, body, message)¶
celery.contrib.rdb
- -class celery.contrib.rdb.Rdb(host='127.0.0.1', port=6899, port_search_limit=100, port_skew=0, out=<open file '<stdout>', mode 'w' at 0x1002821e0>)¶
+class celery.contrib.rdb.Rdb(host='127.0.0.1', port=6899, port_search_limit=100, port_skew=0, out=<open file '<stdout>', mode 'w' at 0x1002811e0>)¶celery.events
-
- -- -consumer(*args, **kwds)¶
-Create event consumer.
-@@ -216,6 +210,11 @@
+celery.eventsitercapture(limit=None, timeout=None, wakeup=True)¶
+
+- +on_consume_ready(connection, channel, consumers, wakeup=True, **kwargs)¶
++
- process(type, event)¶
diff --git a/reference/celery.events.state.html b/reference/celery.events.state.html index 64f61dcffc3..e8e120e5bba 100644 --- a/reference/celery.events.state.html +++ b/reference/celery.events.state.html @@ -333,6 +333,11 @@celery.events.state +
- +status_string¶
+diff --git a/reference/celery.html b/reference/celery.html index 3272a800055..441a45e0cc7 100644 --- a/reference/celery.html +++ b/reference/celery.html @@ -221,6 +221,23 @@
+Application
+
+- +add_defaults(d)¶
+Add default configuration from dict d.
+If the argument is a callable function then it will be regarded +as a promise, and it won’t be loaded until the configuration is +actually needed.
+This method can be compared to:
+++>>> celery.conf.update(d) +with a difference that 1) no copy will be made and 2) the dict will +not be transferred when the worker spawns child processes, so +it’s important that the same configuration happens at import time +when pickle restores the object on the other side.
+
- start(argv=None)¶
@@ -343,8 +360,8 @@Application
-
- -default_connection(connection=None)¶
+- +connection_or_acquire(connection=None)¶
For use within a with-statement to get a connection from the pool if one is not already provided.
Navigation
CELERYD_GROUP="celery" # Name of the projects settings module. -export DJANGO_SETTINGS_MODULE="settings" +export DJANGO_SETTINGS_MODULE="MyProject.settings"@@ -216,7 +216,7 @@Navigation
CELERYD_GROUP="celery" # Name of the projects settings module. -export DJANGO_SETTINGS_MODULE="settings" +export DJANGO_SETTINGS_MODULE="MyProject.settings"diff --git a/tutorials/index.html b/tutorials/index.html index 8dba36e05b7..00579e4c7a0 100644 --- a/tutorials/index.html +++ b/tutorials/index.html @@ -74,7 +74,7 @@Tutorials
- Release: 3.1 Date: July 07, 2012 +diff --git a/tutorials/task-cookbook.html b/tutorials/task-cookbook.html index d19244bc6f6..d4843457028 100644 --- a/tutorials/task-cookbook.html +++ b/tutorials/task-cookbook.html @@ -102,7 +102,7 @@ Date: July 28, 2012 Navigation
# The cache key consists of the task name and the MD5 digest # of the feed URL. feed_url_digest = md5(feed_url).hexdigest() - lock_id = '%s-lock-%s' % (self.name, feed_url_hexdigest) + lock_id = '{0}-lock-{1}'.format(self.name, feed_url_hexdigest) # cache.add fails if if the key already exists acquire_lock = lambda: cache.add(lock_id, 'true', LOCK_EXPIRE) @@ -110,7 +110,7 @@Navigation
# advantage of using add() for atomic locking release_lock = lambda: cache.delete(lock_id) - logger.debug('Importing feed: %s' % feed_url) + logger.debug('Importing feed: %s', feed_url) if acquire_lock(): try: feed = Feed.objects.import_feed(feed_url) @@ -119,7 +119,7 @@Navigation
return feed.url logger.debug( - 'Feed %s is already being imported by another worker' % feed_url) + 'Feed %s is already being imported by another worker', feed_url)Breaking the chain
def hello(to): - return 'hello %s' % to + return 'hello {0}'.format(to) >>> from celery.execute import apply_async @@ -419,7 +419,7 @@Breaking the chainsend_error_emails = True def run(self, to): - return 'hello %s' % to + return 'hello {0}'.format(to) tasks.register(Hello) >>> Hello.delay('world!') @@ -433,7 +433,7 @@
Breaking the chain@task(send_error_emails=True) def hello(x): - return 'hello %s' % to + return 'hello {0}'.format(to)
Abstract Tasksabstract = True def __call__(self, *args, **kwargs): - print('TASK STARTING: %s[%s]' % (self.name, self.request.id)) + print('TASK STARTING: {0.name}[{0.request.id}].format(self)) return self.run(*args, **kwargs)
Example +(2 + 2) + 16 = 20
You can also cause a callback to be applied if task raises an exception (errback), but this behaves differently from a regular callback in that it will be passed the id of the parent task, not the result. @@ -217,8 +217,8 @@
Exampledef error_handler(uuid): result = AsyncResult(uuid) exc = result.get(propagate=False) - print('Task %r raised exception: %r\n%r' % ( - exc, result.traceback)) + print('Task {0} raised exception: {1!r}\n{2!r}'.format( + uuid, exc, result.traceback))
it can be added to the task using the link_error execution diff --git a/userguide/canvas.html b/userguide/canvas.html index fa02556c3fc..9b780e26f7a 100644 --- a/userguide/canvas.html +++ b/userguide/canvas.html @@ -235,8 +235,9 @@
ImmutabilityNew in version 3.0.
Callbacks can be added to any task using the link argument to apply_async:
--+add.apply_async((2, 2), link=other_task.subtask())+add.apply_async((2, 2), link=other_task.subtask()) +The callback will only be applied if the task exited successfully, and it will be applied with the return value of the parent task as argument.
As we mentioned earlier, any arguments you add to subtask, @@ -255,8 +256,8 @@
Immutability
>>> add.apply_async((2, 2), link=add.subtask((8, )))As expected this will first launch one task calculating , then -another task calculating .
+As expected this will first launch one task calculating 2 + 2, then +another task calculating 4 + 8.
@@ -321,8 +322,8 @@The PrimitivesThe primitives are also subtasks themselves, so that they can be combined in any number of ways to compose complex workflows.
Here’s some examples:
-+- Simple chain-+
Simple chain
Here’s a simple chain, the first task executes passing its return value to the next task in the chain, and so on.
@@ -340,7 +341,7 @@The Primitives
+
Immutable subtasks
As we have learned signatures can be partial, so that arguments can be @@ -544,15 +545,17 @@
The Primitives
Since exceptions can only be serialized when pickle is used the error callbacks take the id of the parent task as argument instead:
-from proj.celery import celery +from __future__ import print_function +import os +from proj.celery import celery @celery.task() def log_error(task_id): result = celery.AsyncResult(task_id) result.get(propagate=False) # make sure result written. - with open('/var/errors/%s' % (task_id, )) as fh: - fh.write('--\n\n%s %s %s' % ( - task_id, result.result, result.traceback)) + with open(os.path.join('/var/errors', task_id)) as fh: + print('--\n\n{0} {1} {2}'.format( + task_id, result.result, result.traceback), file=fh)To make it even easier to link tasks together there is @@ -563,12 +566,12 @@
The Primitives# (4 + 4) * 8 * 10 >>> res = chain(add.s(4, 4), mul.s(8), mul.s(10)) -proj.tasks.add(4, 4) | proj.tasks.mul(8) +proj.tasks.add(4, 4) | proj.tasks.mul(8) | proj.tasks.mul(10)
Calling the chain will call the tasks in the current process and return the result of the last task in the chain:
->>> res = chain(add.s(4, 4), mul.s(8), mul.s(10)) +@@ -576,7 +579,7 @@>>> res = chain(add.s(4, 4), mul.s(8), mul.s(10))() >>> res.get() 640The PrimitivesAnd calling apply_async will create a dedicated task so that the act of calling the chain happens in a worker: -
@@ -811,7 +813,7 @@>>> res = chain(add.s(4, 4), mul.s(8), mul.s(10)) +@@ -341,7 +343,7 @@@@ -686,8 +689,8 @@>>> res = chain(add.s(4, 4), mul.s(8), mul.s(10)).apply_async() >>> res.get() 640Group ResultsGroupResult takes a list of -AsyncResult instances and operates on them as if it was a -single task. +AsyncResult instances and operates on them as +if it was a single task.
It supports the following operations:
successful()
@@ -746,7 +749,7 @@Group Results up to a hundred digits. +1 + 1 + 2 + 2 + 3 + 3 ... n + n up to a hundred digits.
First we need two tasks, add() and tsum() (sum() is already a standard function):
-@celery.task() @@ -803,11 +806,11 @@Group Resultsraise unlock_chord.retry(countdown=interval, max_retries=max_retries)
This is used by all result backends except Redis and Memcached, which increment a -counter after each task in the header, then applying the callback when the -counter exceeds the number of tasks in the set. Note: chords do not properly -work with Redis before version 2.2; you will need to upgrade to at least 2.2 to -use them.
+This is used by all result backends except Redis and Memcached, which +increment a counter after each task in the header, then applying the callback +when the counter exceeds the number of tasks in the set. Note: chords do not +properly work with Redis before version 2.2; you will need to upgrade to at +least 2.2 to use them.
The Redis and Memcached approach is a much better solution, but not easily implemented in other backends (suggestions welcome!).
@@ -865,11 +868,9 @@Group Results
Chunks¶
--
+- – Chunking lets you divide an iterable of work into pieces,
-- so that if you have one million objects, you can create -10 tasks with hundred thousand objects each.
-Chunking lets you divide an iterable of work into pieces, so that if +you have one million objects, you can create 10 tasks with hundred +thousand objects each.
Some may worry that chunking your tasks results in a degradation of parallelism, but this is rarely true for a busy cluster and in practice since you are avoiding the overhead of messaging diff --git a/userguide/concurrency/eventlet.html b/userguide/concurrency/eventlet.html index 4f846ac44ff..be8c63eca5b 100644 --- a/userguide/concurrency/eventlet.html +++ b/userguide/concurrency/eventlet.html @@ -104,8 +104,8 @@
Navigation
@@ -311,7 +313,7 @@Enabling Eventlet¶
You can enable the Eventlet pool by using the -P option to -celeryd:
-$ celeryd -P eventlet -c 1000+celery worker: +$ celery worker -P eventlet -c 1000diff --git a/userguide/concurrency/index.html b/userguide/concurrency/index.html index e77923e72cd..b0ec98b66d8 100644 --- a/userguide/concurrency/index.html +++ b/userguide/concurrency/index.html @@ -76,7 +76,7 @@Navigation
- Release: 3.1 Date: July 07, 2012 +diff --git a/userguide/index.html b/userguide/index.html index 17dfd71754b..89e54b3d7c8 100644 --- a/userguide/index.html +++ b/userguide/index.html @@ -74,7 +74,7 @@ Date: July 28, 2012 Navigation
- Release: 3.1 Date: July 07, 2012 +diff --git a/userguide/monitoring.html b/userguide/monitoring.html index ef29ca19098..b07f5492879 100644 --- a/userguide/monitoring.html +++ b/userguide/monitoring.html @@ -79,33 +79,38 @@ Date: July 28, 2012 Navigation
- Specifying destination nodes
-- Django Admin Monitor
-
- Starting the monitor
-- Shutter frequency
-- Using outside of Django
+- Celery Flower: Web interface
-- celery events: Curses Monitor
-- celerymon: Web monitor
+- Django Admin Monitor
-- RabbitMQ
-- Redis
-
- Inspecting queues
+- RabbitMQ
-- Munin
-- Events
-
- Snapshots
-
- Custom Camera
+- Redis
-- Event Reference
-
- Task Events
-- Worker Events
+- Munin
+- Events @@ -220,14 +225,14 @@
Commands -
- inspect enable_events: Enable events
- $ celery inspect enable_events+- control enable_events: Enable events
+ $ celery control enable_events-
- inspect disable_events: Disable events
+- control disable_events: Disable events
- @@ -258,8 +263,38 @@
$ celery inspect disable_eventsCommands +
Celery Flower: Web interface¶
+Celery Flower is a web based, real-time monitor and administration tool.
+++Features¶
++
+- Workers monitoring and management
+- Configuration viewer
+- Worker pool control
+- Broker options viewer
+- Queues management
+- Tasks execution statistics
+- Task viewer
+Screenshot
++ ++More screenshots:
+++Usage¶
+Install Celery Flower:
++$ pip install flower+Launch Celery Flower and open http://localhost:8008 in browser:
++$ celery flower+-Django Admin Monitor¶
+Django Admin Monitor¶
New in version 2.1.
When you add django-celery to your Django project you will @@ -270,7 +305,7 @@
Commands
-Starting the monitor¶
+Starting the monitor¶
The Celery section will already be present in your admin interface, but you won’t see any data appearing until you start the snapshot camera.
The camera takes snapshots of the events your workers sends at regular @@ -279,7 +314,7 @@
Commands
$ python manage.py celerycamIf you haven’t already enabled the sending of events you need to do so:
-@@ -284,7 +286,7 @@$ python manage.py celery inspect enable_events+$ python manage.py celery control enable_events
@@ -297,7 +332,7 @@ Commands -
Shutter frequency¶
+Shutter frequency¶
By default the camera takes a snapshot every second, if this is too frequent or you want to have higher precision, then you can change this using the --frequency argument. This is a float describing how often, in seconds, @@ -317,7 +352,7 @@
Commands -
Using outside of Django¶
+Using outside of Django¶
django-celery also installs the djcelerymon program. This can be used by non-Django users, and runs both a web server and a snapshot camera in the same process.
@@ -368,7 +403,7 @@Commands -
celery events: Curses Monitor¶
+celery events: Curses Monitor¶
New in version 2.0.
celery events is a simple curses monitor displaying @@ -394,7 +429,7 @@
Commands -
celerymon: Web monitor¶
+celerymon: Web monitor¶
celerymon is the ongoing work to create a web monitor. It’s far from complete yet, and does currently only support a JSON API. Help is desperately needed for this project, so if you, @@ -412,7 +447,7 @@
Commands -
RabbitMQ¶
+RabbitMQ¶
To manage a Celery cluster it is important to know how RabbitMQ can be monitored.
RabbitMQ ships with the rabbitmqctl(1) command, @@ -427,7 +462,7 @@
Commandsrabbitmqctl list_queues -p my_vhost ....
-Inspecting queues¶
+Inspecting queues¶
Finding the number of tasks in a queue:
$ rabbitmqctl list_queues name messages messages_ready \ messages_unacknowledged@@ -455,11 +490,11 @@Commands -
Redis¶
+Redis¶
If you’re using Redis as the broker, you can monitor the Celery cluster using the redis-cli(1) command to list lengths of queues.
-Inspecting queues¶
+Inspecting queues¶
Finding the number of tasks in a queue:
@@ -478,7 +513,7 @@$ redis-cli -h HOST -p PORT -n DATABASE_NUMBER llen QUEUE_NAMECommands -
Munin¶
+Munin¶
This is a list of known Munin plug-ins that can be useful when maintaining a Celery cluster.
@@ -502,12 +537,12 @@
Commands -
Events¶
+Events¶
The worker has the ability to send a message whenever some event happens. These events are then captured by tools like celerymon and celery events to monitor the cluster.
-Snapshots¶
+Snapshots¶
New in version 2.1.
Even a single worker can produce a huge amount of events, so storing @@ -525,7 +560,7 @@
Commands
$ celery events -c myapp.Camera --frequency=2.0-Custom Camera¶
+Custom Camera¶
Here is an example camera, dumping the snapshot to screen:
from pprint import pformat @@ -538,10 +573,10 @@Commandsif not state.event_count: # No new events since last snapshot. return - print('Workers: %s' % (pformat(state.workers, indent=4), )) - print('Tasks: %s' % (pformat(state.tasks, indent=4), )) - print('Total: %s events, %s tasks' % ( - state.event_count, state.task_count)) + print('Workers: {0}'.format(pformat(state.workers, indent=4))) + print('Tasks: {0}'.format(pformat(state.tasks, indent=4))) + print('Total: {0.event_count} events, %s {0.task_count}'.format( + state))
See the API reference for celery.events.state to read more @@ -570,12 +605,13 @@
Commands -
Event Reference¶
+Event Reference¶
This list contains the events sent by the worker, and their arguments.
-Task Events¶
+Task Events¶
-
task-sent(uuid, name, args, kwargs, retries, eta, expires, queue)
+- +
task-sent(uuid, name, args, kwargs, retries, eta, expires, +queue, exchange, routing_key)
@@ -260,6 +261,11 @@Sent when a task message is published and the CELERY_SEND_TASK_SENT_EVENT setting is enabled.
@@ -619,7 +655,7 @@Commands -
Worker Events¶
+Worker Events¶
worker-online(hostname, timestamp, freq, sw_ident, sw_ver, sw_sys)
diff --git a/userguide/routing.html b/userguide/routing.html index f641995cb40..0902e586560 100644 --- a/userguide/routing.html +++ b/userguide/routing.html @@ -462,8 +462,8 @@MessagesCELERY_QUEUES = ( Queue('default', default_exchange, routing_key='default'), - Queue('videos', media_exchange', routing_key='media.video') - Queue('images', media_exchange', routing_key='media.image') + Queue('videos', media_exchange, routing_key='media.video') + Queue('images', media_exchange, routing_key='media.image') ) CELERY_DEFAULT_QUEUE = 'default' CELERY_DEFAULT_EXCHANGE = 'default' @@ -540,7 +540,8 @@
Messages
Broadcast¶
Celery can also support broadcast routing. -Here is an example exchange bcast that uses this:
+Here is an example exchange broadcast_tasks that delivers +copies of tasks to all workers connected to it:from kombu.common import Broadcast CELERY_QUEUES = (Broadcast('broadcast_tasks'), ) diff --git a/userguide/signals.html b/userguide/signals.html index 04dac0613b6..036fed72cf0 100644 --- a/userguide/signals.html +++ b/userguide/signals.html @@ -84,29 +84,30 @@Navigation
- Worker Signals
-- Celerybeat Signals
-
- beat_init
-- beat_embedded_init
+- Celerybeat Signals
-- Eventlet Signals
-
- eventlet_pool_started
-- eventlet_pool_preshutdown
-- eventlet_pool_postshutdown
-- eventlet_pool_apply
+- Eventlet Signals
-- Logging Signals @@ -127,7 +128,7 @@
Navigation
@task_sent.connect def task_sent_handler(sender=None, task_id=None, task=None, args=None, kwargs=None, \*\*kwds): - print('Got signal task_sent for task id %s' % (task_id, )) + print('Got signal task_sent for task id {0}'.format(task_id))Some signals also have a sender which you can filter by. For example the @@ -138,7 +139,7 @@
Navigation
@task_sent.connect(task_sent_handler, sender='tasks.add') def task_sent_handler(sender=None, task_id=None, task=None, args=None, kwargs=None, \*\*kwds): - print('Got signal task_sent for task id %s' % (task_id, )) + print('Got signal task_sent for task id {0}'.format(task_id)Task Signals
state
+++Name of the resulting state.
+@@ -347,8 +353,46 @@Task Signals
Worker Signals¶
++celeryd_after_setup¶
+This signal is sent after the worker instance is set up, +but before it calls run. This means that any queues from the -Q +option is enabled, logging has been set up and so on.
+It can be used to e.g. add custom queues that should always be consumed +from, disregarding the -Q option. Here’s an example +that sets up a direct queue for each worker, these queues can then be +used to route a task to any specific worker:
+++from celery.signals import celeryd_after_setup + +@celeryd_after_setup.connect +def setup_direct_queue(sender, instance, **kwargs): + queue_name = '{0}.dq'.format(sender) # sender is the hostname of the worker + instance.app.queues.select_add(queue_name) +Provides arguments:
++
+- +
sender +Hostname of the worker.
+- +
+
+- instance
+- +
This is the celery.apps.worker.Worker instance to be initialized. +Note that only the app and hostname attributes have been +set so far, and the rest of __init__ has not been executed.
+- +
+
+- conf
+- +
The configuration of the current app.
+-celeryd_init¶
+celeryd_init¶
This is the first signal sent when celeryd starts up. The sender is the host name of the worker, so this signal can be used to setup worker specific configuration:
@@ -373,6 +417,9 @@Worker Signals
Provides arguments:
+
sender +Hostname of the worker.
+
- instance
This is the celery.apps.worker.Worker instance to be initialized. @@ -390,56 +437,56 @@
Worker Signals
-worker_process_init¶
+worker_process_init¶
Dispatched by each new pool worker process when it starts.
-Celerybeat Signals¶
+Celerybeat Signals¶
-beat_init¶
+beat_init¶
Dispatched when celerybeat starts (either standalone or embedded). Sender is the celery.beat.Service instance.
-beat_embedded_init¶
+beat_embedded_init¶
Dispatched in addition to the beat_init signal when celerybeat is started as an embedded process. Sender is the celery.beat.Service instance.
-Eventlet Signals¶
+Eventlet Signals¶
-eventlet_pool_started¶
+eventlet_pool_started¶
Sent when the eventlet pool has been started.
Sender is the celery.concurrency.eventlet.TaskPool instance.
-eventlet_pool_preshutdown¶
+eventlet_pool_preshutdown¶
Sent when the worker shutdown, just before the eventlet pool is requested to wait for remaining workers.
Sender is the celery.concurrency.eventlet.TaskPool instance.
-eventlet_pool_postshutdown¶
+eventlet_pool_postshutdown¶
Sent when the pool has been joined and the worker is ready to shutdown.
Sender is the celery.concurrency.eventlet.TaskPool instance.
-eventlet_pool_apply¶
+eventlet_pool_apply¶
Sent whenever a task is applied to the pool.
Sender is the celery.concurrency.eventlet.TaskPool instance.
Provides arguments:
@@ -463,9 +510,9 @@Eventlet Signals -
Logging Signals¶
+Logging Signals¶
-setup_logging¶
+setup_logging¶
Celery won’t configure the loggers if this signal is connected, so you can use this to completely override the logging configuration with your own.
@@ -501,7 +548,7 @@Logging Signals
-after_setup_logger¶
+after_setup_logger¶
Sent after the setup of every global logger (not task loggers). Used to augment logging configuration.
Provides arguments:
@@ -539,7 +586,7 @@Logging Signals
-after_setup_task_logger¶
+after_setup_task_logger¶
Sent after the setup of every single task logger. Used to augment logging configuration.
Provides arguments:
diff --git a/userguide/tasks.html b/userguide/tasks.html index 521573930d8..f58af9af7df 100644 --- a/userguide/tasks.html +++ b/userguide/tasks.html @@ -257,15 +257,17 @@Navigation
delivery_info: Additional message delivery information. This is a mapping containing the exchange and routing key used to deliver this task. Used by e.g. retry() -to resend the task to the same destination queue. +to resend the task to the same destination queue. +Availability of keys in this dict depends on the +message broker used.An example task accessing information in the context is:
@celery.task() def dump_context(x, y): - print('Executing task id %r, args: %r kwargs: %r' % ( - add.request.id, add.request.args, add.request.kwargs)) + print('Executing task id {0.id}, args: {0.args!r} kwargs: {0.kwargs!r}'.format( + add.request))Navigation
@celery.task() def add(x, y): - logger.info('Adding %s + %s' % (x, y)) + logger.info('Adding {0} + {1}'.format(x, y)) return x + yNavigation
try: twitter = Twitter(oauth) twitter.update_status(tweet) - except (Twitter.FailWhaleError, Twitter.LoginError), exc: + except (Twitter.FailWhaleError, Twitter.LoginError) as exc: raise send_twitter_status.retry(exc=exc)Navigation
def add(x, y): try: ... - except Exception, exc: + except Exception as exc: raise add.retry(exc=exc, countdown=60) # override the default and # retry in 1 minuteAbstract classesabstract = True def after_return(self, *args, **kwargs): - print('Task returned: %r' % (self.request, )) + print('Task returned: {0!r}'.format(self.request) @celery.task(base=DebugTask) @@ -1248,11 +1250,11 @@
blog/models.py@celery.task() def spam_filter(comment_id, remote_addr=None): logger = spam_filter.get_logger() - logger.info('Running spam filter for comment %s' % comment_id) + logger.info('Running spam filter for comment %s', comment_id) comment = Comment.objects.get(pk=comment_id) current_domain = Site.objects.get_current().domain - akismet = Akismet(settings.AKISMET_KEY, 'http://%s' % domain) + akismet = Akismet(settings.AKISMET_KEY, 'http://{0}'.format(domain)) if not akismet.verify_key(): raise ImproperlyConfigured('Invalid AKISMET_KEY') diff --git a/userguide/workers.html b/userguide/workers.html index 1c6e035aff7..b2164180c69 100644 --- a/userguide/workers.html +++ b/userguide/workers.html @@ -108,10 +108,27 @@
Navigation
You can also start multiple workers on the same machine. If you do so be sure to give a unique name to each individual worker by specifying a host name with the --hostname|-n argument:
-$ celery worker --loglevel=INFO --concurrency=10 -n worker1.example.com -$ celery worker --loglevel=INFO --concurrency=10 -n worker2.example.com -$ celery worker --loglevel=INFO --concurrency=10 -n worker3.example.com++$ celery worker --loglevel=INFO --concurrency=10 -n worker1.%h +$ celery worker --loglevel=INFO --concurrency=10 -n worker2.%h +$ celery worker --loglevel=INFO --concurrency=10 -n worker3.%hThe hostname argument can expand the following variables:
++++
+- %h: Hostname including domain name.
+- %n: Hostname only.
+- %d: Domain name only.
+E.g. if the current hostname is george.example.com then +these will expand to:
+++
+- worker1.%h -> worker1.george.example.com
+- worker1.%n -> worker1.george
+- worker1.%d -> worker1.example.com
+Stopping the worker¶
diff --git a/whatsnew-3.0.html b/whatsnew-3.0.html index 56cd4116659..01278efa3cc 100644 --- a/whatsnew-3.0.html +++ b/whatsnew-3.0.html @@ -343,20 +343,21 @@Chaining TasksA new special subtask called chain is also included: -
.. code-block:: python - - >>> from celery import chain +++>>> from celery import chain - # (2 + 2) * 8 / 2 - >>> res = chain(add.subtask((2, 2)), - mul.subtask((8, )), - div.subtask((2,))).apply_async() - >>> res.get() == 16 +# (2 + 2) * 8 / 2 +>>> res = chain(add.subtask((2, 2)), + mul.subtask((8, )), + div.subtask((2,))).apply_async() +>>> res.get() == 16 - >>> res.parent.get() == 32 +>>> res.parent.get() == 32 - >>> res.parent.parent.get() == 4+>>> res.parent.parent.get() == 4 +Adds AsyncResult.get_leaf()
@@ -396,7 +397,7 @@Redis: Priority support.
Priorities implemented in this way is not as reliable as priorities on the server side, which is why -nickname the feature “quasi-priorities”; +the feature is nicknamed “quasi-priorities”; Using routing is still the suggested way of ensuring quality of service, as client implemented priorities fall short in a number of ways, e.g. if the worker @@ -424,12 +425,15 @@
group/chord/chain are now subtasks
A new shortcut has been added to tasks:
->>> task.s(arg1, arg2, kw=1) - -as a shortcut to:: - - >>> task.subtask((arg1, arg2), {'kw': 1})++++>>> task.s(arg1, arg2, kw=1) +as a shortcut to:
++>>> task.subtask((arg1, arg2), {'kw': 1}) +Tasks can be chained by using the | operator:
>>> (add.s(2, 2), pow.s(2)).apply_async() @@ -437,15 +441,18 @@group/chord/chain are now subtasks
Subtasks can be “evaluated” using the ~ operator:
->>> ~add.s(2, 2) - 4 - - >>> ~(add.s(2, 2) | pow.s(2)) - -is the same as:: ++++>>> ~add.s(2, 2) +4 - >>> chain(add.s(2, 2), pow.s(2)).apply_async().get()+>>> ~(add.s(2, 2) | pow.s(2)) +is the same as:
++>>> chain(add.s(2, 2), pow.s(2)).apply_async().get() +A new subtask_type key has been added to the subtask dicts
@@ -890,7 +897,7 @@In Other NewsWorker/Celerybeat no longer logs the startup banner.
Previously it would be logged with severity warning, -no it’s only written to stdout.
+now it’s only written to stdout.The contrib/ directory in the distribution has been renamed to @@ -937,7 +944,7 @@
InternalsNow using kombu.utils.encoding instead of -:mod:`celery.utils.encoding. +celery.utils.encoding.
Renamed module celery.routes -> celery.app.routes.