| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306 | .. _deprecation-timeline:============================= Celery Deprecation Timeline=============================.. contents::    :local:.. _deprecations-v4.0:Removals for version 4.0========================- Module ``celery.task.trace`` has been renamed to ``celery.app.trace``  as the ``celery.task`` package is being phased out.  The compat module  will be removed in version 4.0 so please change any import from::    from celery.task.trace import …  to::    from celery.app.trace import …- ``AsyncResult.serializable()`` and ``celery.result.from_serializable``  will be removed.    Use instead::        >>> tup = result.as_tuple()        >>> from celery.result import result_from_tuple        >>> result = result_from_tuple(tup).. _deprecations-v4.0:Removals for version 4.0========================Old Task API------------.. _deprecate-compat-task-modules:Compat Task Modules~~~~~~~~~~~~~~~~~~~- Module ``celery.decorators`` will be removed:  Which means you need to change::    from celery.decorators import taskInto::    from celery import task- Module ``celery.task`` *may* be removed (not decided)    This means you should change::        from celery.task import task    into::        from celery import task    -- and::        from celery.task import Task    into::        from celery import TaskNote that the new :class:`~celery.Task` class no longeruses classmethods for these methods:    - delay    - apply_async    - retry    - apply    - AsyncResult    - subtaskThis also means that you can't call these methods directlyon the class, but have to instantiate the task first::    >>> MyTask.delay()          # NO LONGER WORKS    >>> MyTask().delay()        # WORKS!TaskSet~~~~~~~TaskSet has been renamed to group and TaskSet will be removed in version 4.0.Old::    >>> from celery.task import TaskSet    >>> TaskSet(add.subtask((i, i)) for i in xrange(10)).apply_async()New::    >>> from celery import group    >>> group(add.s(i, i) for i in xrange(10))()Magic keyword arguments~~~~~~~~~~~~~~~~~~~~~~~The magic keyword arguments accepted by tasks will be removedin 4.0, so you should start rewriting any tasksusing the ``celery.decorators`` module and dependingon keyword arguments being passed to the task,for example::    from celery.decorators import task    @task()    def add(x, y, task_id=None):        print("My task id is %r" % (task_id,))should be rewritten into::    from celery import task    @task(bind=True)    def add(self, x, y):        print("My task id is {0.request.id}".format(self))Task attributes---------------The task attributes:- ``queue``- ``exchange``- ``exchange_type``- ``routing_key``- ``delivery_mode``- ``priority``is deprecated and must be set by :setting:`CELERY_ROUTES` instead.:mod:`celery.result`--------------------- ``BaseAsyncResult`` -> ``AsyncResult``.- ``TaskSetResult`` -> ``GroupResult``.- ``TaskSetResult.total`` -> ``len(GroupResult)``- ``TaskSetResult.taskset_id`` -> ``GroupResult.id``Apply to: :class:`~celery.result.AsyncResult`,:class:`~celery.result.EagerResult`::- ``Result.wait()`` -> ``Result.get()``- ``Result.task_id()`` -> ``Result.id``- ``Result.status`` -> ``Result.state``.:mod:`celery.loader`--------------------- ``current_loader()`` -> ``current_app.loader``- ``load_settings()`` -> ``current_app.conf``Task_sent signal----------------The :signal:`task_sent` signal will be removed in version 4.0.Please use the :signal:`before_task_publish` and :signal:`after_task_publush`signals instead.Modules to Remove------------------ ``celery.execute``  This module only contains ``send_task``, which must be replaced with  :attr:`@send_task` instead.- ``celery.decorators``    See :ref:`deprecate-compat-task-modules`- ``celery.log``    Use :attr:`@log` instead.- ``celery.messaging``    Use :attr:`@amqp` instead.- ``celery.registry``    Use :mod:`celery.app.registry` instead.- ``celery.task.control``    Use :attr:`@control` instead.- ``celery.task.schedules``    Use :mod:`celery.schedules` instead.- ``celery.task.chords``    Use :func:`celery.chord` instead.Settings--------``BROKER`` Settings~~~~~~~~~~~~~~~~~~~=====================================  =====================================**Setting name**                       **Replace with**=====================================  =====================================``BROKER_HOST``                        :setting:`BROKER_URL```BROKER_PORT``                        :setting:`BROKER_URL```BROKER_USER``                        :setting:`BROKER_URL```BROKER_PASSWORD``                    :setting:`BROKER_URL```BROKER_VHOST``                       :setting:`BROKER_URL`=====================================  =====================================``REDIS`` Result Backend Settings~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~=====================================  =====================================**Setting name**                       **Replace with**=====================================  =====================================``CELERY_REDIS_HOST``                  :setting:`CELERY_RESULT_BACKEND```CELERY_REDIS_PORT``                  :setting:`CELERY_RESULT_BACKEND```CELERY_REDIS_DB``                    :setting:`CELERY_RESULT_BACKEND```CELERY_REDIS_PASSWORD``              :setting:`CELERY_RESULT_BACKEND```REDIS_HOST``                         :setting:`CELERY_RESULT_BACKEND```REDIS_PORT``                         :setting:`CELERY_RESULT_BACKEND```REDIS_DB``                           :setting:`CELERY_RESULT_BACKEND```REDIS_PASSWORD``                     :setting:`CELERY_RESULT_BACKEND`=====================================  =====================================Logging Settings~~~~~~~~~~~~~~~~=====================================  =====================================**Setting name**                       **Replace with**=====================================  =====================================``CELERYD_LOG_LEVEL``                  :option:`--loglevel```CELERYD_LOG_FILE``                   :option:`--logfile````CELERYBEAT_LOG_LEVEL``               :option:`--loglevel```CELERYBEAT_LOG_FILE``                :option:`--loglevel````CELERYMON_LOG_LEVEL``                :option:`--loglevel```CELERYMON_LOG_FILE``                 :option:`--loglevel``=====================================  =====================================Other Settings~~~~~~~~~~~~~~=====================================  =====================================**Setting name**                       **Replace with**=====================================  =====================================``CELERY_TASK_ERROR_WITELIST``         Annotate ``Task.ErrorMail````CELERY_AMQP_TASK_RESULT_EXPIRES``    :setting:`CELERY_TASK_RESULT_EXPIRES`=====================================  =====================================.. _deprecations-v2.0:Removals for version 2.0========================* The following settings will be removed:=====================================  =====================================**Setting name**                       **Replace with**=====================================  =====================================`CELERY_AMQP_CONSUMER_QUEUES`          `CELERY_QUEUES``CELERY_AMQP_CONSUMER_QUEUES`          `CELERY_QUEUES``CELERY_AMQP_EXCHANGE`                 `CELERY_DEFAULT_EXCHANGE``CELERY_AMQP_EXCHANGE_TYPE`            `CELERY_DEFAULT_AMQP_EXCHANGE_TYPE``CELERY_AMQP_CONSUMER_ROUTING_KEY`     `CELERY_QUEUES``CELERY_AMQP_PUBLISHER_ROUTING_KEY`    `CELERY_DEFAULT_ROUTING_KEY`=====================================  =====================================* :envvar:`CELERY_LOADER` definitions without class name.    E.g. `celery.loaders.default`, needs to include the class name:    `celery.loaders.default.Loader`.* :meth:`TaskSet.run`. Use :meth:`celery.task.base.TaskSet.apply_async`    instead.* The module :mod:`celery.task.rest`; use :mod:`celery.task.http` instead.
 |