first-steps-with-django.rst 6.2 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202
  1. =========================
  2. First steps with Django
  3. =========================
  4. Configuring your Django project to use Celery
  5. =============================================
  6. You need four simple steps to use celery with your Django project.
  7. 1. Install the ``django-celery`` library:
  8. .. code-block:: bash
  9. $ pip install django-celery
  10. 2. Add the following lines to ``settings.py``:
  11. .. code-block:: python
  12. import djcelery
  13. djcelery.setup_loader()
  14. 3. Add ``djcelery`` to ``INSTALLED_APPS``.
  15. 4. Create the celery database tables.
  16. If you are using south_ for schema migrations, you'll want to:
  17. .. code-block:: bash
  18. $ python manage.py migrate djcelery
  19. For those who are not using south, a normal ``syncdb`` will work:
  20. .. code-block:: bash
  21. $ python manage.py syncdb
  22. .. _south: http://pypi.python.org/pypi/South/
  23. By default Celery uses `RabbitMQ`_ as the broker, but there are several
  24. alternatives to choose from, see :ref:`celerytut-broker`.
  25. All settings mentioned in the Celery documentation should be added
  26. to your Django project's ``settings.py`` module. For example
  27. you can configure the :setting:`BROKER_URL` setting to specify
  28. what broker to use::
  29. BROKER_URL = 'amqp://guest:guest@localhost:5672/'
  30. That's it.
  31. .. _`RabbitMQ`: http://www.rabbitmq.com/
  32. Special note for mod_wsgi users
  33. -------------------------------
  34. If you're using ``mod_wsgi`` to deploy your Django application you need to
  35. include the following in your ``.wsgi`` module::
  36. import djcelery
  37. djcelery.setup_loader()
  38. Defining and calling tasks
  39. ==========================
  40. Tasks are defined by wrapping functions in the ``@task`` decorator.
  41. It is a common practice to put these in their own module named ``tasks.py``,
  42. and the worker will automatically go through the apps in ``INSTALLED_APPS``
  43. to import these modules.
  44. For a simple demonstration create a new Django app called
  45. ``celerytest``. To create this app you need to be in the directory
  46. of your Django project where ``manage.py`` is located and execute:
  47. .. code-block:: bash
  48. $ python manage.py startapp celerytest
  49. Next you have to add the new app to ``INSTALLED_APPS`` so that your
  50. Django project recognizes it. This setting is a tuple/list so just
  51. append ``celerytest`` as a new element at the end
  52. .. code-block:: python
  53. INSTALLED_APPS = (
  54. ...,
  55. 'djcelery',
  56. 'celerytest',
  57. )
  58. After the new app has been created and added to ``INSTALLED_APPS``,
  59. you can define your tasks by creating a new file called ``celerytest/tasks.py``:
  60. .. code-block:: python
  61. from celery import task
  62. @task()
  63. def add(x, y):
  64. return x + y
  65. Our example task is pretty pointless, it just returns the sum of two
  66. arguments, but it will do for demonstration, and it is referred to in many
  67. parts of the Celery documentation.
  68. .. admonition:: Relative Imports
  69. You have to be consistent in how you import the task module, e.g. if
  70. you have ``project.app`` in ``INSTALLED_APPS`` then you also
  71. need to import the tasks ``from project.app`` or else the names
  72. of the tasks will be different.
  73. See :ref:`task-naming-relative-imports`
  74. Starting the worker process
  75. ===========================
  76. In a production environment you will want to run the worker in the background
  77. as a daemon - see :ref:`daemonizing` - but for testing and
  78. development it is useful to be able to start a worker instance by using the
  79. ``celery worker`` manage command, much as you would use Django's runserver:
  80. .. code-block:: bash
  81. $ python manage.py celery worker --loglevel=info
  82. For a complete listing of the command-line options available,
  83. use the help command:
  84. .. code-block:: bash
  85. $ python manage.py celery help
  86. Calling our task
  87. ================
  88. Now that the worker is running, open up a new python interactive shell
  89. with ``python manage.py shell`` to actually call the task you defined::
  90. >>> from celerytest.tasks import add
  91. >>> add.delay(2, 2)
  92. Note that if you open a regular python shell by simply running ``python``
  93. you will need to import your Django application's settings by running::
  94. # Replace 'myproject' with your project's name
  95. >>> from myproject import settings
  96. The ``delay`` method used above is a handy shortcut to the ``apply_async``
  97. method which enables you to have greater control of the task execution.
  98. To read more about calling tasks, including specifying the time at which
  99. the task should be processed see :ref:`guide-calling`.
  100. .. note::
  101. Tasks need to be stored in a real module, they can't
  102. be defined in the python shell or IPython/bpython. This is because the
  103. worker server must be able to import the task function.
  104. The task should now be processed by the worker you started earlier,
  105. and you can verify that by looking at the worker's console output.
  106. Calling a task returns an :class:`~celery.result.AsyncResult` instance,
  107. which can be used to check the state of the task, wait for the task to finish
  108. or get its return value (or if the task failed, the exception and traceback).
  109. By default django-celery stores this state in the Django database.
  110. You may consider choosing an alternate result backend or disabling
  111. states alltogether (see :ref:`task-result-backends`).
  112. To demonstrate how the results work call the task again, but this time
  113. keep the result instance returned::
  114. >>> result = add.delay(4, 4)
  115. >>> result.ready() # returns True if the task has finished processing.
  116. False
  117. >>> result.result # task is not ready, so no return value yet.
  118. None
  119. >>> result.get() # Waits until the task is done and returns the retval.
  120. 8
  121. >>> result.result # direct access to result, doesn't re-raise errors.
  122. 8
  123. >>> result.successful() # returns True if the task didn't end in failure.
  124. True
  125. If the task raises an exception, the return value of ``result.successful()``
  126. will be ``False``, and ``result.result`` will contain the exception instance
  127. raised by the task.
  128. Where to go from here
  129. =====================
  130. To learn more you should read the `Celery User Guide`_, and the
  131. `Celery Documentation`_ in general.
  132. .. _`Celery User Guide`: http://docs.celeryproject.org/en/latest/userguide/
  133. .. _`Celery Documentation`: http://docs.celeryproject.org/