| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863 | # -*- coding: utf-8 -*-"""    celery.app.task    ~~~~~~~~~~~~~~~    Task Implementation: Task request context, and the base task class."""from __future__ import absolute_importimport sysfrom billiard.einfo import ExceptionInfofrom celery import current_appfrom celery import statesfrom celery._state import _task_stackfrom celery.canvas import signaturefrom celery.exceptions import Ignore, MaxRetriesExceededError, Reject, Retryfrom celery.five import class_property, itemsfrom celery.result import EagerResultfrom celery.utils import uuid, maybe_reraisefrom celery.utils.functional import mattrgetter, maybe_listfrom celery.utils.imports import instantiatefrom celery.utils.mail import ErrorMailfrom .annotations import resolve_all as resolve_all_annotationsfrom .registry import _unpickle_task_v2from .utils import appstr__all__ = ['Context', 'Task']#: extracts attributes related to publishing a message from an object.extract_exec_options = mattrgetter(    'queue', 'routing_key', 'exchange', 'priority', 'expires',    'serializer', 'delivery_mode', 'compression', 'time_limit',    'soft_time_limit', 'immediate', 'mandatory',  # imm+man is deprecated)# We take __repr__ very seriously around here ;)R_BOUND_TASK = '<class {0.__name__} of {app}{flags}>'R_UNBOUND_TASK = '<unbound {0.__name__}{flags}>'R_SELF_TASK = '<@task {0.name} bound to other {0.__self__}>'R_INSTANCE = '<@task: {0.name} of {app}{flags}>'#: Here for backwards compatibility as tasks no longer use a custom metaclass.TaskType = typedef _strflags(flags, default=''):    if flags:        return ' ({0})'.format(', '.join(flags))    return defaultdef _reprtask(task, fmt=None, flags=None):    flags = list(flags) if flags is not None else []    flags.append('v2 compatible') if task.__v2_compat__ else None    if not fmt:        fmt = R_BOUND_TASK if task._app else R_UNBOUND_TASK    return fmt.format(        task, flags=_strflags(flags),        app=appstr(task._app) if task._app else None,    )class Context(object):    # Default context    logfile = None    loglevel = None    hostname = None    id = None    args = None    kwargs = None    retries = 0    eta = None    expires = None    is_eager = False    headers = None    delivery_info = None    reply_to = None    root_id = None    parent_id = None    correlation_id = None    taskset = None   # compat alias to group    group = None    chord = None    utc = None    called_directly = True    callbacks = None    errbacks = None    timelimit = None    _children = None   # see property    _protected = 0    def __init__(self, *args, **kwargs):        self.update(*args, **kwargs)    def update(self, *args, **kwargs):        return self.__dict__.update(*args, **kwargs)    def clear(self):        return self.__dict__.clear()    def get(self, key, default=None):        return getattr(self, key, default)    def __repr__(self):        return '<Context: {0!r}>'.format(vars(self))    @property    def children(self):        # children must be an empy list for every thread        if self._children is None:            self._children = []        return self._childrenclass Task(object):    """Task base class.    When called tasks apply the :meth:`run` method.  This method must    be defined by all tasks (that is unless the :meth:`__call__` method    is overridden).    """    __trace__ = None    __v2_compat__ = False  # set by old base in celery.task.base    ErrorMail = ErrorMail    MaxRetriesExceededError = MaxRetriesExceededError    #: Execution strategy used, or the qualified name of one.    Strategy = 'celery.worker.strategy:default'    #: This is the instance bound to if the task is a method of a class.    __self__ = None    #: The application instance associated with this task class.    _app = None    #: Name of the task.    name = None    #: If :const:`True` the task is an abstract base class.    abstract = True    #: Maximum number of retries before giving up.  If set to :const:`None`,    #: it will **never** stop retrying.    max_retries = 3    #: Default time in seconds before a retry of the task should be    #: executed.  3 minutes by default.    default_retry_delay = 3 * 60    #: Rate limit for this task type.  Examples: :const:`None` (no rate    #: limit), `'100/s'` (hundred tasks a second), `'100/m'` (hundred tasks    #: a minute),`'100/h'` (hundred tasks an hour)    rate_limit = None    #: If enabled the worker will not store task state and return values    #: for this task.  Defaults to the :setting:`CELERY_IGNORE_RESULT`    #: setting.    ignore_result = None    #: If enabled the request will keep track of subtasks started by    #: this task, and this information will be sent with the result    #: (``result.children``).    trail = True    #: When enabled errors will be stored even if the task is otherwise    #: configured to ignore results.    store_errors_even_if_ignored = None    #: If enabled an email will be sent to :setting:`ADMINS` whenever a task    #: of this type fails.    send_error_emails = None    #: The name of a serializer that are registered with    #: :mod:`kombu.serialization.registry`.  Default is `'pickle'`.    serializer = None    #: Hard time limit.    #: Defaults to the :setting:`CELERYD_TASK_TIME_LIMIT` setting.    time_limit = None    #: Soft time limit.    #: Defaults to the :setting:`CELERYD_TASK_SOFT_TIME_LIMIT` setting.    soft_time_limit = None    #: The result store backend used for this task.    backend = None    #: If disabled this task won't be registered automatically.    autoregister = True    #: If enabled the task will report its status as 'started' when the task    #: is executed by a worker.  Disabled by default 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 application default can be overridden using the    #: :setting:`CELERY_TRACK_STARTED` setting.    track_started = None    #: When enabled messages for this task will be acknowledged **after**    #: the task has been executed, and not *just before* which is the    #: default behavior.    #:    #: Please note that this means the task may be executed twice if the    #: worker crashes mid execution (which may be acceptable for some    #: applications).    #:    #: The application default can be overridden with the    #: :setting:`CELERY_ACKS_LATE` setting.    acks_late = None    #: Tuple of expected exceptions.    #:    #: These are errors that are expected in normal operation    #: and that should not be regarded as a real error by the worker.    #: Currently this means that the state will be updated to an error    #: state, but the worker will not log the event as an error.    throws = ()    #: Default task expiry time.    expires = None    #: Some may expect a request to exist even if the task has not been    #: called.  This should probably be deprecated.    _default_request = None    _exec_options = None    __bound__ = False    from_config = (        ('send_error_emails', 'CELERY_SEND_TASK_ERROR_EMAILS'),        ('serializer', 'CELERY_TASK_SERIALIZER'),        ('rate_limit', 'CELERY_DEFAULT_RATE_LIMIT'),        ('track_started', 'CELERY_TRACK_STARTED'),        ('acks_late', 'CELERY_ACKS_LATE'),        ('ignore_result', 'CELERY_IGNORE_RESULT'),        ('store_errors_even_if_ignored',            'CELERY_STORE_ERRORS_EVEN_IF_IGNORED'),    )    #: ignored    accept_magic_kwargs = False    _backend = None  # set by backend property.    __bound__ = False    # - Tasks are lazily bound, so that configuration is not set    # - until the task is actually used    @classmethod    def bind(self, app):        was_bound, self.__bound__ = self.__bound__, True        self._app = app        conf = app.conf        self._exec_options = None  # clear option cache        for attr_name, config_name in self.from_config:            if getattr(self, attr_name, None) is None:                setattr(self, attr_name, conf[config_name])        # decorate with annotations from config.        if not was_bound:            self.annotate()            from celery.utils.threads import LocalStack            self.request_stack = LocalStack()        # PeriodicTask uses this to add itself to the PeriodicTask schedule.        self.on_bound(app)        return app    @classmethod    def on_bound(self, app):        """This method can be defined to do additional actions when the        task class is bound to an app."""        pass    @classmethod    def _get_app(self):        if self._app is None:            self._app = current_app        if not self.__bound__:            # The app property's __set__  method is not called            # if Task.app is set (on the class), so must bind on use.            self.bind(self._app)        return self._app    app = class_property(_get_app, bind)    @classmethod    def annotate(self):        for d in resolve_all_annotations(self.app.annotations, self):            for key, value in items(d):                if key.startswith('@'):                    self.add_around(key[1:], value)                else:                    setattr(self, key, value)    @classmethod    def add_around(self, attr, around):        orig = getattr(self, attr)        if getattr(orig, '__wrapped__', None):            orig = orig.__wrapped__        meth = around(orig)        meth.__wrapped__ = orig        setattr(self, attr, meth)    def __call__(self, *args, **kwargs):        _task_stack.push(self)        self.push_request()        try:            # add self if this is a bound task            if self.__self__ is not None:                return self.run(self.__self__, *args, **kwargs)            return self.run(*args, **kwargs)        finally:            self.pop_request()            _task_stack.pop()    def __reduce__(self):        # - tasks are pickled into the name of the task only, and the reciever        # - simply grabs it from the local registry.        # - in later versions the module of the task is also included,        # - and the receiving side tries to import that module so that        # - it will work even if the task has not been registered.        mod = type(self).__module__        mod = mod if mod and mod in sys.modules else None        return (_unpickle_task_v2, (self.name, mod), None)    def run(self, *args, **kwargs):        """The body of the task executed by workers."""        raise NotImplementedError('Tasks must define the run method.')    def start_strategy(self, app, consumer, **kwargs):        return instantiate(self.Strategy, self, app, consumer, **kwargs)    def delay(self, *args, **kwargs):        """Star argument version of :meth:`apply_async`.        Does not support the extra options enabled by :meth:`apply_async`.        :param \*args: positional arguments passed on to the task.        :param \*\*kwargs: keyword arguments passed on to the task.        :returns :class:`celery.result.AsyncResult`:        """        return self.apply_async(args, kwargs)    def apply_async(self, args=None, kwargs=None, task_id=None, producer=None,                    link=None, link_error=None, **options):        """Apply tasks asynchronously by sending a message.        :keyword args: The positional arguments to pass on to the                       task (a :class:`list` or :class:`tuple`).        :keyword kwargs: The keyword arguments to pass on to the                         task (a :class:`dict`)        :keyword countdown: Number of seconds into the future that the                            task should execute. Defaults to immediate                            execution.        :keyword eta: A :class:`~datetime.datetime` object describing                      the absolute time and date of when the task should                      be executed.  May not be specified if `countdown`                      is also supplied.        :keyword expires: Either a :class:`int`, describing the number of                          seconds, or a :class:`~datetime.datetime` object                          that describes the absolute time and date of when                          the task should expire.  The task will not be                          executed after the expiration time.        :keyword connection: Re-use existing broker connection instead                             of establishing a new one.        :keyword retry: If enabled sending of the task message will be retried                        in the event of connection loss or failure.  Default                        is taken from the :setting:`CELERY_TASK_PUBLISH_RETRY`                        setting.  Note you need to handle the                        producer/connection manually for this to work.        :keyword retry_policy:  Override the retry policy used.  See the                                :setting:`CELERY_TASK_PUBLISH_RETRY` setting.        :keyword routing_key: Custom routing key used to route the task to a                              worker server. If in combination with a                              ``queue`` argument only used to specify custom                              routing keys to topic exchanges.        :keyword queue: The queue to route the task to.  This must be a key                        present in :setting:`CELERY_QUEUES`, or                        :setting:`CELERY_CREATE_MISSING_QUEUES` must be                        enabled.  See :ref:`guide-routing` for more                        information.        :keyword exchange: Named custom exchange to send the task to.                           Usually not used in combination with the ``queue``                           argument.        :keyword priority: The task priority, a number between 0 and 9.                           Defaults to the :attr:`priority` attribute.        :keyword serializer: A string identifying the default                             serialization method to use.  Can be `pickle`,                             `json`, `yaml`, `msgpack` or any custom                             serialization method that has been registered                             with :mod:`kombu.serialization.registry`.                             Defaults to the :attr:`serializer` attribute.        :keyword compression: A string identifying the compression method                              to use.  Can be one of ``zlib``, ``bzip2``,                              or any custom compression methods registered with                              :func:`kombu.compression.register`. Defaults to                              the :setting:`CELERY_MESSAGE_COMPRESSION`                              setting.        :keyword link: A single, or a list of tasks to apply if the                       task exits successfully.        :keyword link_error: A single, or a list of tasks to apply                      if an error occurs while executing the task.        :keyword producer: :class:~@kombu.Producer` instance to use.        :keyword add_to_parent: If set to True (default) and the task            is applied while executing another task, then the result            will be appended to the parent tasks ``request.children``            attribute.  Trailing can also be disabled by default using the            :attr:`trail` attribute        :keyword publisher: Deprecated alias to ``producer``.        Also supports all keyword arguments supported by        :meth:`kombu.Producer.publish`.        .. note::            If the :setting:`CELERY_ALWAYS_EAGER` setting is set, it will            be replaced by a local :func:`apply` call instead.        """        app = self._get_app()        if app.conf.CELERY_ALWAYS_EAGER:            return self.apply(args, kwargs, task_id=task_id or uuid(),                              link=link, link_error=link_error, **options)        # add 'self' if this is a "task_method".        if self.__self__ is not None:            args = args if isinstance(args, tuple) else tuple(args or ())            args = (self.__self__, ) + args        return app.send_task(            self.name, args, kwargs, task_id=task_id, producer=producer,            link=link, link_error=link_error, result_cls=self.AsyncResult,            **dict(self._get_exec_options(), **options)        )    def signature_from_request(self, request=None, args=None, kwargs=None,                               queue=None, **extra_options):        request = self.request if request is None else request        args = request.args if args is None else args        kwargs = request.kwargs if kwargs is None else kwargs        limit_hard, limit_soft = request.timelimit or (None, None)        options = {            'task_id': request.id,            'link': request.callbacks,            'link_error': request.errbacks,            'group_id': request.group,            'chord': request.chord,            'soft_time_limit': limit_soft,            'time_limit': limit_hard,            'reply_to': request.reply_to,        }        options.update(            {'queue': queue} if queue else (request.delivery_info or {})        )        return self.signature(            args, kwargs, options, type=self, **extra_options        )    subtask_from_request = signature_from_request    def retry(self, args=None, kwargs=None, exc=None, throw=True,              eta=None, countdown=None, max_retries=None, **options):        """Retry the task.        :param args: Positional arguments to retry with.        :param kwargs: Keyword arguments to retry with.        :keyword exc: Custom exception to report when the max restart            limit has been exceeded (default:            :exc:`~@MaxRetriesExceededError`).            If this argument is set and retry is called while            an exception was raised (``sys.exc_info()`` is set)            it will attempt to reraise the current exception.            If no exception was raised it will raise the ``exc``            argument provided.        :keyword countdown: Time in seconds to delay the retry for.        :keyword eta: Explicit time and date to run the retry at                      (must be a :class:`~datetime.datetime` instance).        :keyword max_retries: If set, overrides the default retry limit.        :keyword time_limit: If set, overrides the default time limit.        :keyword soft_time_limit: If set, overrides the default soft                                  time limit.        :keyword \*\*options: Any extra options to pass on to                              meth:`apply_async`.        :keyword throw: If this is :const:`False`, do not raise the                        :exc:`~@Retry` exception,                        that tells the worker to mark the task as being                        retried.  Note that this means the task will be                        marked as failed if the task raises an exception,                        or successful if it returns.        :raises celery.exceptions.Retry: To tell the worker that            the task has been re-sent for retry. This always happens,            unless the `throw` keyword argument has been explicitly set            to :const:`False`, and is considered normal operation.        **Example**        .. code-block:: python            >>> from imaginary_twitter_lib import Twitter            >>> from proj.celery import app            >>> @app.task()            ... def tweet(auth, message):            ...     twitter = Twitter(oauth=auth)            ...     try:            ...         twitter.post_status_update(message)            ...     except twitter.FailWhale as exc:            ...         # Retry in 5 minutes.            ...         raise tweet.retry(countdown=60 * 5, exc=exc)        Although the task will never return above as `retry` raises an        exception to notify the worker, we use `raise` in front of the retry        to convey that the rest of the block will not be executed.        """        request = self.request        retries = request.retries + 1        max_retries = self.max_retries if max_retries is None else max_retries        # Not in worker or emulated by (apply/always_eager),        # so just raise the original exception.        if request.called_directly:            maybe_reraise()  # raise orig stack if PyErr_Occurred            raise exc or Retry('Task can be retried', None)        if not eta and countdown is None:            countdown = self.default_retry_delay        is_eager = request.is_eager        S = self.signature_from_request(            request, args, kwargs,            countdown=countdown, eta=eta, retries=retries,            **options        )        if max_retries is not None and retries > max_retries:            if exc:                # first try to reraise the original exception                maybe_reraise()                # or if not in an except block then raise the custom exc.                raise exc()            raise self.MaxRetriesExceededError(                "Can't retry {0}[{1}] args:{2} kwargs:{3}".format(                    self.name, request.id, S.args, S.kwargs))        ret = Retry(exc=exc, when=eta or countdown)        if is_eager:            # if task was executed eagerly using apply(),            # then the retry must also be executed eagerly.            S.apply().get()            return ret        try:            S.apply_async()        except Exception as exc:            raise Reject(exc, requeue=False)        if throw:            raise ret        return ret    def replace(self, sig):        request = self.request        sig.set_immutable(True)        chord_id, request.chord = request.chord, None        group_id, request.group = request.group, None        callbacks, request.callbacks = request.callbacks, [sig]        if group_id or chord_id:            sig.set(group=group_id, chord=chord_id)        sig |= callbacks[0]        return sig    def apply(self, args=None, kwargs=None,              link=None, link_error=None, **options):        """Execute this task locally, by blocking until the task returns.        :param args: positional arguments passed on to the task.        :param kwargs: keyword arguments passed on to the task.        :keyword throw: Re-raise task exceptions.  Defaults to                        the :setting:`CELERY_EAGER_PROPAGATES_EXCEPTIONS`                        setting.        :rtype :class:`celery.result.EagerResult`:        """        # trace imports Task, so need to import inline.        from celery.app.trace import build_tracer        app = self._get_app()        args = args or ()        # add 'self' if this is a bound method.        if self.__self__ is not None:            args = (self.__self__, ) + tuple(args)        kwargs = kwargs or {}        task_id = options.get('task_id') or uuid()        retries = options.get('retries', 0)        throw = app.either('CELERY_EAGER_PROPAGATES_EXCEPTIONS',                           options.pop('throw', None))        # Make sure we get the task instance, not class.        task = app._tasks[self.name]        request = {'id': task_id,                   'retries': retries,                   'is_eager': True,                   'logfile': options.get('logfile'),                   'loglevel': options.get('loglevel', 0),                   'callbacks': maybe_list(link),                   'errbacks': maybe_list(link_error),                   'headers': options.get('headers'),                   'delivery_info': {'is_eager': True}}        tb = None        tracer = build_tracer(            task.name, task, eager=True,            propagate=throw, app=self._get_app(),        )        ret = tracer(task_id, args, kwargs, request)        retval = ret.retval        if isinstance(retval, ExceptionInfo):            retval, tb = retval.exception, retval.traceback        state = states.SUCCESS if ret.info is None else ret.info.state        return EagerResult(task_id, retval, state, traceback=tb)    def AsyncResult(self, task_id, **kwargs):        """Get AsyncResult instance for this kind of task.        :param task_id: Task id to get result for.        """        return self._get_app().AsyncResult(task_id, backend=self.backend,                                           task_name=self.name, **kwargs)    def signature(self, args=None, *starargs, **starkwargs):        """Return :class:`~celery.signature` object for        this task, wrapping arguments and execution options        for a single task invocation."""        starkwargs.setdefault('app', self.app)        return signature(self, args, *starargs, **starkwargs)    subtask = signature    def s(self, *args, **kwargs):        """``.s(*a, **k) -> .signature(a, k)``"""        return self.signature(args, kwargs)    def si(self, *args, **kwargs):        """``.si(*a, **k) -> .signature(a, k, immutable=True)``"""        return self.signature(args, kwargs, immutable=True)    def chunks(self, it, n):        """Creates a :class:`~celery.canvas.chunks` task for this task."""        from celery import chunks        return chunks(self.s(), it, n, app=self.app)    def map(self, it):        """Creates a :class:`~celery.canvas.xmap` task from ``it``."""        from celery import xmap        return xmap(self.s(), it, app=self.app)    def starmap(self, it):        """Creates a :class:`~celery.canvas.xstarmap` task from ``it``."""        from celery import xstarmap        return xstarmap(self.s(), it, app=self.app)    def send_event(self, type_, **fields):        req = self.request        with self.app.events.default_dispatcher(hostname=req.hostname) as d:            return d.send(type_, uuid=req.id, **fields)    def replace_in_chord(self, sig):        sig.freeze(self.request.id,                   group_id=self.request.group,                   chord=self.request.chord,                   root_id=self.request.root_id)        sig.delay()        raise Ignore('Chord member replaced by new task')    def add_to_chord(self, sig, lazy=False):        """Add signature to the chord the current task is a member of.        :param sig: Signature to extend chord with.        :param lazy: If enabled the new task will not actually be called,                      and ``sig.delay()`` must be called manually.        Currently only supported by the Redis result backend when        ``?new_join=1`` is enabled.        """        if not self.request.chord:            raise ValueError('Current task is not member of any chord')        result = sig.freeze(group_id=self.request.group,                            chord=self.request.chord,                            root_id=self.request.root_id)        self.backend.add_to_chord(self.request.group, result)        return sig.delay() if not lazy else sig    def update_state(self, task_id=None, state=None, meta=None):        """Update task state.        :keyword task_id: Id of the task to update, defaults to the                          id of the current task        :keyword state: New state (:class:`str`).        :keyword meta: State metadata (:class:`dict`).        """        if task_id is None:            task_id = self.request.id        self.backend.store_result(task_id, meta, state)    def on_success(self, retval, task_id, args, kwargs):        """Success handler.        Run by the worker if the task executes successfully.        :param retval: The return value of the task.        :param task_id: Unique id of the executed task.        :param args: Original arguments for the executed task.        :param kwargs: Original keyword arguments for the executed task.        The return value of this handler is ignored.        """        pass    def on_retry(self, exc, task_id, args, kwargs, einfo):        """Retry handler.        This is run by the worker when the task is to be retried.        :param exc: The exception sent to :meth:`retry`.        :param task_id: Unique id of the retried task.        :param args: Original arguments for the retried task.        :param kwargs: Original keyword arguments for the retried task.        :keyword einfo: :class:`~billiard.einfo.ExceptionInfo`                        instance, containing the traceback.        The return value of this handler is ignored.        """        pass    def on_failure(self, exc, task_id, args, kwargs, einfo):        """Error handler.        This is run by the worker when the task fails.        :param exc: The exception raised by the task.        :param task_id: Unique id of the failed task.        :param args: Original arguments for the task that failed.        :param kwargs: Original keyword arguments for the task                       that failed.        :keyword einfo: :class:`~billiard.einfo.ExceptionInfo`                        instance, containing the traceback.        The return value of this handler is ignored.        """        pass    def after_return(self, status, retval, task_id, args, kwargs, einfo):        """Handler called after the task returns.        :param status: Current task state.        :param retval: Task return value/exception.        :param task_id: Unique id of the task.        :param args: Original arguments for the task that failed.        :param kwargs: Original keyword arguments for the task                       that failed.        :keyword einfo: :class:`~billiard.einfo.ExceptionInfo`                        instance, containing the traceback (if any).        The return value of this handler is ignored.        """        pass    def send_error_email(self, context, exc, **kwargs):        if self.send_error_emails and \                not getattr(self, 'disable_error_emails', None):            self.ErrorMail(self, **kwargs).send(context, exc)    def add_trail(self, result):        if self.trail:            self.request.children.append(result)        return result    def push_request(self, *args, **kwargs):        self.request_stack.push(Context(*args, **kwargs))    def pop_request(self):        self.request_stack.pop()    def __repr__(self):        """`repr(task)`"""        return _reprtask(self, R_SELF_TASK if self.__self__ else R_INSTANCE)    def _get_request(self):        """Get current request object."""        req = self.request_stack.top        if req is None:            # task was not called, but some may still expect a request            # to be there, perhaps that should be deprecated.            if self._default_request is None:                self._default_request = Context()            return self._default_request        return req    request = property(_get_request)    def _get_exec_options(self):        if self._exec_options is None:            self._exec_options = extract_exec_options(self)        return self._exec_options    @property    def backend(self):        backend = self._backend        if backend is None:            return self.app.backend        return backend    @backend.setter    def backend(self, value):  # noqa        self._backend = value    @property    def __name__(self):        return self.__class__.__name__BaseTask = Task  # compat alias
 |