a
    xd                     @   sh  d Z ddlZddlZddlmZ ddlmZ ddlmZ ddl	m
Z
mZmZ ddlmZmZ dd	lmZmZ dd
lmZ ddlmZmZmZ ddlmZmZ ddlmZ zddlZW n ey   dZY n0 dZ dZ!dd Z"edd Z#edd Z$G dd dZ%e
j&G dd de%Z'e
j&G dd de%Z(e
j&G dd de(Z)e
j&G dd de'Z*d"d d!Z+dS )#z3Task results/state and results for groups of tasks.    N)deque)contextmanager)cached_property)Thenablebarrierpromise   )current_appstates)_set_task_join_will_blocktask_join_will_block)app_or_default)ImproperlyConfiguredIncompleteStreamTimeoutError)DependencyGraphGraphFormatter)parse_iso8601)
ResultBaseAsyncResult	ResultSetGroupResultEagerResultresult_from_tuplez|Never call result.get() within a task!
See http://docs.celeryq.org/en/latest/userguide/tasks.html#task-synchronous-subtasks
c                   C   s   t  rttd S N)r   RuntimeErrorE_WOULDBLOCK r   r   E/var/www/html/Ranjet/env/lib/python3.9/site-packages/celery/result.pyassert_will_not_block#   s    r   c                  c   s0   t  } td zd V  W t|  n
t|  0 d S NFr   r   Zreset_valuer   r   r   allow_join_result(   s
    r#   c                  c   s0   t  } td zd V  W t|  n
t|  0 d S NTr!   r"   r   r   r   denied_join_result2   s
    r%   c                   @   s   e Zd ZdZdZdS )r   zBase class for results.N)__name__
__module____qualname____doc__parentr   r   r   r   r   <   s   r   c                   @   s2  e Zd ZdZdZeZdZdZdhddZe	dd Z
e
jdd Z
did	d
Zdd Zdd Zdd Zdd ZdjddZdddddddddejejfddZeZdd Zdd ZdkddZdd  Zdld!d"Zd#d$ Zd%d& Zd'd( Zd)d* Zdmd+d,Z e Z!d-d. Z"dnd/d0Z#d1d2 Z$d3d4 Z%d5d6 Z&d7d8 Z'd9d: Z(d;d< Z)d=d> Z*d?d@ Z+dAdB Z,e-dCdD Z.e	dEdF Z/e	dGdH Z0dIdJ Z1dKdL Z2dMdN Z3dOdP Z4e	dQdR Z5e5Z6e	dSdT Z7e	dUdV Z8e8Z9e	dWdX Z:e:jdYdX Z:e	dZd[ Z;e	d\d] Z<e	d^d_ Z=e	d`da Z>e	dbdc Z?e	ddde Z@e	dfdg ZAdS )or   zxQuery task state.

    Arguments:
        id (str): See :attr:`id`.
        backend (Backend): See :attr:`backend`.
    Nc                 C   sd   |d u rt dt| t|p$| j| _|| _|p:| jj| _|| _t| jdd| _	d | _
d| _d S )Nz#AsyncResult requires valid id, not TweakF)
ValueErrortyper   appidbackendr*   r   _on_fulfilledon_ready_cache_ignored)selfr0   r1   Z	task_namer/   r*   r   r   r   __init__W   s    zAsyncResult.__init__c                 C   s   t | dr| jS dS )z+If True, task result retrieval is disabled.r5   F)hasattrr5   r6   r   r   r   ignorede   s    
zAsyncResult.ignoredc                 C   s
   || _ dS )z%Enable/disable task result retrieval.N)r5   )r6   valuer   r   r   r:   l   s    Fc                 C   s   | j j| |d | j||S )Nr+   )r1   add_pending_resultr3   thenr6   callbackZon_errorr,   r   r   r   r=   q   s    zAsyncResult.thenc                 C   s   | j |  |S r   r1   remove_pending_resultr6   resultr   r   r   r2   u   s    zAsyncResult._on_fulfilledc                 C   s   | j }| j|o| fd fS r   )r*   r0   as_tuple)r6   r*   r   r   r   rD   y   s    zAsyncResult.as_tuplec                 C   s0   g }| j }|| j |dur,||  |S )zReturn as a list of task IDs.N)r*   appendr0   extendas_list)r6   resultsr*   r   r   r   rG   }   s    zAsyncResult.as_listc                 C   s(   d| _ | jr| j  | j| j dS )z/Forget the result of this task and its parents.N)r4   r*   forgetr1   r0   r9   r   r   r   rI      s    
zAsyncResult.forgetc                 C   s    | j jj| j|||||d dS )a  Send revoke signal to all workers.

        Any worker receiving the task, or having reserved the
        task, *must* ignore it.

        Arguments:
            terminate (bool): Also terminate the process currently working
                on the task (if any).
            signal (str): Name of signal to send to process if terminate.
                Default is TERM.
            wait (bool): Wait for replies from workers.
                The ``timeout`` argument specifies the seconds to wait.
                Disabled by default.
            timeout (float): Time in seconds to wait for replies when
                ``wait`` is enabled.
        )
connection	terminatesignalreplytimeoutN)r/   controlrevoker0   r6   rJ   rK   rL   waitrN   r   r   r   rP      s    zAsyncResult.revokeT      ?c              
   C   s   | j r
dS |	rt  t }|r>|r>| jr>t| jdd}|   |rL|| | jrh|rb| j|d | jS | j	
|  | j	j| |||||||dS )a  Wait until task is ready, and return its result.

        Warning:
           Waiting for tasks within a task may lead to deadlocks.
           Please read :ref:`task-synchronous-subtasks`.

        Warning:
           Backends use resources to store and transmit results. To ensure
           that resources are released, you must eventually call
           :meth:`~@AsyncResult.get` or :meth:`~@AsyncResult.forget` on
           EVERY :class:`~@AsyncResult` instance returned after calling
           a task.

        Arguments:
            timeout (float): How long to wait, in seconds, before the
                operation times out.
            propagate (bool): Re-raise exception if the task failed.
            interval (float): Time to wait (in seconds) before retrying to
                retrieve the result.  Note that this does not have any effect
                when using the RPC/redis result store backends, as they don't
                use polling.
            no_ack (bool): Enable amqp no ack (automatically acknowledge
                message).  If this is :const:`False` then the message will
                **not be acked**.
            follow_parents (bool): Re-raise any exception raised by
                parent tasks.
            disable_sync_subtasks (bool): Disable tasks to wait for sub tasks
                this is the default configuration. CAUTION do not enable this
                unless you must.

        Raises:
            celery.exceptions.TimeoutError: if `timeout` isn't
                :const:`None` and the result does not arrive within
                `timeout` seconds.
            Exception: If the remote call raised an exception then that
                exception will be re-raised in the caller process.
        NTr+   )r?   )rN   intervalon_intervalno_ack	propagater?   
on_message)r:   r   r   r*   _maybe_reraise_parent_errorr=   r4   maybe_throwrC   r1   r<   Zwait_for_pending)r6   rN   rW   rT   rV   Zfollow_parentsr?   rX   rU   disable_sync_subtasksEXCEPTION_STATESPROPAGATE_STATESZ_on_intervalr   r   r   get   s0    *
zAsyncResult.getc                 C   s"   t t|  D ]}|  qd S r   )reversedlist_parentsrZ   r6   noder   r   r   rY      s    z'AsyncResult._maybe_reraise_parent_errorc                 c   s   | j }|r|V  |j }qd S r   r*   rb   r   r   r   ra      s    zAsyncResult._parentsc                 k   s0   | j |dD ]\}}||jf i |fV  qdS )a  Collect results as they return.

        Iterator, like :meth:`get` will wait for the task to complete,
        but will also follow :class:`AsyncResult` and :class:`ResultSet`
        returned by the task, yielding ``(result, value)`` tuples for each
        result in the tree.

        An example would be having the following tasks:

        .. code-block:: python

            from celery import group
            from proj.celery import app

            @app.task(trail=True)
            def A(how_many):
                return group(B.s(i) for i in range(how_many))()

            @app.task(trail=True)
            def B(i):
                return pow2.delay(i)

            @app.task(trail=True)
            def pow2(i):
                return i ** 2

        .. code-block:: pycon

            >>> from celery.result import ResultBase
            >>> from proj.tasks import A

            >>> result = A.delay(10)
            >>> [v for v in result.collect()
            ...  if not isinstance(v, (ResultBase, tuple))]
            [0, 1, 4, 9, 16, 25, 36, 49, 64, 81]

        Note:
            The ``Task.trail`` option must be enabled
            so that the list of children is stored in ``result.children``.
            This is the default but enabled explicitly for illustration.

        Yields:
            Tuple[AsyncResult, Any]: tuples containing the result instance
            of the child task, and the return value of that task.
        intermediateNiterdepsr^   )r6   rf   kwargs_Rr   r   r   collect   s    .zAsyncResult.collectc                 C   s"   d }|   D ]\}}| }q|S r   rg   )r6   r;   rj   rk   r   r   r   get_leaf%  s    
zAsyncResult.get_leafc                 #   s`   t d | fg}|r\| \} | fV    rP| fdd jpFg D  q|st qd S )Nc                 3   s   | ]} |fV  qd S r   r   .0childrc   r   r   	<genexpr>2      z'AsyncResult.iterdeps.<locals>.<genexpr>)r   popleftreadyrF   childrenr   )r6   rf   stackr*   r   rq   r   rh   +  s    
 zAsyncResult.iterdepsc                 C   s   | j | jjv S )zReturn :const:`True` if the task has executed.

        If the task is still running, pending, or is waiting
        for retry then :const:`False` is returned.
        )stater1   READY_STATESr9   r   r   r   ru   7  s    zAsyncResult.readyc                 C   s   | j tjkS )z7Return :const:`True` if the task executed successfully.)rx   r
   SUCCESSr9   r   r   r   
successful?  s    zAsyncResult.successfulc                 C   s   | j tjkS )z(Return :const:`True` if the task failed.)rx   r
   FAILUREr9   r   r   r   failedC  s    zAsyncResult.failedc                 O   s   | j j|i | d S r   )r3   throwr6   argsri   r   r   r   r~   G  s    zAsyncResult.throwc                 C   sn   | j d u r|  n| j }|d |d |d  }}}|tjv rV|rV| || | |d urj|| j| |S )NstatusrC   	traceback)r4   _get_task_metar^   r
   r]   r~   _to_remote_tracebackr0   )r6   rW   r?   cacherx   r;   tbr   r   r   rZ   J  s    
zAsyncResult.maybe_throwc                 C   s*   |r&t d ur&| jjjr&t j| S d S r   )tblibr/   confZtask_remote_tracebacks	TracebackZfrom_stringZas_traceback)r6   r   r   r   r   r   U  s    z AsyncResult._to_remote_tracebackc                 C   sL   t |pt| jddd}| j|dD ]"\}}|| |r$||| q$|S )NZoval)rootshape)	formatterre   )r   r   r0   rh   Zadd_arcZadd_edge)r6   rf   r   graphr*   rc   r   r   r   build_graphY  s    
zAsyncResult.build_graphc                 C   s
   t | jS z`str(self) -> self.id`.strr0   r9   r   r   r   __str__c  s    zAsyncResult.__str__c                 C   s
   t | jS z`hash(self) -> hash(self.id)`.hashr0   r9   r   r   r   __hash__g  s    zAsyncResult.__hash__c                 C   s   dt | j d| j dS )N<: >)r.   r&   r0   r9   r   r   r   __repr__k  s    zAsyncResult.__repr__c                 C   s.   t |tr|j| jkS t |tr*|| jkS tS r   )
isinstancer   r0   r   NotImplementedr6   otherr   r   r   __eq__n  s
    


zAsyncResult.__eq__c                 C   s   |  |}|tu rdS | S r$   r   r   r6   r   resr   r   r   __ne__u  s    
zAsyncResult.__ne__c                 C   s   |  | j| jd | j| jS r   )	__class__r0   r1   r/   r*   r9   r   r   r   __copy__y  s    zAsyncResult.__copy__c                 C   s   | j |  fS r   r   __reduce_args__r9   r   r   r   
__reduce__~  s    zAsyncResult.__reduce__c                 C   s   | j | jd d | jfS r   )r0   r1   r*   r9   r   r   r   r     s    zAsyncResult.__reduce_args__c                 C   s   | j dur| j |  dS )z9Cancel pending operations when the instance is destroyed.Nr@   r9   r   r   r   __del__  s    
zAsyncResult.__del__c                 C   s   |   S r   )r   r9   r   r   r   r     s    zAsyncResult.graphc                 C   s   | j jS r   )r1   supports_native_joinr9   r   r   r   r     s    z AsyncResult.supports_native_joinc                 C   s   |   dS )Nrv   r   r^   r9   r   r   r   rv     s    zAsyncResult.childrenc                 C   s:   |r6|d }|t jv r6| | j|}| |  |S |S )Nr   )r
   ry   
_set_cacher1   Zmeta_from_decodedr3   )r6   metarx   dr   r   r   _maybe_set_cache  s    

zAsyncResult._maybe_set_cachec                 C   s$   | j d u r| | j| jS | j S r   )r4   r   r1   Zget_task_metar0   r9   r   r   r   r     s    
zAsyncResult._get_task_metac                 K   s   t |  gS r   )iterr   r6   ri   r   r   r   
_iter_meta  s    zAsyncResult._iter_metac                    s.   | d}|r$ fdd|D |d< | _|S )Nrv   c                    s   g | ]}t | jqS r   )r   r/   rn   r9   r   r   
<listcomp>  s   z*AsyncResult._set_cache.<locals>.<listcomp>)r^   r4   )r6   r   rv   r   r9   r   r     s    


zAsyncResult._set_cachec                 C   s   |   d S )zTask return value.

        Note:
            When the task has been executed, this contains the return value.
            If the task raised an exception, this will be the exception
            instance.
        rC   r   r9   r   r   r   rC     s    	zAsyncResult.resultc                 C   s   |   dS )z#Get the traceback of a failed task.r   r   r9   r   r   r   r     s    zAsyncResult.tracebackc                 C   s   |   d S )a  The tasks current state.

        Possible values includes:

            *PENDING*

                The task is waiting for execution.

            *STARTED*

                The task has been started.

            *RETRY*

                The task is to be retried, possibly because of failure.

            *FAILURE*

                The task raised an exception, or has exceeded the retry limit.
                The :attr:`result` attribute then contains the
                exception raised by the task.

            *SUCCESS*

                The task executed successfully.  The :attr:`result` attribute
                then contains the tasks return value.
        r   r   r9   r   r   r   rx     s    zAsyncResult.statec                 C   s   | j S )zCompat. alias to :attr:`id`.r0   r9   r   r   r   task_id  s    zAsyncResult.task_idc                 C   s
   || _ d S r   r   )r6   r0   r   r   r   r     s    c                 C   s   |   dS )Nnamer   r9   r   r   r   r     s    zAsyncResult.namec                 C   s   |   dS )Nr   r   r9   r   r   r   r     s    zAsyncResult.argsc                 C   s   |   dS )Nri   r   r9   r   r   r   ri     s    zAsyncResult.kwargsc                 C   s   |   dS )Nworkerr   r9   r   r   r   r     s    zAsyncResult.workerc                 C   s*   |   d}|r&t|tjs&t|S |S )zUTC date and time.	date_done)r   r^   r   datetimer   )r6   r   r   r   r   r     s    zAsyncResult.date_donec                 C   s   |   dS )Nretriesr   r9   r   r   r   r     s    zAsyncResult.retriesc                 C   s   |   dS )Nqueuer   r9   r   r   r   r     s    zAsyncResult.queue)NNNN)NF)NFNFN)F)F)TN)FN)Br&   r'   r(   r)   r/   r   r0   r1   r7   propertyr:   setterr=   r2   rD   rG   rI   rP   r
   r\   r]   r^   rR   rY   ra   rl   rm   rh   ru   r{   r}   r~   rZ   maybe_reraiser   r   r   r   r   r   r   r   r   r   r   r   r   r   rv   r   r   r   r   rC   infor   rx   r   r   r   r   ri   r   r   r   r   r   r   r   r   r   C   s      



	  

E
1

	




		
	









r   c                   @   s>  e Zd ZdZdZdZdEddZdd Zdd Zd	d
 Z	dd Z
dd Zdd Zdd Zdd ZdFddZeZdd Zdd Zdd Zdd ZdGd!d"Zd#d$ Zd%d& ZdHd(d)ZdId*d+ZdJd,d-ZdKd.d/ZdLd0d1Zd2d3 Zd4d5 Zd6d7 Zd8d9 Z d:d; Z!d<d= Z"e#d>d? Z$e#d@dA Z%e%j&dBdA Z%e#dCdD Z'dS )Mr   zpA collection of results.

    Arguments:
        results (Sequence[AsyncResult]): List of result instances.
    Nc                 K   sH   || _ || _t| fd| _|p$t|| _| jrD| jt| jdd d S )N)r   Tr+   )_apprH   r   r3   r   _on_fullr=   	_on_ready)r6   rH   r/   Zready_barrierri   r   r   r   r7     s    zResultSet.__init__c                 C   s,   || j vr(| j | | jr(| j| dS )zvAdd :class:`AsyncResult` as a new member of the set.

        Does nothing if the result is already a member.
        N)rH   rE   r   addrB   r   r   r   r     s    
zResultSet.addc                 C   s   | j jr|   d S r   )r1   is_asyncr3   r9   r   r   r   r   )  s    zResultSet._on_readyc                 C   sF   t |tr| j|}z| j| W n ty@   t|Y n0 dS )z~Remove result from the set; it must be a member.

        Raises:
            KeyError: if the result isn't a member.
        N)r   r   r/   r   rH   remover-   KeyErrorrB   r   r   r   r   -  s    
zResultSet.removec                 C   s&   z|  | W n ty    Y n0 dS )zbRemove result from the set if it is a member.

        Does nothing if it's not a member.
        N)r   r   rB   r   r   r   discard:  s    zResultSet.discardc                    s    j  fdd|D  dS )z Extend from iterable of results.c                 3   s   | ]}| j vr|V  qd S r   rH   ro   rr9   r   r   rr   F  rs   z#ResultSet.update.<locals>.<genexpr>N)rH   rF   )r6   rH   r   r9   r   updateD  s    zResultSet.updatec                 C   s   g | j dd< dS )z!Remove all results from this set.Nr   r9   r   r   r   clearH  s    zResultSet.clearc                 C   s   t dd | jD S )zReturn true if all tasks successful.

        Returns:
            bool: true if all of the tasks finished
                successfully (i.e. didn't raise an exception).
        c                 s   s   | ]}|  V  qd S r   )r{   ro   rC   r   r   r   rr   S  rs   z'ResultSet.successful.<locals>.<genexpr>allrH   r9   r   r   r   r{   L  s    zResultSet.successfulc                 C   s   t dd | jD S )zReturn true if any of the tasks failed.

        Returns:
            bool: true if one of the tasks failed.
                (i.e., raised an exception)
        c                 s   s   | ]}|  V  qd S r   )r}   r   r   r   r   rr   \  rs   z#ResultSet.failed.<locals>.<genexpr>anyrH   r9   r   r   r   r}   U  s    zResultSet.failedTc                 C   s   | j D ]}|j||d qd S )N)r?   rW   )rH   rZ   )r6   r?   rW   rC   r   r   r   rZ   ^  s    
zResultSet.maybe_throwc                 C   s   t dd | jD S )zReturn true if any of the tasks are incomplete.

        Returns:
            bool: true if one of the tasks are still
                waiting for execution.
        c                 s   s   | ]}|   V  qd S r   ru   r   r   r   r   rr   j  rs   z$ResultSet.waiting.<locals>.<genexpr>r   r9   r   r   r   waitingc  s    zResultSet.waitingc                 C   s   t dd | jD S )zDid all of the tasks complete? (either by success of failure).

        Returns:
            bool: true if all of the tasks have been executed.
        c                 s   s   | ]}|  V  qd S r   r   r   r   r   r   rr   r  rs   z"ResultSet.ready.<locals>.<genexpr>r   r9   r   r   r   ru   l  s    zResultSet.readyc                 C   s   t dd | jD S )zaTask completion count.

        Returns:
            int: the number of tasks completed.
        c                 s   s   | ]}t | V  qd S r   )intr{   r   r   r   r   rr   z  rs   z,ResultSet.completed_count.<locals>.<genexpr>)sumrH   r9   r   r   r   completed_countt  s    zResultSet.completed_countc                 C   s   | j D ]}|  qdS )z?Forget about (and possible remove the result of) all the tasks.N)rH   rI   rB   r   r   r   rI   |  s    
zResultSet.forgetFc                 C   s*   | j jjdd | jD |||||d dS )a[  Send revoke signal to all workers for all tasks in the set.

        Arguments:
            terminate (bool): Also terminate the process currently working
                on the task (if any).
            signal (str): Name of signal to send to process if terminate.
                Default is TERM.
            wait (bool): Wait for replies from worker.
                The ``timeout`` argument specifies the number of seconds
                to wait.  Disabled by default.
            timeout (float): Time in seconds to wait for replies when
                the ``wait`` argument is enabled.
        c                 S   s   g | ]
}|j qS r   r   r   r   r   r   r     rs   z$ResultSet.revoke.<locals>.<listcomp>)rJ   rN   rK   rL   rM   N)r/   rO   rP   rH   rQ   r   r   r   rP     s    zResultSet.revokec                 C   s
   t | jS r   )r   rH   r9   r   r   r   __iter__  s    zResultSet.__iter__c                 C   s
   | j | S )z`res[i] -> res.results[i]`.r   )r6   indexr   r   r   __getitem__  s    zResultSet.__getitem__rS   c	           	   
   C   s&   | j r| jn| j||||||||dS )zSee :meth:`join`.

        This is here for API compatibility with :class:`AsyncResult`,
        in addition it uses :meth:`join_native` if available for the
        current result backend.
        )rN   rW   rT   r?   rV   rX   r[   rU   )r   join_nativejoin)	r6   rN   rW   rT   r?   rV   rX   r[   rU   r   r   r   r^     s    	zResultSet.getc	              	   C   s   |r
t   t }	d}
|dur&tdg }| jD ]^}d}
|r\|t |	  }
|
dkr\td|j|
|||||d}|r||j| q0|| q0|S )a  Gather the results of all tasks as a list in order.

        Note:
            This can be an expensive operation for result store
            backends that must resort to polling (e.g., database).

            You should consider using :meth:`join_native` if your backend
            supports it.

        Warning:
            Waiting for tasks within a task may lead to deadlocks.
            Please see :ref:`task-synchronous-subtasks`.

        Arguments:
            timeout (float): The number of seconds to wait for results
                before the operation times out.
            propagate (bool): If any of the tasks raises an exception,
                the exception will be re-raised when this flag is set.
            interval (float): Time to wait (in seconds) before retrying to
                retrieve a result from the set.  Note that this does not have
                any effect when using the amqp result store backend,
                as it does not use polling.
            callback (Callable): Optional callback to be called for every
                result received.  Must have signature ``(task_id, value)``
                No results will be returned by this function if a callback
                is specified.  The order of results is also arbitrary when a
                callback is used.  To get access to the result object for
                a particular id you'll have to generate an index first:
                ``index = {r.id: r for r in gres.results.values()}``
                Or you can create new result objects on the fly:
                ``result = app.AsyncResult(task_id)`` (both will
                take advantage of the backend cache anyway).
            no_ack (bool): Automatic message acknowledgment (Note that if this
                is set to :const:`False` then the messages
                *will not be acknowledged*).
            disable_sync_subtasks (bool): Disable tasks to wait for sub tasks
                this is the default configuration. CAUTION do not enable this
                unless you must.

        Raises:
            celery.exceptions.TimeoutError: if ``timeout`` isn't
                :const:`None` and the operation takes longer than ``timeout``
                seconds.
        Nz,Backend does not support on_message callbackg        zjoin operation timed out)rN   rW   rT   rV   rU   r[   )	r   time	monotonicr   rH   r   r^   r0   rE   )r6   rN   rW   rT   r?   rV   rX   r[   rU   Z
time_start	remainingrH   rC   r;   r   r   r   r     s0    /
zResultSet.joinc                 C   s   | j ||S r   r3   r=   r>   r   r   r   r=     s    zResultSet.thenc                 C   s   | j j| |||||dS )a0  Backend optimized version of :meth:`iterate`.

        .. versionadded:: 2.2

        Note that this does not support collecting the results
        for different task types using different backends.

        This is currently only supported by the amqp, Redis and cache
        result backends.
        )rN   rT   rV   rX   rU   )r1   iter_native)r6   rN   rT   rV   rX   rU   r   r   r   r     s
    zResultSet.iter_nativec	                 C   s   |r
t   |rdndd t| jD }	|r.dndd tt| D }
| |||||D ]j\}}t|trg }|D ]}||	  qpn|d }|r|d t
jv r||r||| qV||
|	| < qV|
S )a-  Backend optimized version of :meth:`join`.

        .. versionadded:: 2.2

        Note that this does not support collecting the results
        for different task types using different backends.

        This is currently only supported by the amqp, Redis and cache
        result backends.
        Nc                 S   s   i | ]\}}|j |qS r   r   )ro   irC   r   r   r   
<dictcomp>  s   z)ResultSet.join_native.<locals>.<dictcomp>c                 S   s   g | ]}d qS r   r   )ro   rj   r   r   r   r     rs   z)ResultSet.join_native.<locals>.<listcomp>rC   r   )r   	enumeraterH   rangelenr   r   r`   rE   r^   r
   r]   )r6   rN   rW   rT   r?   rV   rX   rU   r[   Zorder_indexaccr   r   r;   Zchildren_resultr   r   r   r   
  s(    

zResultSet.join_nativec                 K   s.   dd | j jdd | jD fddi|D S )Nc                 s   s   | ]\}}|V  qd S r   r   )ro   rj   r   r   r   r   rr   /  rs   z'ResultSet._iter_meta.<locals>.<genexpr>c                 S   s   h | ]
}|j qS r   r   r   r   r   r   	<setcomp>0  rs   z'ResultSet._iter_meta.<locals>.<setcomp>Zmax_iterationsr   )r1   Zget_manyrH   r   r   r   r   r   .  s    zResultSet._iter_metac                 C   s   dd | j D S )Nc                 s   s,   | ]$}|j |jr|jtjv r|V  qd S r   )r1   Z	is_cachedr0   rx   r
   r]   )ro   r   r   r   r   rr   4  s   z0ResultSet._failed_join_report.<locals>.<genexpr>r   r9   r   r   r   _failed_join_report3  s    zResultSet._failed_join_reportc                 C   s
   t | jS r   )r   rH   r9   r   r   r   __len__8  s    zResultSet.__len__c                 C   s   t |tr|j| jkS tS r   )r   r   rH   r   r   r   r   r   r   ;  s    
zResultSet.__eq__c                 C   s   |  |}|tu rdS | S r$   r   r   r   r   r   r   @  s    
zResultSet.__ne__c                 C   s*   dt | j dddd | jD  dS )Nr   z: [, c                 s   s   | ]}|j V  qd S r   r   r   r   r   r   rr   E  rs   z%ResultSet.__repr__.<locals>.<genexpr>]>)r.   r&   r   rH   r9   r   r   r   r   D  s    zResultSet.__repr__c                 C   s&   z| j d jW S  ty    Y n0 d S Nr   )rH   r   
IndexErrorr9   r   r   r   r   G  s    zResultSet.supports_native_joinc                 C   s,   | j d u r&| jr| jd jnt | _ | j S r   )r   rH   r/   r	   Z_get_current_objectr9   r   r   r   r/   N  s
    
zResultSet.appc                 C   s
   || _ d S r   )r   )r6   r/   r   r   r   r/   U  s    c                 C   s   | j r| j jS | jd jS r   )r/   r1   rH   r9   r   r   r   r1   Y  s    zResultSet.backend)NN)NT)NFNFN)NTrS   NTNTN)NTrS   NTNTN)NF)NrS   TNN)NTrS   NTNNT)(r&   r'   r(   r)   r   rH   r7   r   r   r   r   r   r   r{   r}   rZ   r   r   ru   r   rI   rP   r   r   r^   r   r=   r   r   r   r   r   r   r   r   r   r   r/   r   r1   r   r   r   r   r   
  sl   


		
	  
   
   
J
  
    
$


r   c                   @   s   e Zd ZdZdZdZd!ddZdd Zd"ddZd#d	d
Z	dd Z
dd Zdd ZeZdd Zdd Zdd Zdd Zdd Zdd Zedd Zed$dd ZdS )%r   az  Like :class:`ResultSet`, but with an associated id.

    This type is returned by :class:`~celery.group`.

    It enables inspection of the tasks state and return values as
    a single entity.

    Arguments:
        id (str): The id of the group.
        results (Sequence[AsyncResult]): List of result instances.
        parent (ResultBase): Parent result of this group.
    Nc                 K   s$   || _ || _tj| |fi | d S r   )r0   r*   r   r7   )r6   r0   rH   r*   ri   r   r   r   r7   s  s    zGroupResult.__init__c                 C   s   | j |  t|  d S r   )r1   rA   r   r   r9   r   r   r   r   x  s    zGroupResult._on_readyc                 C   s   |p
| j j| j| S )zSave group-result for later retrieval using :meth:`restore`.

        Example:
            >>> def save_and_restore(result):
            ...     result.save()
            ...     result = GroupResult.restore(result.id)
        )r/   r1   Z
save_groupr0   r6   r1   r   r   r   save|  s    zGroupResult.savec                 C   s   |p
| j j| j dS )z.Remove this result if it was previously saved.N)r/   r1   Zdelete_groupr0   r   r   r   r   delete  s    zGroupResult.deletec                 C   s   | j |  fS r   r   r9   r   r   r   r     s    zGroupResult.__reduce__c                 C   s   | j | jfS r   )r0   rH   r9   r   r   r   r     s    zGroupResult.__reduce_args__c                 C   s   t | jp| jS r   )boolr0   rH   r9   r   r   r   __bool__  s    zGroupResult.__bool__c                 C   sF   t |tr.|j| jko,|j| jko,|j| jkS t |trB|| jkS tS r   )r   r   r0   rH   r*   r   r   r   r   r   r   r     s    




zGroupResult.__eq__c                 C   s   |  |}|tu rdS | S r$   r   r   r   r   r   r     s    
zGroupResult.__ne__c              	   C   s2   dt | j d| j dddd | jD  dS )Nr   r   z [r   c                 s   s   | ]}|j V  qd S r   r   r   r   r   r   rr     rs   z'GroupResult.__repr__.<locals>.<genexpr>r   )r.   r&   r0   r   rH   r9   r   r   r   r     s    zGroupResult.__repr__c                 C   s
   t | jS r   r   r9   r   r   r   r     s    zGroupResult.__str__c                 C   s
   t | jS r   r   r9   r   r   r   r     s    zGroupResult.__hash__c                 C   s&   | j | jo| j fdd | jD fS )Nc                 S   s   g | ]}|  qS r   )rD   r   r   r   r   r     rs   z(GroupResult.as_tuple.<locals>.<listcomp>)r0   r*   rD   rH   r9   r   r   r   rD     s    zGroupResult.as_tuplec                 C   s   | j S r   r   r9   r   r   r   rv     s    zGroupResult.childrenc                 C   s.   |pt | jts| jnt}|p"|j}||S )z&Restore previously saved group result.)r   r/   r   r	   r1   Zrestore_group)clsr0   r1   r/   r   r   r   restore  s
    
zGroupResult.restore)NNN)N)N)NN)r&   r'   r(   r)   r0   rH   r7   r   r   r   r   r   r   __nonzero__r   r   r   r   r   rD   r   rv   classmethodr   r   r   r   r   r   ^  s*   




r   c                   @   s   e Zd ZdZd%ddZd&ddZdd	 Zd
d Zdd Zdd Z	dd Z
d'ddZeZdd Zdd Zdd Zedd Zedd Zedd  ZeZed!d" Zed#d$ ZdS )(r   z.Result that we know has already been executed.Nc                 C   s.   || _ || _|| _|| _t | _| |  d S r   )r0   _result_state
_tracebackr   r3   )r6   r0   Z	ret_valuerx   r   r   r   r   r7     s    zEagerResult.__init__Fc                 C   s   | j ||S r   r   r>   r   r   r   r=     s    zEagerResult.thenc                 C   s   | j S r   )r4   r9   r   r   r   r     s    zEagerResult._get_task_metac                 C   s   | j |  fS r   r   r9   r   r   r   r     s    zEagerResult.__reduce__c                 C   s   | j | j| j| jfS r   r0   r   r   r   r9   r   r   r   r     s    zEagerResult.__reduce_args__c                 C   s   |   \}}|| S r   )r   )r6   r   r   r   r   r   r     s    zEagerResult.__copy__c                 C   s   dS r$   r   r9   r   r   r   ru     s    zEagerResult.readyTc                 K   sN   |r
t   |  r| jS | jtjv rJ|rDt| jtr:| jnt| j| jS d S r   )r   r{   rC   rx   r
   r]   r   	Exception)r6   rN   rW   r[   ri   r   r   r   r^     s    
zEagerResult.getc                 C   s   d S r   r   r9   r   r   r   rI     s    zEagerResult.forgetc                 O   s   t j| _d S r   )r
   ZREVOKEDr   r   r   r   r   rP     s    zEagerResult.revokec                 C   s   d| j  dS )Nz<EagerResult: r   r   r9   r   r   r   r     s    zEagerResult.__repr__c                 C   s   | j | j| j| jdS )N)r   rC   r   r   r   r9   r   r   r   r4     s
    zEagerResult._cachec                 C   s   | j S )zThe tasks return value.)r   r9   r   r   r   rC     s    zEagerResult.resultc                 C   s   | j S )zThe tasks state.)r   r9   r   r   r   rx     s    zEagerResult.statec                 C   s   | j S )z!The traceback if the task failed.)r   r9   r   r   r   r     s    zEagerResult.tracebackc                 C   s   dS r    r   r9   r   r   r   r     s    z EagerResult.supports_native_join)N)NF)NTT)r&   r'   r(   r)   r7   r=   r   r   r   r   ru   r^   rR   rI   rP   r   r   r4   rC   rx   r   r   r   r   r   r   r   r     s4   


  




r   c                    s   t    j}t| ts~| \}}t|ttfr2|n|df\}}|rLt| }|durr j| fdd|D |dS |||dS | S )zDeserialize result from tuple.Nc                    s   g | ]}t | qS r   )r   rn   r/   r   r   r   &  rs   z%result_from_tuple.<locals>.<listcomp>rd   )r   r   r   r   r`   tupler   r   )r   r/   ZResultr   nodesr0   r*   r   r   r   r     s    

r   )N),r)   r   r   collectionsr   
contextlibr   Zkombu.utils.objectsr   Zviner   r   r    r	   r
   r   r   r   r/   r   
exceptionsr   r   r   Zutils.graphr   r   Zutils.iso8601r   r   ImportError__all__r   r   r#   r%   r   registerr   r   r   r   r   r   r   r   r   <module>   sL   

	
	   I  UcU