index.rst 1.3 KB

1234567891011121314151617181920212223242526272829303132333435363738394041424344454647484950515253545556575859606162636465666768
  1. =================================
  2. Celery - Distributed Task Queue
  3. =================================
  4. Celery is a simple, flexible and reliable distributed system to
  5. process vast amounts of messages, while providing operations with
  6. the tools required to maintain such a system.
  7. It's a task queue with focus on real-time processing, while also
  8. supporting task scheduling.
  9. Celery has a large and diverse community of users and contributors,
  10. you should come join us :ref:`on IRC <irc-channel>`
  11. or :ref:`our mailing-list <mailing-list>`.
  12. Celery is Open Source and licensed under the `BSD License`_.
  13. Getting Started
  14. ===============
  15. - If you are new to Celery you can get started by following
  16. the :ref:`first-steps` tutorial.
  17. - You can also check out the :ref:`FAQ <faq>`.
  18. .. _`BSD License`: http://www.opensource.org/licenses/BSD-3-Clause
  19. Contents
  20. ========
  21. .. toctree::
  22. :maxdepth: 1
  23. copyright
  24. .. toctree::
  25. :maxdepth: 2
  26. getting-started/index
  27. userguide/index
  28. .. toctree::
  29. :maxdepth: 1
  30. configuration
  31. django/index
  32. contributing
  33. community
  34. tutorials/index
  35. faq
  36. changelog
  37. whatsnew-4.0
  38. whatsnew-3.1
  39. whatsnew-3.0
  40. whatsnew-2.5
  41. reference/index
  42. internals/index
  43. history/index
  44. glossary
  45. Indices and tables
  46. ==================
  47. * :ref:`genindex`
  48. * :ref:`modindex`
  49. * :ref:`search`