Skip to content

Commit

Permalink
Use vine for promises
Browse files Browse the repository at this point in the history
  • Loading branch information
ask committed Mar 2, 2016
1 parent fd2f712 commit 22eba29
Show file tree
Hide file tree
Showing 9 changed files with 11 additions and 8 deletions.
2 changes: 1 addition & 1 deletion celery/app/base.py
Expand Up @@ -16,11 +16,11 @@
from operator import attrgetter
from functools import wraps

from amqp import starpromise
from kombu import pools
from kombu.clocks import LamportClock
from kombu.common import oid_from
from kombu.utils import cached_property, register_after_fork, uuid
from vine import starpromise

from celery import platforms
from celery import signals
Expand Down
2 changes: 1 addition & 1 deletion celery/canvas.py
Expand Up @@ -20,8 +20,8 @@
from operator import itemgetter
from itertools import chain as _chain

from amqp.promise import barrier
from kombu.utils import cached_property, fxrange, reprcall, uuid
from vine import barrier

from celery._state import current_app
from celery.local import try_import
Expand Down
3 changes: 2 additions & 1 deletion celery/concurrency/asynpool.py
Expand Up @@ -33,7 +33,6 @@
from time import sleep
from weakref import WeakValueDictionary, ref

from amqp import promise
from billiard.pool import RUN, TERMINATE, ACK, NACK, WorkersJoined
from billiard import pool as _pool
from billiard.compat import buf_t, setblocking, isblocking
Expand All @@ -42,6 +41,8 @@
from kombu.serialization import pickle as _pickle
from kombu.utils import fxrange
from kombu.utils.eventio import SELECT_BAD_FD
from vine import promise

from celery.five import Counter, items, values
from celery.utils.functional import noop
from celery.utils.log import get_logger
Expand Down
2 changes: 1 addition & 1 deletion celery/result.py
Expand Up @@ -14,8 +14,8 @@
from contextlib import contextmanager
from copy import copy

from amqp.promise import Thenable, promise
from kombu.utils import cached_property
from vine import Thenable, promise

from . import current_app
from . import states
Expand Down
2 changes: 1 addition & 1 deletion celery/tests/app/test_app.py
Expand Up @@ -7,7 +7,7 @@
from copy import deepcopy
from pickle import loads, dumps

from amqp import promise
from vine import promise

from celery import Celery
from celery import shared_task, current_app
Expand Down
2 changes: 1 addition & 1 deletion celery/utils/functional.py
Expand Up @@ -19,10 +19,10 @@
from inspect import isfunction, getargspec # noqa
from itertools import chain, islice

from amqp import promise
from kombu.utils.functional import (
dictfilter, lazy, maybe_evaluate, is_list, maybe_list,
)
from vine import promise

from celery.five import UserDict, UserList, keys, range

Expand Down
2 changes: 1 addition & 1 deletion celery/worker/consumer/consumer.py
Expand Up @@ -17,14 +17,14 @@
from collections import defaultdict
from time import sleep

from amqp.promise import ppartial, promise
from billiard.common import restart_state
from billiard.exceptions import RestartFreqExceeded
from kombu.async.semaphore import DummyLock
from kombu.five import buffer_t, items
from kombu.syn import _detect_environment
from kombu.utils.encoding import safe_repr, bytes_t
from kombu.utils.limits import TokenBucket
from vine import ppartial, promise

from celery import bootsteps
from celery import signals
Expand Down
1 change: 1 addition & 0 deletions docs/conf.py
Expand Up @@ -76,6 +76,7 @@ def linkcode_resolve(domain, info):
'djcelery': ('http://django-celery.readthedocs.org/en/master', None),
'cyme': ('http://cyme.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),
}

Expand Down
3 changes: 2 additions & 1 deletion requirements/dev.txt
@@ -1,3 +1,4 @@
https://github.com/celery/py-amqp/zipball/master
https://github.com/celery/billiard/zipball/master
https://github.com/celery/kombu/zipball/master
https://github.com/celery/py-amqp/zipball/master
https://github.com/celery/vine/zipball/master

0 comments on commit 22eba29

Please sign in to comment.