This commit is contained in:
Ask Solem 2016-03-02 13:50:38 -08:00
Родитель fd2f712f1b
Коммит 22eba29948
9 изменённых файлов: 11 добавлений и 8 удалений

Просмотреть файл

@ -16,11 +16,11 @@ from collections import defaultdict, deque
from operator import attrgetter from operator import attrgetter
from functools import wraps from functools import wraps
from amqp import starpromise
from kombu import pools from kombu import pools
from kombu.clocks import LamportClock from kombu.clocks import LamportClock
from kombu.common import oid_from from kombu.common import oid_from
from kombu.utils import cached_property, register_after_fork, uuid from kombu.utils import cached_property, register_after_fork, uuid
from vine import starpromise
from celery import platforms from celery import platforms
from celery import signals from celery import signals

Просмотреть файл

@ -20,8 +20,8 @@ from functools import partial as _partial, reduce
from operator import itemgetter from operator import itemgetter
from itertools import chain as _chain from itertools import chain as _chain
from amqp.promise import barrier
from kombu.utils import cached_property, fxrange, reprcall, uuid from kombu.utils import cached_property, fxrange, reprcall, uuid
from vine import barrier
from celery._state import current_app from celery._state import current_app
from celery.local import try_import from celery.local import try_import

Просмотреть файл

@ -33,7 +33,6 @@ from pickle import HIGHEST_PROTOCOL
from time import sleep from time import sleep
from weakref import WeakValueDictionary, ref from weakref import WeakValueDictionary, ref
from amqp import promise
from billiard.pool import RUN, TERMINATE, ACK, NACK, WorkersJoined from billiard.pool import RUN, TERMINATE, ACK, NACK, WorkersJoined
from billiard import pool as _pool from billiard import pool as _pool
from billiard.compat import buf_t, setblocking, isblocking from billiard.compat import buf_t, setblocking, isblocking
@ -42,6 +41,8 @@ from kombu.async import READ, WRITE, ERR
from kombu.serialization import pickle as _pickle from kombu.serialization import pickle as _pickle
from kombu.utils import fxrange from kombu.utils import fxrange
from kombu.utils.eventio import SELECT_BAD_FD from kombu.utils.eventio import SELECT_BAD_FD
from vine import promise
from celery.five import Counter, items, values from celery.five import Counter, items, values
from celery.utils.functional import noop from celery.utils.functional import noop
from celery.utils.log import get_logger from celery.utils.log import get_logger

Просмотреть файл

@ -14,8 +14,8 @@ from collections import OrderedDict, deque
from contextlib import contextmanager from contextlib import contextmanager
from copy import copy from copy import copy
from amqp.promise import Thenable, promise
from kombu.utils import cached_property from kombu.utils import cached_property
from vine import Thenable, promise
from . import current_app from . import current_app
from . import states from . import states

Просмотреть файл

@ -7,7 +7,7 @@ import itertools
from copy import deepcopy from copy import deepcopy
from pickle import loads, dumps from pickle import loads, dumps
from amqp import promise from vine import promise
from celery import Celery from celery import Celery
from celery import shared_task, current_app from celery import shared_task, current_app

Просмотреть файл

@ -19,10 +19,10 @@ except ImportError: # Py2
from inspect import isfunction, getargspec # noqa from inspect import isfunction, getargspec # noqa
from itertools import chain, islice from itertools import chain, islice
from amqp import promise
from kombu.utils.functional import ( from kombu.utils.functional import (
dictfilter, lazy, maybe_evaluate, is_list, maybe_list, dictfilter, lazy, maybe_evaluate, is_list, maybe_list,
) )
from vine import promise
from celery.five import UserDict, UserList, keys, range from celery.five import UserDict, UserList, keys, range

Просмотреть файл

@ -17,7 +17,6 @@ import os
from collections import defaultdict from collections import defaultdict
from time import sleep from time import sleep
from amqp.promise import ppartial, promise
from billiard.common import restart_state from billiard.common import restart_state
from billiard.exceptions import RestartFreqExceeded from billiard.exceptions import RestartFreqExceeded
from kombu.async.semaphore import DummyLock from kombu.async.semaphore import DummyLock
@ -25,6 +24,7 @@ from kombu.five import buffer_t, items
from kombu.syn import _detect_environment from kombu.syn import _detect_environment
from kombu.utils.encoding import safe_repr, bytes_t from kombu.utils.encoding import safe_repr, bytes_t
from kombu.utils.limits import TokenBucket from kombu.utils.limits import TokenBucket
from vine import ppartial, promise
from celery import bootsteps from celery import bootsteps
from celery import signals from celery import signals

Просмотреть файл

@ -76,6 +76,7 @@ intersphinx_mapping = {
'djcelery': ('http://django-celery.readthedocs.org/en/master', None), 'djcelery': ('http://django-celery.readthedocs.org/en/master', None),
'cyme': ('http://cyme.readthedocs.org/en/latest', None), 'cyme': ('http://cyme.readthedocs.org/en/latest', None),
'amqp': ('http://amqp.readthedocs.org/en/latest', None), 'amqp': ('http://amqp.readthedocs.org/en/latest', None),
'vine': ('http://vine.readthedocs.org/en/latest', None),
'flower': ('http://flower.readthedocs.org/en/latest', None), 'flower': ('http://flower.readthedocs.org/en/latest', None),
} }

Просмотреть файл

@ -1,3 +1,4 @@
https://github.com/celery/py-amqp/zipball/master
https://github.com/celery/billiard/zipball/master https://github.com/celery/billiard/zipball/master
https://github.com/celery/kombu/zipball/master https://github.com/celery/kombu/zipball/master
https://github.com/celery/py-amqp/zipball/master
https://github.com/celery/vine/zipball/master