Skip to content

Commit

Permalink
On 2.6 we don't have to import with statement from __future__
Browse files Browse the repository at this point in the history
Conflicts:

	celery/bin/celeryctl.py
	celery/tests/test_app/__init__.py
	celery/tests/test_app/test_app_amqp.py
	celery/tests/test_app/test_app_defaults.py
	celery/tests/test_app/test_loaders.py
	celery/tests/test_app/test_log.py
	celery/tests/test_app/test_routes.py
	celery/tests/test_backends/__init__.py
	celery/tests/test_backends/test_redis.py
	celery/tests/test_bin/__init__.py
	celery/tests/test_bin/test_celeryd.py
	celery/tests/test_task/__init__.py
	celery/tests/test_task/test_chord.py
	celery/tests/test_task/test_registry.py
	celery/tests/test_task/test_result.py
	celery/tests/test_task/test_task_http.py
	celery/tests/test_worker/test_worker_job.py
	contrib/release/flakeplus.py
  • Loading branch information
ask committed Jul 20, 2012
1 parent 2718b05 commit f72ca13
Show file tree
Hide file tree
Showing 46 changed files with 0 additions and 46 deletions.
1 change: 0 additions & 1 deletion celery/app/base.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import warnings

Expand Down
1 change: 0 additions & 1 deletion celery/app/control.py
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

from kombu.pidbox import Mailbox
from kombu.utils import cached_property
Expand Down
1 change: 0 additions & 1 deletion celery/backends/amqp.py
Original file line number Diff line number Diff line change
Expand Up @@ -9,7 +9,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import socket
import threading
Expand Down
1 change: 0 additions & 1 deletion celery/bin/celerybeat.py
Original file line number Diff line number Diff line change
Expand Up @@ -38,7 +38,6 @@
`ERROR`, `CRITICAL`, or `FATAL`.
"""
from __future__ import with_statement
from __future__ import absolute_import

import os
Expand Down
1 change: 0 additions & 1 deletion celery/bin/celeryd_detach.py
Original file line number Diff line number Diff line change
Expand Up @@ -11,7 +11,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import celery
import os
Expand Down
1 change: 0 additions & 1 deletion celery/bin/celeryev.py
Original file line number Diff line number Diff line change
Expand Up @@ -36,7 +36,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import os
import sys
Expand Down
1 change: 0 additions & 1 deletion celery/contrib/migrate.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import socket

Expand Down
1 change: 0 additions & 1 deletion celery/datastructures.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import sys
import time
Expand Down
1 change: 0 additions & 1 deletion celery/events/__init__.py
Original file line number Diff line number Diff line change
Expand Up @@ -9,7 +9,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import time
import socket
Expand Down
1 change: 0 additions & 1 deletion celery/events/cursesmon.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import curses
import sys
Expand Down
1 change: 0 additions & 1 deletion celery/events/state.py
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import heapq

Expand Down
1 change: 0 additions & 1 deletion celery/result.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import time

Expand Down
1 change: 0 additions & 1 deletion celery/security/__init__.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

from kombu.serialization import registry

Expand Down
1 change: 0 additions & 1 deletion celery/security/certificate.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import glob
import os
Expand Down
1 change: 0 additions & 1 deletion celery/task/sets.py
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

from celery._state import get_current_worker_task
from celery.app import app_or_default
Expand Down
1 change: 0 additions & 1 deletion celery/tests/app/test_control.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

from functools import wraps

Expand Down
1 change: 0 additions & 1 deletion celery/tests/backends/test_amqp.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import socket

Expand Down
1 change: 0 additions & 1 deletion celery/tests/backends/test_base.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import sys
import types
Expand Down
1 change: 0 additions & 1 deletion celery/tests/backends/test_cache.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import sys
import types
Expand Down
1 change: 0 additions & 1 deletion celery/tests/backends/test_database.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import sys

Expand Down
1 change: 0 additions & 1 deletion celery/tests/bin/test_celerybeat.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import logging
import sys
Expand Down
1 change: 0 additions & 1 deletion celery/tests/concurrency/test_concurrency.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import os

Expand Down
1 change: 0 additions & 1 deletion celery/tests/concurrency/test_processes.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import signal
import time
Expand Down
1 change: 0 additions & 1 deletion celery/tests/events/test_events.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import socket

Expand Down
1 change: 0 additions & 1 deletion celery/tests/events/test_snapshot.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

from mock import patch

Expand Down
1 change: 0 additions & 1 deletion celery/tests/slow/test_buckets.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import sys
import time
Expand Down
1 change: 0 additions & 1 deletion celery/tests/tasks/test_sets.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import anyjson

Expand Down
1 change: 0 additions & 1 deletion celery/tests/tasks/test_trace.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

from mock import patch

Expand Down
1 change: 0 additions & 1 deletion celery/tests/utilities/test_datastructures.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

from celery.datastructures import (
ExceptionInfo,
Expand Down
1 change: 0 additions & 1 deletion celery/tests/utilities/test_serialization.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import sys

Expand Down
1 change: 0 additions & 1 deletion celery/tests/utilities/test_timer2.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import sys
import time
Expand Down
1 change: 0 additions & 1 deletion celery/tests/utilities/test_utils.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

from kombu.utils.functional import promise

Expand Down
1 change: 0 additions & 1 deletion celery/tests/worker/test_bootsteps.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

from mock import Mock

Expand Down
1 change: 0 additions & 1 deletion celery/tests/worker/test_control.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import sys
import socket
Expand Down
1 change: 0 additions & 1 deletion celery/tests/worker/test_worker.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,4 @@
from __future__ import absolute_import
from __future__ import with_statement

import socket

Expand Down
1 change: 0 additions & 1 deletion celery/utils/__init__.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import operator
import os
Expand Down
1 change: 0 additions & 1 deletion celery/utils/functional.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import operator

Expand Down
1 change: 0 additions & 1 deletion celery/utils/timer2.py
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import atexit
import heapq
Expand Down
1 change: 0 additions & 1 deletion celery/worker/autoreload.py
Original file line number Diff line number Diff line change
Expand Up @@ -6,7 +6,6 @@
This module implements automatic module reloading
"""
from __future__ import absolute_import
from __future__ import with_statement

import errno
import hashlib
Expand Down
1 change: 0 additions & 1 deletion celery/worker/autoscale.py
Original file line number Diff line number Diff line change
Expand Up @@ -12,7 +12,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import threading

Expand Down
1 change: 0 additions & 1 deletion celery/worker/buckets.py
Original file line number Diff line number Diff line change
Expand Up @@ -13,7 +13,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import threading

Expand Down
1 change: 0 additions & 1 deletion celery/worker/consumer.py
Original file line number Diff line number Diff line change
Expand Up @@ -71,7 +71,6 @@
"""
from __future__ import absolute_import
from __future__ import with_statement

import logging
import socket
Expand Down
1 change: 0 additions & 1 deletion examples/eventlet/bulk_task_producer.py
Original file line number Diff line number Diff line change
@@ -1,4 +1,3 @@
from __future__ import with_statement

from eventlet import spawn_n, monkey_patch, Timeout
from eventlet.queue import LightQueue
Expand Down
1 change: 0 additions & 1 deletion examples/eventlet/webcrawler.py
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,6 @@
"""

from __future__ import with_statement

import re
import time
Expand Down
1 change: 0 additions & 1 deletion extra/release/attribution.py
Original file line number Diff line number Diff line change
@@ -1,6 +1,5 @@
#!/usr/bin/env python
from __future__ import absolute_import
from __future__ import with_statement

import fileinput

Expand Down
1 change: 0 additions & 1 deletion extra/release/bump_version.py
Original file line number Diff line number Diff line change
@@ -1,7 +1,6 @@
#!/usr/bin/env python

from __future__ import absolute_import
from __future__ import with_statement

import errno
import os
Expand Down

0 comments on commit f72ca13

Please sign in to comment.