123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410 |
- from __future__ import generators
- import os
- import sys
- import operator
- import importlib
- import logging
- import threading
- import traceback
- import warnings
- from inspect import getargspec
- from itertools import islice
- from pprint import pprint
- from kombu.utils import gen_unique_id, rpartition, cached_property
- from celery.utils.compat import StringIO
- from celery.utils.functional import partial, wraps
- LOG_LEVELS = dict(logging._levelNames)
- LOG_LEVELS["FATAL"] = logging.FATAL
- LOG_LEVELS[logging.FATAL] = "FATAL"
- PENDING_DEPRECATION_FMT = """
- %(description)s is scheduled for deprecation in \
- version %(deprecation)s and removal in version v%(removal)s. \
- %(alternative)s
- """
- DEPRECATION_FMT = """
- %(description)s is deprecated and scheduled for removal in
- version %(removal)s. %(alternative)s
- """
- def deprecated(description=None, deprecation=None, removal=None,
- alternative=None):
- def _inner(fun):
- @wraps(fun)
- def __inner(*args, **kwargs):
- ctx = {"description": description or get_full_cls_name(fun),
- "deprecation": deprecation, "removal": removal,
- "alternative": alternative}
- if deprecation is not None:
- w = PendingDeprecationWarning(PENDING_DEPRECATION_FMT % ctx)
- else:
- w = DeprecationWarning(DEPRECATION_FMT % ctx)
- warnings.warn(w)
- return fun(*args, **kwargs)
- return __inner
- return _inner
- def lpmerge(L, R):
- """Left precedent dictionary merge. Keeps values from `l`, if the value
- in `r` is :const:`None`."""
- return dict(L, **dict((k, v) for k, v in R.iteritems() if v is not None))
- class promise(object):
- """A promise.
- Evaluated when called or if the :meth:`evaluate` method is called.
- The function is evaluated on every access, so the value is not
- memoized (see :class:`mpromise`).
- Overloaded operations that will evaluate the promise:
- :meth:`__str__`, :meth:`__repr__`, :meth:`__cmp__`.
- """
- def __init__(self, fun, *args, **kwargs):
- self._fun = fun
- self._args = args
- self._kwargs = kwargs
- def __call__(self):
- return self.evaluate()
- def evaluate(self):
- return self._fun(*self._args, **self._kwargs)
- def __str__(self):
- return str(self())
- def __repr__(self):
- return repr(self())
- def __cmp__(self, rhs):
- if isinstance(rhs, self.__class__):
- return -cmp(rhs, self())
- return cmp(self(), rhs)
- def __eq__(self, rhs):
- return self() == rhs
- def __deepcopy__(self, memo):
- memo[id(self)] = self
- return self
- def __reduce__(self):
- return (self.__class__, (self._fun, ), {"_args": self._args,
- "_kwargs": self._kwargs})
- class mpromise(promise):
- """Memoized promise.
- The function is only evaluated once, every subsequent access
- will return the same value.
- .. attribute:: evaluated
- Set to to :const:`True` after the promise has been evaluated.
- """
- evaluated = False
- _value = None
- def evaluate(self):
- if not self.evaluated:
- self._value = super(mpromise, self).evaluate()
- self.evaluated = True
- return self._value
- def maybe_promise(value):
- """Evaluates if the value is a promise."""
- if isinstance(value, promise):
- return value.evaluate()
- return value
- def noop(*args, **kwargs):
- """No operation.
- Takes any arguments/keyword arguments and does nothing.
- """
- pass
- def kwdict(kwargs):
- """Make sure keyword arguments are not in unicode.
- This should be fixed in newer Python versions,
- see: http://bugs.python.org/issue4978.
- """
- return dict((key.encode("utf-8"), value)
- for key, value in kwargs.items())
- def first(predicate, iterable):
- """Returns the first element in `iterable` that `predicate` returns a
- :const:`True` value for."""
- for item in iterable:
- if predicate(item):
- return item
- def firstmethod(method):
- """Returns a functions that with a list of instances,
- finds the first instance that returns a value for the given method.
- The list can also contain promises (:class:`promise`.)
- """
- def _matcher(seq, *args, **kwargs):
- for cls in seq:
- try:
- answer = getattr(maybe_promise(cls), method)(*args, **kwargs)
- if answer is not None:
- return answer
- except AttributeError:
- pass
- return _matcher
- def chunks(it, n):
- """Split an iterator into chunks with `n` elements each.
- Examples
- # n == 2
- >>> x = chunks(iter([0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]), 2)
- >>> list(x)
- [[0, 1], [2, 3], [4, 5], [6, 7], [8, 9], [10]]
- # n == 3
- >>> x = chunks(iter([0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]), 3)
- >>> list(x)
- [[0, 1, 2], [3, 4, 5], [6, 7, 8], [9, 10]]
- """
- for first in it:
- yield [first] + list(islice(it, n - 1))
- def padlist(container, size, default=None):
- """Pad list with default elements.
- Examples:
- >>> first, last, city = padlist(["George", "Costanza", "NYC"], 3)
- ("George", "Costanza", "NYC")
- >>> first, last, city = padlist(["George", "Costanza"], 3)
- ("George", "Costanza", None)
- >>> first, last, city, planet = padlist(["George", "Costanza",
- "NYC"], 4, default="Earth")
- ("George", "Costanza", "NYC", "Earth")
- """
- return list(container)[:size] + [default] * (size - len(container))
- def is_iterable(obj):
- try:
- iter(obj)
- except TypeError:
- return False
- return True
- def mattrgetter(*attrs):
- """Like :func:`operator.itemgetter` but returns :const:`None` on missing
- attributes instead of raising :exc:`AttributeError`."""
- return lambda obj: dict((attr, getattr(obj, attr, None))
- for attr in attrs)
- def get_full_cls_name(cls):
- """With a class, get its full module and class name."""
- return ".".join([cls.__module__,
- cls.__name__])
- def fun_takes_kwargs(fun, kwlist=[]):
- """With a function, and a list of keyword arguments, returns arguments
- in the list which the function takes.
- If the object has an `argspec` attribute that is used instead
- of using the :meth:`inspect.getargspec` introspection.
- :param fun: The function to inspect arguments of.
- :param kwlist: The list of keyword arguments.
- Examples
- >>> def foo(self, x, y, logfile=None, loglevel=None):
- ... return x * y
- >>> fun_takes_kwargs(foo, ["logfile", "loglevel", "task_id"])
- ["logfile", "loglevel"]
- >>> def foo(self, x, y, **kwargs):
- >>> fun_takes_kwargs(foo, ["logfile", "loglevel", "task_id"])
- ["logfile", "loglevel", "task_id"]
- """
- argspec = getattr(fun, "argspec", getargspec(fun))
- args, _varargs, keywords, _defaults = argspec
- if keywords != None:
- return kwlist
- return filter(partial(operator.contains, args), kwlist)
- def get_cls_by_name(name, aliases={}, imp=None):
- """Get class by name.
- The name should be the full dot-separated path to the class::
- modulename.ClassName
- Example::
- celery.concurrency.processes.TaskPool
- ^- class name
- If `aliases` is provided, a dict containing short name/long name
- mappings, the name is looked up in the aliases first.
- Examples:
- >>> get_cls_by_name("celery.concurrency.processes.TaskPool")
- <class 'celery.concurrency.processes.TaskPool'>
- >>> get_cls_by_name("default", {
- ... "default": "celery.concurrency.processes.TaskPool"})
- <class 'celery.concurrency.processes.TaskPool'>
- # Does not try to look up non-string names.
- >>> from celery.concurrency.processes import TaskPool
- >>> get_cls_by_name(TaskPool) is TaskPool
- True
- """
- if imp is None:
- imp = importlib.import_module
- if not isinstance(name, basestring):
- return name # already a class
- name = aliases.get(name) or name
- module_name, _, cls_name = rpartition(name, ".")
- module = imp(module_name)
- return getattr(module, cls_name)
- get_symbol_by_name = get_cls_by_name
- def instantiate(name, *args, **kwargs):
- """Instantiate class by name.
- See :func:`get_cls_by_name`.
- """
- return get_cls_by_name(name)(*args, **kwargs)
- def truncate_text(text, maxlen=128, suffix="..."):
- """Truncates text to a maximum number of characters."""
- if len(text) >= maxlen:
- return text[:maxlen].rsplit(" ", 1)[0] + suffix
- return text
- def abbr(S, max, ellipsis="..."):
- if S is None:
- return "???"
- if len(S) > max:
- return ellipsis and (S[:max - len(ellipsis)] + ellipsis) or S[:max]
- return S
- def abbrtask(S, max):
- if S is None:
- return "???"
- if len(S) > max:
- module, _, cls = rpartition(S, ".")
- module = abbr(module, max - len(cls) - 3, False)
- return module + "[.]" + cls
- return S
- def isatty(fh):
- # Fixes bug with mod_wsgi:
- # mod_wsgi.Log object has no attribute isatty.
- return getattr(fh, "isatty", None) and fh.isatty()
- def textindent(t, indent=0):
- """Indent text."""
- return "\n".join(" " * indent + p for p in t.split("\n"))
- def import_from_cwd(module, imp=None):
- """Import module, but make sure it finds modules
- located in the current directory.
- Modules located in the current directory has
- precedence over modules located in `sys.path`.
- """
- if imp is None:
- imp = importlib.import_module
- cwd = os.getcwd()
- if cwd in sys.path:
- return imp(module)
- sys.path.insert(0, cwd)
- try:
- return imp(module)
- finally:
- try:
- sys.path.remove(cwd)
- except ValueError:
- pass
- def cry():
- """Return stacktrace of all active threads.
- From https://gist.github.com/737056
- """
- tmap = {}
- main_thread = None
- # get a map of threads by their ID so we can print their names
- # during the traceback dump
- for t in threading.enumerate():
- if getattr(t, "ident", None):
- tmap[t.ident] = t
- else:
- main_thread = t
- out = StringIO()
- for tid, frame in sys._current_frames().iteritems():
- thread = tmap.get(tid, main_thread)
- out.write("%s\n" % (thread.getName(), ))
- out.write("=================================================\n")
- traceback.print_stack(frame, file=out)
- out.write("=================================================\n")
- out.write("LOCAL VARIABLES\n")
- out.write("=================================================\n")
- pprint(frame.f_locals, stream=out)
- out.write("\n\n")
- return out.getvalue()
|