CONTRIBUTORS.txt Changelog LICENSE MANIFEST.in README.rst TODO setup.cfg setup.py celery/__init__.py celery/__main__.py celery/_state.py celery/beat.py celery/bootsteps.py celery/canvas.py celery/datastructures.py celery/exceptions.py celery/five.py celery/local.py celery/platforms.py celery/result.py celery/schedules.py celery/signals.py celery/states.py celery.egg-info/PKG-INFO celery.egg-info/SOURCES.txt celery.egg-info/dependency_links.txt celery.egg-info/entry_points.txt celery.egg-info/not-zip-safe celery.egg-info/requires.txt celery.egg-info/top_level.txt celery/app/__init__.py celery/app/amqp.py celery/app/annotations.py celery/app/base.py celery/app/builtins.py celery/app/control.py celery/app/defaults.py celery/app/log.py celery/app/registry.py celery/app/routes.py celery/app/task.py celery/app/trace.py celery/app/utils.py celery/apps/__init__.py celery/apps/beat.py celery/apps/worker.py celery/backends/__init__.py celery/backends/amqp.py celery/backends/base.py celery/backends/cache.py celery/backends/cassandra.py celery/backends/couchbase.py celery/backends/mongodb.py celery/backends/redis.py celery/backends/rpc.py celery/backends/database/__init__.py celery/backends/database/models.py celery/backends/database/session.py celery/bin/__init__.py celery/bin/amqp.py celery/bin/base.py celery/bin/beat.py celery/bin/celery.py celery/bin/celeryd_detach.py celery/bin/events.py celery/bin/graph.py celery/bin/multi.py celery/bin/worker.py celery/concurrency/__init__.py celery/concurrency/asynpool.py celery/concurrency/base.py celery/concurrency/eventlet.py celery/concurrency/gevent.py celery/concurrency/prefork.py celery/concurrency/solo.py celery/concurrency/threads.py celery/contrib/__init__.py celery/contrib/abortable.py celery/contrib/batches.py celery/contrib/methods.py celery/contrib/migrate.py celery/contrib/rdb.py celery/contrib/sphinx.py celery/events/__init__.py celery/events/cursesmon.py celery/events/dumper.py celery/events/snapshot.py celery/events/state.py celery/fixups/__init__.py celery/fixups/django.py celery/loaders/__init__.py celery/loaders/app.py celery/loaders/base.py celery/loaders/default.py celery/security/__init__.py celery/security/certificate.py celery/security/key.py celery/security/serialization.py celery/security/utils.py celery/task/__init__.py celery/task/base.py celery/task/http.py celery/task/sets.py celery/task/trace.py celery/tests/__init__.py celery/tests/case.py celery/tests/app/__init__.py celery/tests/app/test_amqp.py celery/tests/app/test_annotations.py celery/tests/app/test_app.py celery/tests/app/test_beat.py celery/tests/app/test_builtins.py celery/tests/app/test_celery.py celery/tests/app/test_control.py celery/tests/app/test_defaults.py celery/tests/app/test_exceptions.py celery/tests/app/test_loaders.py celery/tests/app/test_log.py celery/tests/app/test_registry.py celery/tests/app/test_routes.py celery/tests/app/test_schedules.py celery/tests/app/test_utils.py celery/tests/backends/__init__.py celery/tests/backends/test_amqp.py celery/tests/backends/test_backends.py celery/tests/backends/test_base.py celery/tests/backends/test_cache.py celery/tests/backends/test_cassandra.py celery/tests/backends/test_couchbase.py celery/tests/backends/test_database.py celery/tests/backends/test_mongodb.py celery/tests/backends/test_redis.py celery/tests/backends/test_rpc.py celery/tests/bin/__init__.py celery/tests/bin/test_amqp.py celery/tests/bin/test_base.py celery/tests/bin/test_beat.py celery/tests/bin/test_celery.py celery/tests/bin/test_celeryd_detach.py celery/tests/bin/test_celeryevdump.py celery/tests/bin/test_events.py celery/tests/bin/test_multi.py celery/tests/bin/test_worker.py celery/tests/bin/proj/__init__.py celery/tests/bin/proj/app.py celery/tests/compat_modules/__init__.py celery/tests/compat_modules/test_compat.py celery/tests/compat_modules/test_compat_utils.py celery/tests/compat_modules/test_decorators.py celery/tests/compat_modules/test_http.py celery/tests/compat_modules/test_messaging.py celery/tests/compat_modules/test_sets.py celery/tests/concurrency/__init__.py celery/tests/concurrency/test_concurrency.py celery/tests/concurrency/test_eventlet.py celery/tests/concurrency/test_gevent.py celery/tests/concurrency/test_pool.py celery/tests/concurrency/test_prefork.py celery/tests/concurrency/test_solo.py celery/tests/concurrency/test_threads.py celery/tests/contrib/__init__.py celery/tests/contrib/test_abortable.py celery/tests/contrib/test_methods.py celery/tests/contrib/test_migrate.py celery/tests/contrib/test_rdb.py celery/tests/events/__init__.py celery/tests/events/test_cursesmon.py celery/tests/events/test_events.py celery/tests/events/test_snapshot.py celery/tests/events/test_state.py celery/tests/fixups/__init__.py celery/tests/fixups/test_django.py celery/tests/functional/__init__.py celery/tests/functional/case.py celery/tests/functional/tasks.py celery/tests/security/__init__.py celery/tests/security/case.py celery/tests/security/test_certificate.py celery/tests/security/test_key.py celery/tests/security/test_security.py celery/tests/security/test_serialization.py celery/tests/slow/__init__.py celery/tests/tasks/__init__.py celery/tests/tasks/test_canvas.py celery/tests/tasks/test_chord.py celery/tests/tasks/test_context.py celery/tests/tasks/test_result.py celery/tests/tasks/test_states.py celery/tests/tasks/test_tasks.py celery/tests/tasks/test_trace.py celery/tests/utils/__init__.py celery/tests/utils/test_datastructures.py celery/tests/utils/test_dispatcher.py celery/tests/utils/test_encoding.py celery/tests/utils/test_functional.py celery/tests/utils/test_imports.py celery/tests/utils/test_local.py celery/tests/utils/test_mail.py celery/tests/utils/test_pickle.py celery/tests/utils/test_platforms.py celery/tests/utils/test_saferef.py celery/tests/utils/test_serialization.py celery/tests/utils/test_sysinfo.py celery/tests/utils/test_term.py celery/tests/utils/test_text.py celery/tests/utils/test_threads.py celery/tests/utils/test_timer2.py celery/tests/utils/test_timeutils.py celery/tests/utils/test_utils.py celery/tests/worker/__init__.py celery/tests/worker/test_autoreload.py celery/tests/worker/test_autoscale.py celery/tests/worker/test_bootsteps.py celery/tests/worker/test_components.py celery/tests/worker/test_consumer.py celery/tests/worker/test_control.py celery/tests/worker/test_heartbeat.py celery/tests/worker/test_hub.py celery/tests/worker/test_loops.py celery/tests/worker/test_request.py celery/tests/worker/test_revoke.py celery/tests/worker/test_state.py celery/tests/worker/test_strategy.py celery/tests/worker/test_worker.py celery/utils/__init__.py celery/utils/compat.py celery/utils/debug.py celery/utils/encoding.py celery/utils/functional.py celery/utils/imports.py celery/utils/iso8601.py celery/utils/log.py celery/utils/mail.py celery/utils/objects.py celery/utils/serialization.py celery/utils/sysinfo.py celery/utils/term.py celery/utils/text.py celery/utils/threads.py celery/utils/timer2.py celery/utils/timeutils.py celery/utils/dispatch/__init__.py celery/utils/dispatch/saferef.py celery/utils/dispatch/signal.py celery/worker/__init__.py celery/worker/autoreload.py celery/worker/autoscale.py celery/worker/components.py celery/worker/consumer.py celery/worker/control.py celery/worker/heartbeat.py celery/worker/job.py celery/worker/loops.py celery/worker/pidbox.py celery/worker/state.py celery/worker/strategy.py docs/AUTHORS.txt docs/Makefile docs/THANKS docs/changelog.rst docs/community.rst docs/conf.py docs/configuration.rst docs/contributing.rst docs/copyright.rst docs/faq.rst docs/glossary.rst docs/index.rst docs/whatsnew-2.5.rst docs/whatsnew-3.0.rst docs/whatsnew-3.1.rst docs/.static/.keep docs/.templates/page.html docs/.templates/sidebarintro.html docs/.templates/sidebarlogo.html docs/_ext/applyxrefs.py docs/_ext/celerydocs.py docs/_ext/githubsphinx.py docs/_ext/literals_to_xrefs.py docs/_theme/celery/theme.conf docs/_theme/celery/static/celery.css_t docs/django/first-steps-with-django.rst docs/django/index.rst docs/getting-started/first-steps-with-celery.rst docs/getting-started/index.rst docs/getting-started/introduction.rst docs/getting-started/next-steps.rst docs/getting-started/resources.rst docs/getting-started/brokers/beanstalk.rst docs/getting-started/brokers/couchdb.rst docs/getting-started/brokers/django.rst docs/getting-started/brokers/index.rst docs/getting-started/brokers/ironmq.rst docs/getting-started/brokers/mongodb.rst docs/getting-started/brokers/rabbitmq.rst docs/getting-started/brokers/redis.rst docs/getting-started/brokers/sqlalchemy.rst docs/getting-started/brokers/sqs.rst docs/history/changelog-1.0.rst docs/history/changelog-2.0.rst docs/history/changelog-2.1.rst docs/history/changelog-2.2.rst docs/history/changelog-2.3.rst docs/history/changelog-2.4.rst docs/history/changelog-2.5.rst docs/history/changelog-3.0.rst docs/history/index.rst docs/images/celery_128.png docs/images/celery_512.png docs/images/celeryevshotsm.jpg docs/images/dashboard.png docs/images/monitor.png docs/images/result_graph.png docs/images/worker_graph_full.png docs/includes/installation.txt docs/includes/introduction.txt docs/includes/resources.txt docs/internals/app-overview.rst docs/internals/deprecation.rst docs/internals/guide.rst docs/internals/index.rst docs/internals/protocol.rst docs/internals/protov2.rst docs/internals/worker.rst docs/internals/reference/celery._state.rst docs/internals/reference/celery.app.annotations.rst docs/internals/reference/celery.app.routes.rst docs/internals/reference/celery.app.trace.rst docs/internals/reference/celery.backends.amqp.rst docs/internals/reference/celery.backends.base.rst docs/internals/reference/celery.backends.cache.rst docs/internals/reference/celery.backends.cassandra.rst docs/internals/reference/celery.backends.couchbase.rst docs/internals/reference/celery.backends.database.models.rst docs/internals/reference/celery.backends.database.rst docs/internals/reference/celery.backends.database.session.rst docs/internals/reference/celery.backends.mongodb.rst docs/internals/reference/celery.backends.redis.rst docs/internals/reference/celery.backends.rpc.rst docs/internals/reference/celery.backends.rst docs/internals/reference/celery.concurrency.base.rst docs/internals/reference/celery.concurrency.eventlet.rst docs/internals/reference/celery.concurrency.gevent.rst docs/internals/reference/celery.concurrency.prefork.rst docs/internals/reference/celery.concurrency.rst docs/internals/reference/celery.concurrency.solo.rst docs/internals/reference/celery.concurrency.threads.rst docs/internals/reference/celery.datastructures.rst docs/internals/reference/celery.events.cursesmon.rst docs/internals/reference/celery.events.dumper.rst docs/internals/reference/celery.events.snapshot.rst docs/internals/reference/celery.platforms.rst docs/internals/reference/celery.security.certificate.rst docs/internals/reference/celery.security.key.rst docs/internals/reference/celery.security.serialization.rst docs/internals/reference/celery.security.utils.rst docs/internals/reference/celery.utils.compat.rst docs/internals/reference/celery.utils.dispatch.rst docs/internals/reference/celery.utils.dispatch.saferef.rst docs/internals/reference/celery.utils.dispatch.signal.rst docs/internals/reference/celery.utils.functional.rst docs/internals/reference/celery.utils.imports.rst docs/internals/reference/celery.utils.iso8601.rst docs/internals/reference/celery.utils.log.rst docs/internals/reference/celery.utils.objects.rst docs/internals/reference/celery.utils.rst docs/internals/reference/celery.utils.serialization.rst docs/internals/reference/celery.utils.sysinfo.rst docs/internals/reference/celery.utils.term.rst docs/internals/reference/celery.utils.text.rst docs/internals/reference/celery.utils.threads.rst docs/internals/reference/celery.utils.timer2.rst docs/internals/reference/celery.utils.timeutils.rst docs/internals/reference/celery.worker.autoreload.rst docs/internals/reference/celery.worker.autoscale.rst docs/internals/reference/celery.worker.components.rst docs/internals/reference/celery.worker.control.rst docs/internals/reference/celery.worker.heartbeat.rst docs/internals/reference/celery.worker.loops.rst docs/internals/reference/celery.worker.pidbox.rst docs/internals/reference/index.rst docs/reference/celery.app.amqp.rst docs/reference/celery.app.builtins.rst docs/reference/celery.app.control.rst docs/reference/celery.app.defaults.rst docs/reference/celery.app.log.rst docs/reference/celery.app.registry.rst docs/reference/celery.app.rst docs/reference/celery.app.task.rst docs/reference/celery.app.utils.rst docs/reference/celery.apps.beat.rst docs/reference/celery.apps.worker.rst docs/reference/celery.beat.rst docs/reference/celery.bin.amqp.rst docs/reference/celery.bin.base.rst docs/reference/celery.bin.beat.rst docs/reference/celery.bin.celery.rst docs/reference/celery.bin.events.rst docs/reference/celery.bin.graph.rst docs/reference/celery.bin.multi.rst docs/reference/celery.bin.worker.rst docs/reference/celery.bootsteps.rst docs/reference/celery.contrib.abortable.rst docs/reference/celery.contrib.batches.rst docs/reference/celery.contrib.methods.rst docs/reference/celery.contrib.migrate.rst docs/reference/celery.contrib.rdb.rst docs/reference/celery.contrib.sphinx.rst docs/reference/celery.events.rst docs/reference/celery.events.state.rst docs/reference/celery.exceptions.rst docs/reference/celery.loaders.app.rst docs/reference/celery.loaders.base.rst docs/reference/celery.loaders.default.rst docs/reference/celery.loaders.rst docs/reference/celery.result.rst docs/reference/celery.rst docs/reference/celery.schedules.rst docs/reference/celery.security.rst docs/reference/celery.signals.rst docs/reference/celery.states.rst docs/reference/celery.task.http.rst docs/reference/celery.utils.debug.rst docs/reference/celery.utils.mail.rst docs/reference/celery.worker.consumer.rst docs/reference/celery.worker.job.rst docs/reference/celery.worker.rst docs/reference/celery.worker.state.rst docs/reference/celery.worker.strategy.rst docs/reference/index.rst docs/sec/CELERYSA-0001.txt docs/sec/CELERYSA-0002.txt docs/templates/readme.txt docs/tutorials/daemonizing.rst docs/tutorials/debugging.rst docs/tutorials/index.rst docs/tutorials/task-cookbook.rst docs/userguide/application.rst docs/userguide/calling.rst docs/userguide/canvas.rst docs/userguide/extending.rst docs/userguide/index.rst docs/userguide/monitoring.rst docs/userguide/optimizing.rst docs/userguide/periodic-tasks.rst docs/userguide/remote-tasks.rst docs/userguide/routing.rst docs/userguide/security.rst docs/userguide/signals.rst docs/userguide/tasks.rst docs/userguide/workers.rst docs/userguide/concurrency/eventlet.rst docs/userguide/concurrency/index.rst examples/README.rst examples/app/myapp.py examples/celery_http_gateway/README.rst examples/celery_http_gateway/__init__.py examples/celery_http_gateway/manage.py examples/celery_http_gateway/settings.py examples/celery_http_gateway/tasks.py examples/celery_http_gateway/urls.py examples/django/README.rst examples/django/manage.py examples/django/demoapp/__init__.py examples/django/demoapp/models.py examples/django/demoapp/tasks.py examples/django/demoapp/tests.py examples/django/demoapp/views.py examples/django/proj/__init__.py examples/django/proj/celery.py examples/django/proj/settings.py examples/django/proj/urls.py examples/django/proj/wsgi.py examples/eventlet/README.rst examples/eventlet/bulk_task_producer.py examples/eventlet/celeryconfig.py examples/eventlet/tasks.py examples/eventlet/webcrawler.py examples/gevent/celeryconfig.py examples/gevent/tasks.py examples/httpexample/README.rst examples/httpexample/__init__.py examples/httpexample/manage.py examples/httpexample/settings.py examples/httpexample/urls.py examples/httpexample/views.py examples/next-steps/setup.py examples/next-steps/proj/__init__.py examples/next-steps/proj/celery.py examples/next-steps/proj/tasks.py examples/resultgraph/tasks.py examples/tutorial/tasks.py extra/bash-completion/celery.bash extra/centos/celeryd extra/centos/celeryd.sysconfig extra/centos/test_celeryd.sh extra/generic-init.d/celerybeat extra/generic-init.d/celeryd extra/osx/org.celeryq.beat.plist extra/osx/org.celeryq.worker.plist extra/supervisord/celerybeat.conf extra/supervisord/celeryd.conf extra/supervisord/supervisord.conf extra/systemd/celery.conf extra/systemd/celery.service extra/zsh-completion/celery.zsh requirements/default.txt requirements/dev.txt requirements/docs.txt requirements/jython.txt requirements/pkgutils.txt requirements/security.txt requirements/test-ci.txt requirements/test.txt requirements/test3.txt requirements/extras/auth.txt requirements/extras/beanstalk.txt requirements/extras/cassandra.txt requirements/extras/couchbase.txt requirements/extras/couchdb.txt requirements/extras/eventlet.txt requirements/extras/gevent.txt requirements/extras/librabbitmq.txt requirements/extras/memcache.txt requirements/extras/mongodb.txt requirements/extras/msgpack.txt requirements/extras/pyro.txt requirements/extras/redis.txt requirements/extras/slmq.txt requirements/extras/sqlalchemy.txt requirements/extras/sqs.txt requirements/extras/threads.txt requirements/extras/yaml.txt requirements/extras/zeromq.txt requirements/extras/zookeeper.txt