batches.py 6.9 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243
  1. # -*- coding: utf-8 -*-
  2. """
  3. celery.contrib.batches
  4. ======================
  5. Experimental task class that buffers messages and processes them as a list.
  6. .. warning::
  7. For this to work you have to set
  8. :setting:`CELERYD_PREFETCH_MULTIPLIER` to zero, or some value where
  9. the final multiplied value is higher than ``flush_every``.
  10. In the future we hope to add the ability to direct batching tasks
  11. to a channel with different QoS requirements than the task channel.
  12. **Simple Example**
  13. A click counter that flushes the buffer every 100 messages, and every
  14. seconds. Does not do anything with the data, but can easily be modified
  15. to store it in a database.
  16. .. code-block:: python
  17. # Flush after 100 messages, or 10 seconds.
  18. @app.task(base=Batches, flush_every=100, flush_interval=10)
  19. def count_click(requests):
  20. from collections import Counter
  21. count = Counter(request.kwargs['url'] for request in requests)
  22. for url, count in count.items():
  23. print('>>> Clicks: %s -> %s' % (url, count))
  24. Then you can ask for a click to be counted by doing::
  25. >>> count_click.delay('http://example.com')
  26. **Example returning results**
  27. An interface to the Web of Trust API that flushes the buffer every 100
  28. messages, and every 10 seconds.
  29. .. code-block:: python
  30. import requests
  31. from urlparse import urlparse
  32. from celery.contrib.batches import Batches
  33. wot_api_target = "https://api.mywot.com/0.4/public_link_json"
  34. @app.task(base=Batches, flush_every=100, flush_interval=10)
  35. def wot_api(requests):
  36. sig = lambda url: url
  37. reponses = wot_api_real(
  38. (sig(*request.args, **request.kwargs) for request in requests)
  39. )
  40. # use mark_as_done to manually return response data
  41. for response, request in zip(reponses, requests):
  42. app.backend.mark_as_done(request.id, response)
  43. def wot_api_real(urls):
  44. domains = [urlparse(url).netloc for url in urls]
  45. response = requests.get(
  46. wot_api_target,
  47. params={"hosts": ('/').join(set(domains)) + '/'}
  48. )
  49. return [response.json[domain] for domain in domains]
  50. Using the API is done as follows::
  51. >>> wot_api.delay('http://example.com')
  52. .. note::
  53. If you don't have an ``app`` instance then use the current app proxy
  54. instead::
  55. from celery import current_app
  56. app.backend.mark_as_done(request.id, response)
  57. """
  58. from __future__ import absolute_import
  59. from itertools import count
  60. from Queue import Empty, Queue
  61. from celery.task import Task
  62. from celery.utils.log import get_logger
  63. from celery.worker.job import Request
  64. from celery.utils import noop
  65. logger = get_logger(__name__)
  66. def consume_queue(queue):
  67. """Iterator yielding all immediately available items in a
  68. :class:`Queue.Queue`.
  69. The iterator stops as soon as the queue raises :exc:`Queue.Empty`.
  70. *Examples*
  71. >>> q = Queue()
  72. >>> map(q.put, range(4))
  73. >>> list(consume_queue(q))
  74. [0, 1, 2, 3]
  75. >>> list(consume_queue(q))
  76. []
  77. """
  78. get = queue.get_nowait
  79. while 1:
  80. try:
  81. yield get()
  82. except Empty:
  83. break
  84. def apply_batches_task(task, args, loglevel, logfile):
  85. task.push_request(loglevel=loglevel, logfile=logfile)
  86. try:
  87. result = task(*args)
  88. except Exception, exc:
  89. result = None
  90. logger.error('Error: %r', exc, exc_info=True)
  91. finally:
  92. task.pop_request()
  93. return result
  94. class SimpleRequest(object):
  95. """Pickleable request."""
  96. #: task id
  97. id = None
  98. #: task name
  99. name = None
  100. #: positional arguments
  101. args = ()
  102. #: keyword arguments
  103. kwargs = {}
  104. #: message delivery information.
  105. delivery_info = None
  106. #: worker node name
  107. hostname = None
  108. def __init__(self, id, name, args, kwargs, delivery_info, hostname):
  109. self.id = id
  110. self.name = name
  111. self.args = args
  112. self.kwargs = kwargs
  113. self.delivery_info = delivery_info
  114. self.hostname = hostname
  115. @classmethod
  116. def from_request(cls, request):
  117. return cls(request.id, request.name, request.args,
  118. request.kwargs, request.delivery_info, request.hostname)
  119. class Batches(Task):
  120. abstract = True
  121. #: Maximum number of message in buffer.
  122. flush_every = 10
  123. #: Timeout in seconds before buffer is flushed anyway.
  124. flush_interval = 30
  125. def __init__(self):
  126. self._buffer = Queue()
  127. self._count = count(1).next
  128. self._tref = None
  129. self._pool = None
  130. def run(self, requests):
  131. raise NotImplementedError('%r must implement run(requests)' % (self, ))
  132. def Strategy(self, task, app, consumer):
  133. self._pool = consumer.pool
  134. hostname = consumer.hostname
  135. eventer = consumer.event_dispatcher
  136. Req = Request
  137. connection_errors = consumer.connection_errors
  138. timer = consumer.timer
  139. put_buffer = self._buffer.put
  140. flush_buffer = self._do_flush
  141. def task_message_handler(message, body, ack):
  142. request = Req(body, on_ack=ack, app=app, hostname=hostname,
  143. events=eventer, task=task,
  144. connection_errors=connection_errors,
  145. delivery_info=message.delivery_info)
  146. put_buffer(request)
  147. if self._tref is None: # first request starts flush timer.
  148. self._tref = timer.apply_interval(self.flush_interval * 1000.0,
  149. flush_buffer)
  150. if not self._count() % self.flush_every:
  151. flush_buffer()
  152. return task_message_handler
  153. def flush(self, requests):
  154. return self.apply_buffer(requests, ([SimpleRequest.from_request(r)
  155. for r in requests], ))
  156. def _do_flush(self):
  157. logger.debug('Batches: Wake-up to flush buffer...')
  158. requests = None
  159. if self._buffer.qsize():
  160. requests = list(consume_queue(self._buffer))
  161. if requests:
  162. logger.debug('Batches: Buffer complete: %s', len(requests))
  163. self.flush(requests)
  164. if not requests:
  165. logger.debug('Batches: Cancelling timer: Nothing in buffer.')
  166. self._tref.cancel() # cancel timer.
  167. self._tref = None
  168. def apply_buffer(self, requests, args=(), kwargs={}):
  169. acks_late = [], []
  170. [acks_late[r.task.acks_late].append(r) for r in requests]
  171. assert requests and (acks_late[True] or acks_late[False])
  172. def on_accepted(pid, time_accepted):
  173. [req.acknowledge() for req in acks_late[False]]
  174. def on_return(result):
  175. [req.acknowledge() for req in acks_late[True]]
  176. return self._pool.apply_async(apply_batches_task,
  177. (self, args, 0, None),
  178. accept_callback=on_accepted,
  179. callback=acks_late[True] and on_return or noop)