task.py 8.6 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271
  1. from carrot.connection import DjangoAMQPConnection
  2. from celery.log import setup_logger
  3. from celery.conf import TASK_META_USE_DB
  4. from celery.registry import tasks
  5. from celery.messaging import TaskPublisher, TaskConsumer
  6. from celery.models import TaskMeta
  7. from django.core.cache import cache
  8. from datetime import timedelta
  9. import uuid
  10. import traceback
  11. def delay_task(task_name, *args, **kwargs):
  12. """Delay a task for execution by the ``celery`` daemon.
  13. Examples
  14. --------
  15. >>> delay_task("update_record", name="George Constanza", age=32)
  16. """
  17. if task_name not in tasks:
  18. raise tasks.NotRegistered(
  19. "Task with name %s not registered in the task registry." % (
  20. task_name))
  21. publisher = TaskPublisher(connection=DjangoAMQPConnection)
  22. task_id = publisher.delay_task(task_name, *args, **kwargs)
  23. publisher.close()
  24. return task_id
  25. def discard_all():
  26. """Discard all waiting tasks.
  27. This will ignore all tasks waiting for execution, and they will
  28. be deleted from the messaging server.
  29. Returns the number of tasks discarded.
  30. """
  31. consumer = TaskConsumer(connection=DjangoAMQPConnection)
  32. discarded_count = consumer.discard_all()
  33. consumer.close()
  34. return discarded_count
  35. def gen_task_done_cache_key(task_id):
  36. """Generate a cache key for marking a task as done."""
  37. return "celery-task-done-marker-%s" % task_id
  38. def mark_as_done(task_id, result):
  39. """Mark task as done (executed).
  40. if ``settings.TASK_META_USE_DB`` is ``True``, this will
  41. use the :class:`celery.models.TaskMeta` model, if not memcached
  42. is used.
  43. """
  44. if result is None:
  45. result = True
  46. if TASK_META_USE_DB:
  47. TaskMeta.objects.mark_as_done(task_id)
  48. else:
  49. cache_key = gen_task_done_cache_key(task_id)
  50. cache.set(cache_key, result)
  51. def is_done(task_id):
  52. """Returns ``True`` if task with ``task_id`` has been executed."""
  53. if TASK_META_USE_DB:
  54. return TaskMeta.objects.is_done(task_id)
  55. else:
  56. cache_key = gen_task_done_cache_key(task_id)
  57. return bool(cache.get(cache_key))
  58. class Task(object):
  59. """A task that can be delayed for execution by the ``celery`` daemon.
  60. All subclasses of ``Task`` has to define the ``name`` attribute, which is
  61. the name of the task that can be passed to ``celery.task.delay_task``,
  62. it also has to define the ``run`` method, which is the actual method the
  63. ``celery`` daemon executes. This method does not support positional
  64. arguments, only keyword arguments.
  65. Examples
  66. --------
  67. This is a simple task just logging a message,
  68. >>> from celery.task import tasks, Task
  69. >>> class MyTask(Task):
  70. ... name = "mytask"
  71. ...
  72. ... def run(self, some_arg=None, **kwargs):
  73. ... logger = self.get_logger(**kwargs)
  74. ... logger.info("Running MyTask with arg some_arg=%s" %
  75. ... some_arg))
  76. ... tasks.register(MyTask)
  77. You can delay the task using the classmethod ``delay``...
  78. >>> MyTask.delay(some_arg="foo")
  79. ...or using the ``celery.task.delay_task`` function, by passing the
  80. name of the task.
  81. >>> from celery.task import delay_task
  82. >>> delay_task(MyTask.name, some_arg="foo")
  83. """
  84. name = None
  85. type = "regular"
  86. def __init__(self):
  87. if not self.name:
  88. raise NotImplementedError("Tasks must define a name attribute.")
  89. def __call__(self, *args, **kwargs):
  90. """The ``__call__`` is called when you do ``Task().run()`` and calls
  91. the ``run`` method. It also catches any exceptions and logs them."""
  92. try:
  93. retval = self.run(*args, **kwargs)
  94. except Exception, e:
  95. logger = self.get_logger(**kwargs)
  96. logger.critical("Task got exception %s: %s\n%s" % (
  97. e.__class__, e, traceback.format_exc()))
  98. return
  99. else:
  100. return retval
  101. def run(self, *args, **kwargs):
  102. """The actual task. All subclasses of :class:`Task` must define
  103. the run method, if not a ``NotImplementedError`` exception is raised.
  104. """
  105. raise NotImplementedError("Tasks must define a run method.")
  106. def get_logger(self, **kwargs):
  107. """Get a process-aware logger object."""
  108. return setup_logger(**kwargs)
  109. def get_publisher(self):
  110. """Get a celery task message publisher."""
  111. return TaskPublisher(connection=DjangoAMQPConnection)
  112. def get_consumer(self):
  113. """Get a celery task message consumer."""
  114. return TaskConsumer(connection=DjangoAMQPConnection)
  115. @classmethod
  116. def delay(cls, *args, **kwargs):
  117. """Delay this task for execution by the ``celery`` daemon(s)."""
  118. return delay_task(cls.name, *args, **kwargs)
  119. class TaskSet(object):
  120. """A task containing several subtasks, making it possible
  121. to track how many, or when all of the tasks are completed.
  122. Example Usage
  123. --------------
  124. >>> from djangofeeds.tasks import RefreshFeedTask
  125. >>> taskset = TaskSet(RefreshFeedTask, args=[
  126. ... {"feed_url": "http://cnn.com/rss"},
  127. ... {"feed_url": "http://bbc.com/rss"},
  128. ... {"feed_url": "http://xkcd.com/rss"}])
  129. >>> taskset_id, subtask_ids = taskset.run()
  130. """
  131. def __init__(self, task, args):
  132. """``task`` can be either a fully qualified task name, or a task
  133. class, args is a list of arguments for the subtasks.
  134. """
  135. try:
  136. task_name = task.name
  137. except AttributeError:
  138. task_name = task
  139. self.task_name = task_name
  140. self.arguments = args
  141. self.total = len(args)
  142. def run(self):
  143. """Run all tasks in the taskset.
  144. Returns a tuple with the taskset id, and a list of subtask id's.
  145. Examples
  146. --------
  147. >>> ts = RefreshFeeds(["http://foo.com/rss", http://bar.com/rss"])
  148. >>> taskset_id, subtask_ids = ts.run()
  149. >>> taskset_id
  150. "d2c9b261-8eff-4bfb-8459-1e1b72063514"
  151. >>> subtask_ids
  152. ["b4996460-d959-49c8-aeb9-39c530dcde25",
  153. "598d2d18-ab86-45ca-8b4f-0779f5d6a3cb"]
  154. >>> time.sleep(10)
  155. >>> is_done(taskset_id)
  156. True
  157. """
  158. taskset_id = str(uuid.uuid4())
  159. publisher = TaskPublisher(connection=DjangoAMQPConnection)
  160. subtask_ids = []
  161. for arg in self.arguments:
  162. subtask_id = publisher.delay_task_in_set(task_name=self.task_name,
  163. taskset_id=taskset_id,
  164. task_args=[],
  165. task_kwargs=arg)
  166. subtask_ids.append(subtask_id)
  167. publisher.close()
  168. return taskset_id, subtask_ids
  169. class PeriodicTask(Task):
  170. """A periodic task is a task that behaves like a cron job.
  171. The ``run_every`` attribute defines how often the task is run (its
  172. interval), it can be either a ``datetime.timedelta`` object or a integer
  173. specifying the time in seconds.
  174. You have to register the periodic task in the task registry.
  175. Examples
  176. --------
  177. >>> from celery.task import tasks, PeriodicTask
  178. >>> from datetime import timedelta
  179. >>> class MyPeriodicTask(PeriodicTask):
  180. ... name = "my_periodic_task"
  181. ... run_every = timedelta(seconds=30)
  182. ...
  183. ... def run(self, **kwargs):
  184. ... logger = self.get_logger(**kwargs)
  185. ... logger.info("Running MyPeriodicTask")
  186. >>> tasks.register(MyPeriodicTask)
  187. """
  188. run_every = timedelta(days=1)
  189. type = "periodic"
  190. def __init__(self):
  191. if not self.run_every:
  192. raise NotImplementedError(
  193. "Periodic tasks must have a run_every attribute")
  194. # If run_every is a integer, convert it to timedelta seconds.
  195. if isinstance(self.run_every, int):
  196. self.run_every = timedelta(seconds=self.run_every)
  197. super(PeriodicTask, self).__init__()
  198. class DeleteExpiredTaskMetaTask(PeriodicTask):
  199. """A periodic task that deletes expired task metadata every day.
  200. It's only registered if ``settings.CELERY_TASK_META_USE_DB`` is set.
  201. """
  202. name = "celery.delete_expired_task_meta"
  203. run_every = timedelta(days=1)
  204. def run(self, **kwargs):
  205. logger = self.get_logger(**kwargs)
  206. logger.info("Deleting expired task meta objects...")
  207. TaskMeta.objects.delete_expired()
  208. if TASK_META_USE_DB:
  209. tasks.register(DeleteExpiredTaskMetaTask)