Browse Source

[docs] Use sphinxcontrib-cheeseshop

Ask Solem 9 years ago
parent
commit
6474e7e50a

+ 1 - 1
celery/backends/cassandra.py

@@ -75,7 +75,7 @@ class CassandraBackend(BaseBackend):
     """Cassandra backend utilizing DataStax driver
 
     :raises celery.exceptions.ImproperlyConfigured: if
-        module :mod:`cassandra` is not available.
+        module :pypi:`cassandra-driver` is not available.
 
     """
 

+ 1 - 1
celery/backends/couchbase.py

@@ -31,7 +31,7 @@ class CouchBaseBackend(KeyValueStoreBackend):
     """CouchBase backend.
 
     :raises celery.exceptions.ImproperlyConfigured: if
-        module :mod:`couchbase` is not available.
+        module :pypi:`couchbase` is not available.
 
     """
     bucket = 'default'

+ 1 - 1
celery/backends/couchdb.py

@@ -30,7 +30,7 @@ class CouchBackend(KeyValueStoreBackend):
     """CouchDB backend.
 
     :raises celery.exceptions.ImproperlyConfigured: if
-        module :mod:`pycouchdb` is not available.
+        module :pypi:`pycouchdb` is not available.
 
     """
     container = 'default'

+ 1 - 1
celery/backends/elasticsearch.py

@@ -33,7 +33,7 @@ class ElasticsearchBackend(KeyValueStoreBackend):
     """Elasticsearch Backend.
 
     :raises celery.exceptions.ImproperlyConfigured: if
-        module :mod:`elasticsearch` is not available.
+        module :pypi:`elasticsearch` is not available.
 
     """
 

+ 1 - 1
celery/backends/mongodb.py

@@ -43,7 +43,7 @@ class MongoBackend(BaseBackend):
     """MongoDB result backend.
 
     :raises celery.exceptions.ImproperlyConfigured: if
-        module :mod:`pymongo` is not available.
+        module :pypi:`pymongo` is not available.
 
     """
 

+ 1 - 1
celery/backends/riak.py

@@ -53,7 +53,7 @@ class RiakBackend(KeyValueStoreBackend):
     """Riak result backend.
 
     :raises celery.exceptions.ImproperlyConfigured: if
-        module :mod:`riak` is not available.
+        module :pypi:`riak` is not available.
 
     """
     # TODO: allow using other protocols than protobuf ?

+ 2 - 2
celery/platforms.py

@@ -684,7 +684,7 @@ def strargv(argv):
 def set_process_title(progname, info=None):
     """Set the ps name for the currently running process.
 
-    Only works if :mod:`setproctitle` is installed.
+    Only works if :pypi:`setproctitle` is installed.
 
     """
     proctitle = '[{0}]'.format(progname)
@@ -703,7 +703,7 @@ else:
     def set_mp_process_title(progname, info=None, hostname=None):  # noqa
         """Set the ps name using the multiprocessing process name.
 
-        Only works if :mod:`setproctitle` is installed.
+        Only works if :pypi:`setproctitle` is installed.
 
         """
         if hostname:

+ 1 - 1
celery/utils/debug.py

@@ -153,7 +153,7 @@ def mem_rss():
 
 def ps():  # pragma: no cover
     """Return the global :class:`psutil.Process` instance,
-    or :const:`None` if :mod:`psutil` is not installed."""
+    or :const:`None` if :pypi:`psutil` is not installed."""
     global _process
     if _process is None and Process is not None:
         _process = Process(os.getpid())

+ 1 - 0
docs/conf.py

@@ -21,6 +21,7 @@ extensions = ['sphinx.ext.autodoc',
               'sphinx.ext.viewcode',
               'sphinx.ext.coverage',
               'sphinx.ext.intersphinx',
+              'sphinxcontrib.cheeseshop',
               'celery.contrib.sphinx',
               'githubsphinx',
               'celerydocs']

+ 8 - 8
docs/configuration.rst

@@ -789,7 +789,7 @@ Configuring the backend URL
 
 .. note::
 
-    The Redis backend requires the :mod:`redis` library:
+    The Redis backend requires the :pypi:`redis` library:
     http://pypi.python.org/pypi/redis/
 
     To install the redis package use `pip` or `easy_install`:
@@ -855,7 +855,7 @@ MongoDB backend settings
 
 .. note::
 
-    The MongoDB backend requires the :mod:`pymongo` library:
+    The MongoDB backend requires the :pypi:`pymongo` library:
     https://github.com/mongodb/mongo-python-driver/tree/master
 
 .. setting:: mongodb_backend_settings
@@ -882,7 +882,7 @@ This is a dict supporting the following keys:
 * options
 
     Additional keyword arguments to pass to the mongodb connection
-    constructor.  See the :mod:`pymongo` docs to see a list of arguments
+    constructor.  See the :pypi:`pymongo` docs to see a list of arguments
     supported.
 
 .. _example-mongodb-result-config:
@@ -905,7 +905,7 @@ cassandra backend settings
 
 .. note::
 
-    This Cassandra backend driver requires :mod:`cassandra-driver`.
+    This Cassandra backend driver requires :pypi:`cassandra-driver`.
     https://pypi.python.org/pypi/cassandra-driver
 
     To install, use `pip` or `easy_install`:
@@ -1029,7 +1029,7 @@ Riak backend settings
 
 .. note::
 
-    The Riak backend requires the :mod:`riak` library:
+    The Riak backend requires the :pypi:`riak` library:
     http://pypi.python.org/pypi/riak/
 
     To install the riak package use `pip` or `easy_install`:
@@ -1095,7 +1095,7 @@ IronCache backend settings
 
 .. note::
 
-    The IronCache backend requires the :mod:`iron_celery` library:
+    The IronCache backend requires the :pypi:`iron_celery` library:
     http://pypi.python.org/pypi/iron_celery
 
     To install the iron_celery package use `pip` or `easy_install`:
@@ -1121,7 +1121,7 @@ Couchbase backend settings
 
 .. note::
 
-    The Couchbase backend requires the :mod:`couchbase` library:
+    The Couchbase backend requires the :pypi:`couchbase` library:
     https://pypi.python.org/pypi/couchbase
 
     To install the couchbase package use `pip` or `easy_install`:
@@ -1165,7 +1165,7 @@ CouchDB backend settings
 
 .. note::
 
-    The CouchDB backend requires the :mod:`pycouchdb` library:
+    The CouchDB backend requires the :pypi:`pycouchdb` library:
     https://pypi.python.org/pypi/pycouchdb
 
     To install the couchbase package use `pip` or `easy_install`:

+ 3 - 3
docs/contributing.rst

@@ -516,9 +516,9 @@ the steps outlined here: http://bit.ly/koJoso
 Calculating test coverage
 ~~~~~~~~~~~~~~~~~~~~~~~~~
 
-To calculate test coverage you must first install the :mod:`coverage` module.
+To calculate test coverage you must first install the :pypi:`coverage` module.
 
-Installing the :mod:`coverage` module:
+Installing the :pypi:`coverage` module:
 
 .. code-block:: console
 
@@ -1047,7 +1047,7 @@ Deprecated
 
 - pylibrabbitmq
 
-Old name for :mod:`librabbitmq`.
+Old name for :pypi:`librabbitmq`.
 
 :git: :const:`None`
 :PyPI: http://pypi.python.org/pypi/pylibrabbitmq

+ 1 - 1
docs/getting-started/introduction.rst

@@ -102,7 +102,7 @@ Celery is…
 
         A single Celery process can process millions of tasks a minute,
         with sub-millisecond round-trip latency (using RabbitMQ,
-        py-librabbitmq, and optimized settings).
+        librabbitmq, and optimized settings).
 
     - **Flexible**
 

+ 1 - 1
docs/getting-started/next-steps.rst

@@ -749,7 +749,7 @@ If you have strict fair scheduling requirements, or want to optimize
 for throughput then you should read the :ref:`Optimizing Guide
 <guide-optimizing>`.
 
-If you're using RabbitMQ then you should install the :mod:`librabbitmq`
+If you're using RabbitMQ then you should install the :pypi:`librabbitmq`
 module, which is an AMQP client implemented in C:
 
 .. code-block:: console

+ 2 - 2
docs/history/changelog-1.0.rst

@@ -52,7 +52,7 @@ Critical
 
     See issue #122.
 
-* Now depends on :mod:`billiard` >= 0.3.1
+* Now depends on :pypi:`billiard` >= 0.3.1
 
 * worker: Previously exceptions raised by worker components could stall startup,
   now it correctly logs the exceptions and shuts down.
@@ -922,7 +922,7 @@ Changes
   a task type. See :mod:`celery.task.control`.
 
 * The services now sets informative process names (as shown in `ps`
-  listings) if the :mod:`setproctitle` module is installed.
+  listings) if the :pypi:`setproctitle` module is installed.
 
 * :exc:`~@NotRegistered` now inherits from :exc:`KeyError`,
   and `TaskRegistry.__getitem__`+`pop` raises `NotRegistered` instead

+ 5 - 5
docs/history/changelog-2.0.rst

@@ -25,7 +25,7 @@ Fixes
 * Worker: Events are now buffered if the connection is down,
   then sent when the connection is re-established.
 
-* No longer depends on the :mod:`mailer` package.
+* No longer depends on the :pypi:`mailer` package.
 
     This package had a name space collision with `django-mailer`,
     so its functionality was replaced.
@@ -666,7 +666,7 @@ News
 
 * Worker: Standard out/error is now being redirected to the log file.
 
-* :mod:`billiard` has been moved back to the celery repository.
+* :pypi:`billiard` has been moved back to the celery repository.
 
     =====================================  =====================================
     **Module name**                        **celery equivalent**
@@ -676,11 +676,11 @@ News
     `billiard.utils.functional`            `celery.utils.functional`
     =====================================  =====================================
 
-    The :mod:`billiard` distribution may be maintained, depending on interest.
+    The :pypi:`billiard` distribution may be maintained, depending on interest.
 
-* now depends on :mod:`carrot` >= 0.10.5
+* now depends on :pypi:`carrot` >= 0.10.5
 
-* now depends on :mod:`pyparsing`
+* now depends on :pypi:`pyparsing`
 
 * Worker: Added `--purge` as an alias to `--discard`.
 

+ 1 - 1
docs/history/changelog-2.4.rst

@@ -263,7 +263,7 @@ Important Notes
 News
 ----
 
-* No longer depends on :mod:`pyparsing`.
+* No longer depends on :pypi:`pyparsing`.
 
 * Now depends on Kombu 1.4.3.
 

+ 12 - 12
docs/history/changelog-3.0.rst

@@ -18,7 +18,7 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
 
 - Now depends on :ref:`Kombu 2.5.15 <kombu:version-2.5.15>`.
 
-- Now depends on :mod:`billiard` version 2.7.3.34.
+- Now depends on :pypi:`billiard` version 2.7.3.34.
 
 - AMQP Result backend:  No longer caches queue declarations.
 
@@ -109,7 +109,7 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
 
 - Now depends on :ref:`Kombu 2.5.13 <kombu:version-2.5.13>`.
 
-- Now depends on :mod:`billiard` 2.7.3.32
+- Now depends on :pypi:`billiard` 2.7.3.32
 
 - Fixed bug with monthly and yearly crontabs (Issue #1465).
 
@@ -132,7 +132,7 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
 :release-date: 2013-07-05 04:30 P.M BST
 :release-by: Ask Solem
 
-- Now depends on :mod:`billiard` 2.7.3.31.
+- Now depends on :pypi:`billiard` 2.7.3.31.
 
     This version fixed a bug when running without the billiard C extension.
 
@@ -156,7 +156,7 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
 
 - Now depends on :ref:`Kombu 2.5.12 <kombu:version-2.5.12>`.
 
-- Now depends on :mod:`billiard` 2.7.3.30.
+- Now depends on :pypi:`billiard` 2.7.3.30.
 
 - ``--loader`` argument no longer supported importing loaders from the
   current directory.
@@ -219,7 +219,7 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
 :release-date: 2013-04-17 04:30:00 P.M BST
 :release-by: Ask Solem
 
-- Now depends on :mod:`billiard` 2.7.3.28
+- Now depends on :pypi:`billiard` 2.7.3.28
 
 - A Python 3 related fix managed to disable the deadlock fix
   announced in 3.0.18.
@@ -260,11 +260,11 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
 :release-date: 2013-04-12 05:00:00 P.M BST
 :release-by: Ask Solem
 
-- Now depends on :mod:`kombu` 2.5.10.
+- Now depends on :pypi:`kombu` 2.5.10.
 
     See the :ref:`kombu changelog <kombu:version-2.5.10>`.
 
-- Now depends on :mod:`billiard` 2.7.3.27.
+- Now depends on :pypi:`billiard` 2.7.3.27.
 
 - Can now specify a whitelist of accepted serializers using
   the new :setting:`CELERY_ACCEPT_CONTENT` setting.
@@ -457,9 +457,9 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
      - Girls Who Code — http://www.girlswhocode.com
      - Women Who Code — http://www.meetup.com/Women-Who-Code-SF/
 
-- Now depends on :mod:`kombu` version 2.5.7
+- Now depends on :pypi:`kombu` version 2.5.7
 
-- Now depends on :mod:`billiard` version 2.7.3.22
+- Now depends on :pypi:`billiard` version 2.7.3.22
 
 - AMQP heartbeats are now disabled by default.
 
@@ -780,7 +780,7 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
 
     Contributed by Craig Younkins.
 
-- Fixed problem when using earlier versions of :mod:`pytz`.
+- Fixed problem when using earlier versions of :pypi:`pytz`.
 
     Fix contributed by Vlad.
 
@@ -1145,7 +1145,7 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
     or occasionally a ``Framing error`` exception appearing.
 
     Users of the new ``pyamqp://`` transport must upgrade to
-    :mod:`amqp` 0.9.3.
+    :pypi:`amqp` 0.9.3.
 
 - Beat: Fixed another timezone bug with interval and crontab schedules
   (Issue #943).
@@ -1348,7 +1348,7 @@ If you're looking for versions prior to 3.0.x you should go to :ref:`history`.
 
 - Now supports AMQP heartbeats if using the new ``pyamqp://`` transport.
 
-    - The py-amqp transport requires the :mod:`amqp` library to be installed::
+    - The py-amqp transport requires the :pypi:`amqp` library to be installed::
 
         $ pip install amqp
 

+ 1 - 1
docs/internals/deprecation.rst

@@ -212,4 +212,4 @@ Removals for version 2.0
 * :meth:`TaskSet.run`. Use :meth:`celery.task.base.TaskSet.apply_async`
     instead.
 
-* The module :mod:`celery.task.rest`; use :mod:`celery.task.httpY` instead.
+* The module :mod:`celery.task.rest`; use :mod:`celery.task.http` instead.

+ 1 - 1
docs/userguide/calling.rst

@@ -332,7 +332,7 @@ Each option has its advantages and disadvantages.
 
 json -- JSON is supported in many programming languages, is now
     a standard part of Python (since 2.6), and is fairly fast to decode
-    using the modern Python libraries such as :mod:`cjson` or :mod:`simplejson`.
+    using the modern Python libraries such as :pypi:`simplejson`.
 
     The primary disadvantage to JSON is that it limits you to the following
     data types: strings, Unicode, floats, boolean, dictionaries, and lists.

+ 10 - 10
docs/userguide/optimizing.rst

@@ -58,7 +58,7 @@ librabbitmq
 -----------
 
 If you're using RabbitMQ (AMQP) as the broker then you can install the
-:mod:`librabbitmq` module to use an optimized client written in C:
+:pypi:`librabbitmq` module to use an optimized client written in C:
 
 .. code-block:: console
 
@@ -246,15 +246,15 @@ worker option:
 With this option enabled the worker will only write to processes that are
 available for work, disabling the prefetch behavior::
 
--> send task T1 to process A
-# A executes T1
--> send task T2 to process B
-# B executes T2
-<- T2 complete sent by process B
+    -> send task T1 to process A
+    # A executes T1
+    -> send task T2 to process B
+    # B executes T2
+    <- T2 complete sent by process B
 
--> send T3 to process B
-# B executes T3
+    -> send T3 to process B
+    # B executes T3
 
-<- T3 complete sent by process B
-<- T1 complete sent by process A
+    <- T3 complete sent by process B
+    <- T1 complete sent by process A
 

+ 2 - 2
docs/userguide/workers.rst

@@ -753,9 +753,9 @@ implementations:
 
 * inotify (Linux)
 
-    Used if the :mod:`pyinotify` library is installed.
+    Used if the :pypi:`pyinotify` library is installed.
     If you are running on Linux this is the recommended implementation,
-    to install the :mod:`pyinotify` library you have to run the following
+    to install the :pypi:`pyinotify` library you have to run the following
     command:
 
     .. code-block:: console

+ 4 - 4
docs/whatsnew-2.5.rst

@@ -180,7 +180,7 @@ converted to UTC, and then converted back to the local timezone
 when received by a worker.
 
 You can change the local timezone using the :setting:`CELERY_TIMEZONE`
-setting.  Installing the :mod:`pytz` library is recommended when
+setting.  Installing the :pypi:`pytz` library is recommended when
 using a custom timezone, to keep timezone definition up-to-date,
 but it will fallback to a system definition of the timezone if available.
 
@@ -235,9 +235,9 @@ implementations:
 
 * inotify (Linux)
 
-    Used if the :mod:`pyinotify` library is installed.
+    Used if the :pypi:`pyinotify` library is installed.
     If you are running on Linux this is the recommended implementation,
-    to install the :mod:`pyinotify` library you have to run the following
+    to install the :pypi:`pyinotify` library you have to run the following
     command:
 
     .. code-block:: console
@@ -529,7 +529,7 @@ Fixes
 
 
 - Cassandra backend: No longer uses :func:`pycassa.connect` which is
-  deprecated since :mod:`pycassa` 1.4.
+  deprecated since :pypi:`pycassa` 1.4.
 
     Fix contributed by Jeff Terrace.
 

+ 5 - 5
docs/whatsnew-3.0.rst

@@ -57,9 +57,9 @@ Highlights
 
         Starting with Celery 3.1, Python 2.6 or later is required.
 
-    - Support for the new librabbitmq C client.
+    - Support for the new :pypi:`librabbitmq` C client.
 
-        Celery will automatically use the :mod:`librabbitmq` module
+        Celery will automatically use the :pypi:`librabbitmq` module
         if installed, which is a very fast and memory-optimized
         replacement for the py-amqp module.
 
@@ -143,8 +143,8 @@ Commands include:
 The old programs are still available (``celeryd``, ``celerybeat``, etc),
 but you are discouraged from using them.
 
-Now depends on :mod:`billiard`.
--------------------------------
+Now depends on :pypi:`billiard`.
+--------------------------------
 
 Billiard is a fork of the multiprocessing containing
 the no-execv patch by sbt (http://bugs.python.org/issue8713),
@@ -869,7 +869,7 @@ In Other News
 
 - Deprecated module ``celery.conf`` has been removed.
 
-- The :setting:`CELERY_TIMEZONE` now always require the :mod:`pytz`
+- The :setting:`CELERY_TIMEZONE` now always require the :pypi:`pytz`
   library to be installed (exept if the timezone is set to `UTC`).
 
 - The Tokyo Tyrant backend has been removed and is no longer supported.

+ 9 - 9
docs/whatsnew-3.1.rst

@@ -346,7 +346,7 @@ in :file:`examples/django`:
 
 https://github.com/celery/celery/tree/3.1/examples/django
 
-Some features still require the :mod:`django-celery` library:
+Some features still require the :pypi:`django-celery` library:
 
     - Celery does not implement the Django database or cache result backends.
     - Celery does not ship with the database-based periodic task
@@ -357,7 +357,7 @@ Some features still require the :mod:`django-celery` library:
     If you're still using the old API when you upgrade to Celery 3.1
     then you must make sure that your settings module contains
     the ``djcelery.setup_loader()`` line, since this will
-    no longer happen as a side-effect of importing the :mod:`djcelery`
+    no longer happen as a side-effect of importing the :pypi:`django-celery`
     module.
 
     New users (or if you have ported to the new API) don't need the ``setup_loader``
@@ -584,13 +584,13 @@ This setting will be the default in a future version.
 
 Related to Issue #1490.
 
-:mod:`pytz` replaces ``python-dateutil`` dependency
----------------------------------------------------
+:pypi:`pytz` replaces :pypi:`python-dateutil` dependency
+--------------------------------------------------------
 
-Celery no longer depends on the ``python-dateutil`` library,
-but instead a new dependency on the :mod:`pytz` library was added.
+Celery no longer depends on the :pypi:`python-dateutil` library,
+but instead a new dependency on the :pypi:`pytz` library was added.
 
-The :mod:`pytz` library was already recommended for accurate timezone support.
+The :pypi:`pytz` library was already recommended for accurate timezone support.
 
 This also means that dependencies are the same for both Python 2 and
 Python 3, and that the :file:`requirements/default-py3k.txt` file has
@@ -599,7 +599,7 @@ been removed.
 Support for Setuptools extra requirements
 -----------------------------------------
 
-Pip now supports the :mod:`setuptools` extra requirements format,
+Pip now supports the :pypi:`setuptools` extra requirements format,
 so we have removed the old bundles concept, and instead specify
 setuptools extras.
 
@@ -668,7 +668,7 @@ In Other News
 
 - Now depends on :ref:`Kombu 3.0 <kombu:version-3.0.0>`.
 
-- Now depends on :mod:`billiard` version 3.3.
+- Now depends on :pypi:`billiard` version 3.3.
 
 - Worker will now crash if running as the root user with pickle enabled.
 

+ 2 - 2
docs/whatsnew-4.0.rst

@@ -469,9 +469,9 @@ In Other News
 
     - Now depends on :ref:`Kombu 4.0 <kombu:version-4.0>`.
 
-    - Now depends on :mod:`billiard` version 3.5.
+    - Now depends on :pypi:`billiard` version 3.5.
 
-    - No longer depends on ``anyjson`` :sadface:
+    - No longer depends on :pypi:`anyjson` :sadface:
 
 
 - **Tasks**: The "anon-exchange" is now used for simple name-name direct routing.

+ 1 - 0
requirements/docs.txt

@@ -1,3 +1,4 @@
 Sphinx
+sphinxcontrib-cheeseshop
 -r extras/sqlalchemy.txt
 -r dev.txt