| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253 | from __future__ import absolute_importimport sysimport typesfrom contextlib import contextmanagerfrom kombu.utils.encoding import str_to_bytesfrom celery import signaturefrom celery import statesfrom celery import groupfrom celery.backends.cache import CacheBackend, DummyClientfrom celery.exceptions import ImproperlyConfiguredfrom celery.five import items, string, text_tfrom celery.utils import uuidfrom celery.tests.case import (    AppCase, Mock, mask_modules, patch, reset_modules,)PY3 = sys.version_info[0] == 3class SomeClass(object):    def __init__(self, data):        self.data = dataclass test_CacheBackend(AppCase):    def setup(self):        self.tb = CacheBackend(backend='memory://', app=self.app)        self.tid = uuid()    def test_no_backend(self):        self.app.conf.CELERY_CACHE_BACKEND = None        with self.assertRaises(ImproperlyConfigured):            CacheBackend(backend=None, app=self.app)    def test_mark_as_done(self):        self.assertEqual(self.tb.get_status(self.tid), states.PENDING)        self.assertIsNone(self.tb.get_result(self.tid))        self.tb.mark_as_done(self.tid, 42)        self.assertEqual(self.tb.get_status(self.tid), states.SUCCESS)        self.assertEqual(self.tb.get_result(self.tid), 42)    def test_is_pickled(self):        result = {'foo': 'baz', 'bar': SomeClass(12345)}        self.tb.mark_as_done(self.tid, result)        # is serialized properly.        rindb = self.tb.get_result(self.tid)        self.assertEqual(rindb.get('foo'), 'baz')        self.assertEqual(rindb.get('bar').data, 12345)    def test_mark_as_failure(self):        try:            raise KeyError('foo')        except KeyError as exception:            self.tb.mark_as_failure(self.tid, exception)            self.assertEqual(self.tb.get_status(self.tid), states.FAILURE)            self.assertIsInstance(self.tb.get_result(self.tid), KeyError)    def test_apply_chord(self):        tb = CacheBackend(backend='memory://', app=self.app)        gid, res = uuid(), [self.app.AsyncResult(uuid()) for _ in range(3)]        tb.apply_chord(group(app=self.app), (), gid, {}, result=res)    @patch('celery.result.GroupResult.restore')    def test_on_chord_part_return(self, restore):        tb = CacheBackend(backend='memory://', app=self.app)        deps = Mock()        deps.__len__ = Mock()        deps.__len__.return_value = 2        restore.return_value = deps        task = Mock()        task.name = 'foobarbaz'        self.app.tasks['foobarbaz'] = task        task.request.chord = signature(task)        gid, res = uuid(), [self.app.AsyncResult(uuid()) for _ in range(3)]        task.request.group = gid        tb.apply_chord(group(app=self.app), (), gid, {}, result=res)        self.assertFalse(deps.join_native.called)        tb.on_chord_part_return(task)        self.assertFalse(deps.join_native.called)        tb.on_chord_part_return(task)        deps.join_native.assert_called_with(propagate=True)        deps.delete.assert_called_with()    def test_mget(self):        self.tb.set('foo', 1)        self.tb.set('bar', 2)        self.assertDictEqual(self.tb.mget(['foo', 'bar']),                             {'foo': 1, 'bar': 2})    def test_forget(self):        self.tb.mark_as_done(self.tid, {'foo': 'bar'})        x = self.app.AsyncResult(self.tid, backend=self.tb)        x.forget()        self.assertIsNone(x.result)    def test_process_cleanup(self):        self.tb.process_cleanup()    def test_expires_as_int(self):        tb = CacheBackend(backend='memory://', expires=10, app=self.app)        self.assertEqual(tb.expires, 10)    def test_unknown_backend_raises_ImproperlyConfigured(self):        with self.assertRaises(ImproperlyConfigured):            CacheBackend(backend='unknown://', app=self.app)class MyMemcachedStringEncodingError(Exception):    passclass MemcachedClient(DummyClient):    def set(self, key, value, *args, **kwargs):        if PY3:            key_t, must_be, not_be, cod = bytes, 'string', 'bytes', 'decode'        else:            key_t, must_be, not_be, cod = text_t, 'bytes', 'string', 'encode'        if isinstance(key, key_t):            raise MyMemcachedStringEncodingError(                'Keys must be {0}, not {1}.  Convert your '                'strings using mystring.{2}(charset)!'.format(                    must_be, not_be, cod))        return super(MemcachedClient, self).set(key, value, *args, **kwargs)class MockCacheMixin(object):    @contextmanager    def mock_memcache(self):        memcache = types.ModuleType('memcache')        memcache.Client = MemcachedClient        memcache.Client.__module__ = memcache.__name__        prev, sys.modules['memcache'] = sys.modules.get('memcache'), memcache        try:            yield True        finally:            if prev is not None:                sys.modules['memcache'] = prev    @contextmanager    def mock_pylibmc(self):        pylibmc = types.ModuleType('pylibmc')        pylibmc.Client = MemcachedClient        pylibmc.Client.__module__ = pylibmc.__name__        prev = sys.modules.get('pylibmc')        sys.modules['pylibmc'] = pylibmc        try:            yield True        finally:            if prev is not None:                sys.modules['pylibmc'] = prevclass test_get_best_memcache(AppCase, MockCacheMixin):    def test_pylibmc(self):        with self.mock_pylibmc():            with reset_modules('celery.backends.cache'):                from celery.backends import cache                cache._imp = [None]                self.assertEqual(cache.get_best_memcache()[0].__module__,                                 'pylibmc')    def test_memcache(self):        with self.mock_memcache():            with reset_modules('celery.backends.cache'):                with mask_modules('pylibmc'):                    from celery.backends import cache                    cache._imp = [None]                    self.assertEqual(cache.get_best_memcache()[0]().__module__,                                     'memcache')    def test_no_implementations(self):        with mask_modules('pylibmc', 'memcache'):            with reset_modules('celery.backends.cache'):                from celery.backends import cache                cache._imp = [None]                with self.assertRaises(ImproperlyConfigured):                    cache.get_best_memcache()    def test_cached(self):        with self.mock_pylibmc():            with reset_modules('celery.backends.cache'):                from celery.backends import cache                cache._imp = [None]                cache.get_best_memcache()[0](behaviors={'foo': 'bar'})                self.assertTrue(cache._imp[0])                cache.get_best_memcache()[0]()    def test_backends(self):        from celery.backends.cache import backends        with self.mock_memcache():            for name, fun in items(backends):                self.assertTrue(fun())class test_memcache_key(AppCase, MockCacheMixin):    def test_memcache_unicode_key(self):        with self.mock_memcache():            with reset_modules('celery.backends.cache'):                with mask_modules('pylibmc'):                    from celery.backends import cache                    cache._imp = [None]                    task_id, result = string(uuid()), 42                    b = cache.CacheBackend(backend='memcache', app=self.app)                    b.store_result(task_id, result, status=states.SUCCESS)                    self.assertEqual(b.get_result(task_id), result)    def test_memcache_bytes_key(self):        with self.mock_memcache():            with reset_modules('celery.backends.cache'):                with mask_modules('pylibmc'):                    from celery.backends import cache                    cache._imp = [None]                    task_id, result = str_to_bytes(uuid()), 42                    b = cache.CacheBackend(backend='memcache', app=self.app)                    b.store_result(task_id, result, status=states.SUCCESS)                    self.assertEqual(b.get_result(task_id), result)    def test_pylibmc_unicode_key(self):        with reset_modules('celery.backends.cache'):            with self.mock_pylibmc():                from celery.backends import cache                cache._imp = [None]                task_id, result = string(uuid()), 42                b = cache.CacheBackend(backend='memcache', app=self.app)                b.store_result(task_id, result, status=states.SUCCESS)                self.assertEqual(b.get_result(task_id), result)    def test_pylibmc_bytes_key(self):        with reset_modules('celery.backends.cache'):            with self.mock_pylibmc():                from celery.backends import cache                cache._imp = [None]                task_id, result = str_to_bytes(uuid()), 42                b = cache.CacheBackend(backend='memcache', app=self.app)                b.store_result(task_id, result, status=states.SUCCESS)                self.assertEqual(b.get_result(task_id), result)
 |