Browse Source

Remove whitespace [Gun.io WhitespaceBot]

Gun.io Whitespace Robot 13 years ago
parent
commit
bae2e490d4

+ 11 - 11
Changelog

@@ -1632,7 +1632,7 @@ News
     :class:`~celery.task.control.inspect`.
     :class:`~celery.task.control.inspect`.
 
 
 
 
-    Example using celeryctl to start consuming from queue "queue", in 
+    Example using celeryctl to start consuming from queue "queue", in
     exchange "exchange", of type "direct" using binding key "key"::
     exchange "exchange", of type "direct" using binding key "key"::
 
 
         $ celeryctl inspect add_consumer queue exchange direct key
         $ celeryctl inspect add_consumer queue exchange direct key
@@ -3555,7 +3555,7 @@ Fixes
   by rounding to the nearest day/hour.
   by rounding to the nearest day/hour.
 
 
 * Fixed a potential infinite loop in `BaseAsyncResult.__eq__`, although
 * Fixed a potential infinite loop in `BaseAsyncResult.__eq__`, although
-  there is no evidence that it has ever been triggered. 
+  there is no evidence that it has ever been triggered.
 
 
 * celeryd: Now handles messages with encoding problems by acking them and
 * celeryd: Now handles messages with encoding problems by acking them and
   emitting an error message.
   emitting an error message.
@@ -3618,7 +3618,7 @@ Fixes
 
 
 * Execution: `.messaging.TaskPublisher.send_task` now
 * Execution: `.messaging.TaskPublisher.send_task` now
   incorporates all the functionality apply_async previously did.
   incorporates all the functionality apply_async previously did.
-  
+
     Like converting countdowns to eta, so :func:`celery.execute.apply_async` is
     Like converting countdowns to eta, so :func:`celery.execute.apply_async` is
     now simply a convenient front-end to
     now simply a convenient front-end to
     :meth:`celery.messaging.TaskPublisher.send_task`, using
     :meth:`celery.messaging.TaskPublisher.send_task`, using
@@ -3675,7 +3675,7 @@ Fixes
     is revoked even though it's currently being hold because its eta is e.g.
     is revoked even though it's currently being hold because its eta is e.g.
     a week into the future.
     a week into the future.
 
 
-* The `task_id` argument is now respected even if the task is executed 
+* The `task_id` argument is now respected even if the task is executed
   eagerly (either using apply, or :setting:`CELERY_ALWAYS_EAGER`).
   eagerly (either using apply, or :setting:`CELERY_ALWAYS_EAGER`).
 
 
 * The internal queues are now cleared if the connection is reset.
 * The internal queues are now cleared if the connection is reset.
@@ -3947,7 +3947,7 @@ News
     ...                   ([8, 8], {}, {"countdown": 3})])
     ...                   ([8, 8], {}, {"countdown": 3})])
     >>> ts.run()
     >>> ts.run()
 
 
-* Got a 3x performance gain by setting the prefetch count to four times the 
+* Got a 3x performance gain by setting the prefetch count to four times the
   concurrency, (from an average task round-trip of 0.1s to 0.03s!).
   concurrency, (from an average task round-trip of 0.1s to 0.03s!).
 
 
     A new setting has been added: :setting:`CELERYD_PREFETCH_MULTIPLIER`, which
     A new setting has been added: :setting:`CELERYD_PREFETCH_MULTIPLIER`, which
@@ -4084,7 +4084,7 @@ Documentation
 :release-date: 2009-11-20 03:40 P.M CEST
 :release-date: 2009-11-20 03:40 P.M CEST
 
 
 * QOS Prefetch count was not applied properly, as it was set for every message
 * QOS Prefetch count was not applied properly, as it was set for every message
-  received (which apparently behaves like, "receive one more"), instead of only 
+  received (which apparently behaves like, "receive one more"), instead of only
   set when our wanted value changed.
   set when our wanted value changed.
 
 
 .. _version-0.8.1:
 .. _version-0.8.1:
@@ -4261,7 +4261,7 @@ Important changes
 
 
 * Support for multiple AMQP exchanges and queues.
 * Support for multiple AMQP exchanges and queues.
 
 
-    This feature misses documentation and tests, so anyone interested 
+    This feature misses documentation and tests, so anyone interested
     is encouraged to improve this situation.
     is encouraged to improve this situation.
 
 
 * celeryd now survives a restart of the AMQP server!
 * celeryd now survives a restart of the AMQP server!
@@ -4384,7 +4384,7 @@ News
 
 
 * Functions/methods with a timeout argument now works correctly.
 * Functions/methods with a timeout argument now works correctly.
 
 
-* New: `celery.strategy.even_time_distribution`: 
+* New: `celery.strategy.even_time_distribution`:
     With an iterator yielding task args, kwargs tuples, evenly distribute
     With an iterator yielding task args, kwargs tuples, evenly distribute
     the processing of its tasks throughout the time window available.
     the processing of its tasks throughout the time window available.
 
 
@@ -4547,7 +4547,7 @@ News
 *  Only use README as long_description if the file exists so easy_install
 *  Only use README as long_description if the file exists so easy_install
    doesn't break.
    doesn't break.
 
 
-* `celery.view`: JSON responses now properly set its mime-type. 
+* `celery.view`: JSON responses now properly set its mime-type.
 
 
 * `apply_async` now has a `connection` keyword argument so you
 * `apply_async` now has a `connection` keyword argument so you
   can re-use the same AMQP connection if you want to execute
   can re-use the same AMQP connection if you want to execute
@@ -4733,7 +4733,7 @@ arguments, so be sure to flush your task queue before you upgrade.
   version to 0.2. This is a pre-release.
   version to 0.2. This is a pre-release.
 
 
 * `celery.task.mark_as_read()` and `celery.task.mark_as_failure()` has
 * `celery.task.mark_as_read()` and `celery.task.mark_as_failure()` has
-  been removed. Use `celery.backends.default_backend.mark_as_read()`, 
+  been removed. Use `celery.backends.default_backend.mark_as_read()`,
   and `celery.backends.default_backend.mark_as_failure()` instead.
   and `celery.backends.default_backend.mark_as_failure()` instead.
 
 
 .. _version-0.1.15:
 .. _version-0.1.15:
@@ -4790,7 +4790,7 @@ arguments, so be sure to flush your task queue before you upgrade.
   happened.  It kind of works like the `multiprocessing.AsyncResult`
   happened.  It kind of works like the `multiprocessing.AsyncResult`
   class returned by `multiprocessing.Pool.map_async`.
   class returned by `multiprocessing.Pool.map_async`.
 
 
-* Added dmap() and dmap_async(). This works like the 
+* Added dmap() and dmap_async(). This works like the
   `multiprocessing.Pool` versions except they are tasks
   `multiprocessing.Pool` versions except they are tasks
   distributed to the celery server. Example:
   distributed to the celery server. Example:
 
 

+ 1 - 1
README.rst

@@ -256,7 +256,7 @@ Mailing list
 ------------
 ------------
 
 
 For discussions about the usage, development, and future of celery,
 For discussions about the usage, development, and future of celery,
-please join the `celery-users`_ mailing list. 
+please join the `celery-users`_ mailing list.
 
 
 .. _`celery-users`: http://groups.google.com/group/celery-users/
 .. _`celery-users`: http://groups.google.com/group/celery-users/
 
 

+ 1 - 1
celery/tests/test_worker/test_worker_job.py

@@ -554,7 +554,7 @@ class test_TaskRequest(unittest.TestCase):
                           content_encoding="utf-8")
                           content_encoding="utf-8")
         with self.assertRaises(InvalidTaskError):
         with self.assertRaises(InvalidTaskError):
             TaskRequest.from_message(m, m.decode())
             TaskRequest.from_message(m, m.decode())
- 
+
     def test_from_message_nonexistant_task(self):
     def test_from_message_nonexistant_task(self):
         body = {"task": "cu.mytask.doesnotexist", "id": uuid(),
         body = {"task": "cu.mytask.doesnotexist", "id": uuid(),
                 "args": [2], "kwargs": {u"æØåveéðƒeæ": "bar"}}
                 "args": [2], "kwargs": {u"æØåveéðƒeæ": "bar"}}

+ 7 - 7
celery/utils/dispatch/license.txt

@@ -4,23 +4,23 @@ PyDispatcher License:
 
 
     Copyright (c) 2001-2003, Patrick K. O'Brien and Contributors
     Copyright (c) 2001-2003, Patrick K. O'Brien and Contributors
     All rights reserved.
     All rights reserved.
-    
+
     Redistribution and use in source and binary forms, with or without
     Redistribution and use in source and binary forms, with or without
     modification, are permitted provided that the following conditions
     modification, are permitted provided that the following conditions
     are met:
     are met:
-    
+
         Redistributions of source code must retain the above copyright
         Redistributions of source code must retain the above copyright
         notice, this list of conditions and the following disclaimer.
         notice, this list of conditions and the following disclaimer.
-    
+
         Redistributions in binary form must reproduce the above
         Redistributions in binary form must reproduce the above
         copyright notice, this list of conditions and the following
         copyright notice, this list of conditions and the following
         disclaimer in the documentation and/or other materials
         disclaimer in the documentation and/or other materials
         provided with the distribution.
         provided with the distribution.
-    
+
         The name of Patrick K. O'Brien, or the name of any Contributor,
         The name of Patrick K. O'Brien, or the name of any Contributor,
-        may not be used to endorse or promote products derived from this 
+        may not be used to endorse or promote products derived from this
         software without specific prior written permission.
         software without specific prior written permission.
-    
+
     THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS
     THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS
     ``AS IS'' AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT
     ``AS IS'' AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT
     LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS
     LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS
@@ -32,5 +32,5 @@ PyDispatcher License:
     HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
     HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT,
     STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE)
     STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE)
     ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED
     ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED
-    OF THE POSSIBILITY OF SUCH DAMAGE. 
+    OF THE POSSIBILITY OF SUCH DAMAGE.
 
 

+ 1 - 1
contrib/logtools/find-unprocessed-tasks-debug.sh

@@ -13,7 +13,7 @@
 #
 #
 #     # Using a custom logfile
 #     # Using a custom logfile
 #     # bash find-unprocessed-tasks.sh ./celeryd.log
 #     # bash find-unprocessed-tasks.sh ./celeryd.log
-# 
+#
 #--------------------------------------------------------------------#
 #--------------------------------------------------------------------#
 
 
 DEFAULT_LOGFILE=/var/log/celeryd.log
 DEFAULT_LOGFILE=/var/log/celeryd.log

+ 1 - 1
contrib/logtools/find-unprocessed-tasks.sh

@@ -13,7 +13,7 @@
 #
 #
 #     # Using a custom logfile
 #     # Using a custom logfile
 #     # bash find-unprocessed-tasks.sh ./celeryd.log
 #     # bash find-unprocessed-tasks.sh ./celeryd.log
-# 
+#
 #--------------------------------------------------------------------#
 #--------------------------------------------------------------------#
 
 
 DEFAULT_LOGFILE=/var/log/celeryd.log
 DEFAULT_LOGFILE=/var/log/celeryd.log

+ 2 - 2
contrib/logtools/periodic-task-runtimes.sh

@@ -1,12 +1,12 @@
 #!/bin/bash
 #!/bin/bash
 #---------------------------------------------------------------------------#
 #---------------------------------------------------------------------------#
-# 
+#
 # Tool to find race conditions in the Periodic Task system.
 # Tool to find race conditions in the Periodic Task system.
 # Outputs times of all runs of a certain task (by searching for task name
 # Outputs times of all runs of a certain task (by searching for task name
 # using a search query).
 # using a search query).
 #
 #
 # Usage:
 # Usage:
-#   
+#
 #   $ bash periodic-task-runtimes.sh query host1 [host2 ... hostN]
 #   $ bash periodic-task-runtimes.sh query host1 [host2 ... hostN]
 #
 #
 # Example usage:
 # Example usage:

+ 23 - 23
docs/_theme/celery/static/celery.css_t

@@ -13,9 +13,9 @@
 {% set code_font_stack = "'Consolas', 'Menlo', 'Deja Vu Sans Mono', 'Bitstream Vera Sans Mono', monospace" %}
 {% set code_font_stack = "'Consolas', 'Menlo', 'Deja Vu Sans Mono', 'Bitstream Vera Sans Mono', monospace" %}
 
 
 @import url("basic.css");
 @import url("basic.css");
- 
+
 /* -- page layout ----------------------------------------------------------- */
 /* -- page layout ----------------------------------------------------------- */
- 
+
 body {
 body {
     font-family: {{ body_font_stack }};
     font-family: {{ body_font_stack }};
     font-size: 17px;
     font-size: 17px;
@@ -61,7 +61,7 @@ div.sphinxsidebar {
 hr {
 hr {
     border: 1px solid #B1B4B6;
     border: 1px solid #B1B4B6;
 }
 }
- 
+
 div.body {
 div.body {
     background-color: #ffffff;
     background-color: #ffffff;
     color: #3E4349;
     color: #3E4349;
@@ -72,7 +72,7 @@ img.celerylogo {
     padding: 0 0 10px 10px;
     padding: 0 0 10px 10px;
     float: right;
     float: right;
 }
 }
- 
+
 div.footer {
 div.footer {
     width: {{ page_width - 15 }}px;
     width: {{ page_width - 15 }}px;
     margin: 10px auto 30px auto;
     margin: 10px auto 30px auto;
@@ -95,7 +95,7 @@ div.sphinxsidebar a {
 div.sphinxsidebar a:hover {
 div.sphinxsidebar a:hover {
     border-bottom: 1px solid #999;
     border-bottom: 1px solid #999;
 }
 }
- 
+
 div.sphinxsidebar {
 div.sphinxsidebar {
     font-size: 14px;
     font-size: 14px;
     line-height: 1.5;
     line-height: 1.5;
@@ -109,7 +109,7 @@ div.sphinxsidebarwrapper p.logo {
     padding: 0 0 20px 0;
     padding: 0 0 20px 0;
     margin: 0;
     margin: 0;
 }
 }
- 
+
 div.sphinxsidebar h3,
 div.sphinxsidebar h3,
 div.sphinxsidebar h4 {
 div.sphinxsidebar h4 {
     font-family: {{ headline_font_stack }};
     font-family: {{ headline_font_stack }};
@@ -134,7 +134,7 @@ div.sphinxsidebar p.logo a:hover,
 div.sphinxsidebar h3 a:hover {
 div.sphinxsidebar h3 a:hover {
     border: none;
     border: none;
 }
 }
- 
+
 div.sphinxsidebar p {
 div.sphinxsidebar p {
     color: #555;
     color: #555;
     margin: 10px 0;
     margin: 10px 0;
@@ -145,25 +145,25 @@ div.sphinxsidebar ul {
     padding: 0;
     padding: 0;
     color: #000;
     color: #000;
 }
 }
- 
+
 div.sphinxsidebar input {
 div.sphinxsidebar input {
     border: 1px solid #ccc;
     border: 1px solid #ccc;
     font-family: {{ body_font_stack }};
     font-family: {{ body_font_stack }};
     font-size: 1em;
     font-size: 1em;
 }
 }
- 
+
 /* -- body styles ----------------------------------------------------------- */
 /* -- body styles ----------------------------------------------------------- */
- 
+
 a {
 a {
     color: #348613;
     color: #348613;
     text-decoration: underline;
     text-decoration: underline;
 }
 }
- 
+
 a:hover {
 a:hover {
     color: #59B833;
     color: #59B833;
     text-decoration: underline;
     text-decoration: underline;
 }
 }
- 
+
 div.body h1,
 div.body h1,
 div.body h2,
 div.body h2,
 div.body h3,
 div.body h3,
@@ -175,7 +175,7 @@ div.body h6 {
     margin: 30px 0px 10px 0px;
     margin: 30px 0px 10px 0px;
     padding: 0;
     padding: 0;
 }
 }
- 
+
 div.body h1 { margin-top: 0; padding-top: 0; font-size: 200%; }
 div.body h1 { margin-top: 0; padding-top: 0; font-size: 200%; }
 div.body h2 { font-size: 180%; }
 div.body h2 { font-size: 180%; }
 div.body h3 { font-size: 150%; }
 div.body h3 { font-size: 150%; }
@@ -192,18 +192,18 @@ div.body h6 a.toc-backref {
     color: inherit!important;
     color: inherit!important;
     text-decoration: none;
     text-decoration: none;
 }
 }
- 
+
 a.headerlink {
 a.headerlink {
     color: #ddd;
     color: #ddd;
     padding: 0 4px;
     padding: 0 4px;
     text-decoration: none;
     text-decoration: none;
 }
 }
- 
+
 a.headerlink:hover {
 a.headerlink:hover {
     color: #444;
     color: #444;
     background: #eaeaea;
     background: #eaeaea;
 }
 }
- 
+
 div.body p, div.body dd, div.body li {
 div.body p, div.body dd, div.body li {
     line-height: 1.4em;
     line-height: 1.4em;
 }
 }
@@ -241,25 +241,25 @@ div.note {
     background-color: #eee;
     background-color: #eee;
     border: 1px solid #ccc;
     border: 1px solid #ccc;
 }
 }
- 
+
 div.seealso {
 div.seealso {
     background-color: #ffc;
     background-color: #ffc;
     border: 1px solid #ff6;
     border: 1px solid #ff6;
 }
 }
- 
+
 div.topic {
 div.topic {
     background-color: #eee;
     background-color: #eee;
 }
 }
- 
+
 div.warning {
 div.warning {
     background-color: #ffe4e4;
     background-color: #ffe4e4;
     border: 1px solid #f66;
     border: 1px solid #f66;
 }
 }
- 
+
 p.admonition-title {
 p.admonition-title {
     display: inline;
     display: inline;
 }
 }
- 
+
 p.admonition-title:after {
 p.admonition-title:after {
     content: ":";
     content: ":";
 }
 }
@@ -353,7 +353,7 @@ ul {
     margin: 10px 0 10px 30px;
     margin: 10px 0 10px 30px;
     padding: 0;
     padding: 0;
 }
 }
- 
+
 pre {
 pre {
     background: #F0FFEB;
     background: #F0FFEB;
     padding: 7px 10px;
     padding: 7px 10px;
@@ -364,7 +364,7 @@ pre {
     -webkit-border-radius: 2px;
     -webkit-border-radius: 2px;
     line-height: 1.3em;
     line-height: 1.3em;
 }
 }
- 
+
 tt {
 tt {
     background: #F0FFEB;
     background: #F0FFEB;
     color: #222;
     color: #222;

+ 1 - 1
docs/community.rst

@@ -214,7 +214,7 @@ http://www.slideshare.net/idangazit/an-introduction-to-celery
 
 
     <div style="width:425px;text-align:left" id="__ss_2089054">
     <div style="width:425px;text-align:left" id="__ss_2089054">
     <a style="font:14px Helvetica,Arial,Sans-serif;display:block;
     <a style="font:14px Helvetica,Arial,Sans-serif;display:block;
-    margin:12px 0 3px 0;text-decoration:underline;" 
+    margin:12px 0 3px 0;text-decoration:underline;"
     href="http://www.slideshare.net/idangazit/an-introduction-to-celery"
     href="http://www.slideshare.net/idangazit/an-introduction-to-celery"
     title="An Introduction to Celery">An Introduction to Celery</a>
     title="An Introduction to Celery">An Introduction to Celery</a>
     <object style="margin:0px" width="425" height="355"> <param name="movie"
     <object style="margin:0px" width="425" height="355"> <param name="movie"

+ 4 - 4
docs/configuration.rst

@@ -176,10 +176,10 @@ the :setting:`CELERY_RESULT_ENGINE_OPTIONS` setting::
 .. setting:: CELERY_RESULT_DB_SHORT_LIVED_SESSIONS
 .. setting:: CELERY_RESULT_DB_SHORT_LIVED_SESSIONS
     CELERY_RESULT_DB_SHORT_LIVED_SESSIONS = True
     CELERY_RESULT_DB_SHORT_LIVED_SESSIONS = True
 
 
-Short lived sessions are disabled by default.  If enabled they can drastically reduce 
-performance, especially on systems processing lots of tasks.  This option is useful 
-on low-traffic workers that experience errors as a result of cached database connections 
-going stale through inactivity.  For example, intermittent errors like 
+Short lived sessions are disabled by default.  If enabled they can drastically reduce
+performance, especially on systems processing lots of tasks.  This option is useful
+on low-traffic workers that experience errors as a result of cached database connections
+going stale through inactivity.  For example, intermittent errors like
 `(OperationalError) (2006, 'MySQL server has gone away')` can be fixed by enabling
 `(OperationalError) (2006, 'MySQL server has gone away')` can be fixed by enabling
 short lived sessions.  This option only affects the database backend.
 short lived sessions.  This option only affects the database backend.
 
 

+ 1 - 1
docs/includes/resources.txt

@@ -9,7 +9,7 @@ Mailing list
 ------------
 ------------
 
 
 For discussions about the usage, development, and future of celery,
 For discussions about the usage, development, and future of celery,
-please join the `celery-users`_ mailing list. 
+please join the `celery-users`_ mailing list.
 
 
 .. _`celery-users`: http://groups.google.com/group/celery-users/
 .. _`celery-users`: http://groups.google.com/group/celery-users/
 
 

+ 1 - 1
docs/tutorials/clickcounter.rst

@@ -227,7 +227,7 @@ Processing the clicks every 30 minutes is easy using celery periodic tasks.
 
 
 We subclass from :class:`celery.task.base.PeriodicTask`, set the `run_every`
 We subclass from :class:`celery.task.base.PeriodicTask`, set the `run_every`
 attribute and in the body of the task just call the `process_clicks`
 attribute and in the body of the task just call the `process_clicks`
-function we wrote earlier. 
+function we wrote earlier.
 
 
 
 
 Finishing
 Finishing