Skip to content

Commit

Permalink
no from __future__ import ... (#2846)
Browse files Browse the repository at this point in the history
* Update .travis.yml

* no py27 in travis (#2836)

* no py27 in travis

* py37

* flake8 and docs back

* py36 py37 postgres

* py36-apache

* MixedUnicodeBytes removed

* unused imports removed

* no-if-py3

* space

* space

* MixedUnicodeBytesFormat returned

* no from __future__ import
  • Loading branch information
drowoseque authored and honnix committed Dec 16, 2019
1 parent 5c6cfee commit f482013
Show file tree
Hide file tree
Showing 35 changed files with 0 additions and 56 deletions.
3 changes: 0 additions & 3 deletions examples/execution_summary_example.py
Original file line number Diff line number Diff line change
Expand Up @@ -44,9 +44,6 @@
===== Luigi Execution Summary =====
"""


from __future__ import print_function
import datetime

import luigi
Expand Down
2 changes: 0 additions & 2 deletions examples/foo.py
Original file line number Diff line number Diff line change
Expand Up @@ -23,8 +23,6 @@
$ luigi --module examples.foo examples.Foo --workers 2 --local-scheduler
"""

from __future__ import print_function
import time

import luigi
Expand Down
1 change: 0 additions & 1 deletion examples/foo_complex.py
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,6 @@
$ luigi --module examples.foo_complex examples.Foo --workers 2 --local-scheduler
"""
from __future__ import division
import time
import random

Expand Down
2 changes: 0 additions & 2 deletions examples/ftp_experiment_outputs.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,8 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#

from __future__ import print_function
import luigi
from luigi.contrib.ftp import RemoteTarget

Expand Down
2 changes: 0 additions & 2 deletions examples/ssh_remote_execution.py
Original file line number Diff line number Diff line change
Expand Up @@ -15,8 +15,6 @@
# limitations under the License.
#

from __future__ import print_function

from collections import defaultdict

from luigi import six
Expand Down
2 changes: 0 additions & 2 deletions luigi/contrib/dropbox.py
Original file line number Diff line number Diff line change
Expand Up @@ -15,8 +15,6 @@
# the License.
#

from __future__ import absolute_import

import logging
import ntpath
import os
Expand Down
2 changes: 0 additions & 2 deletions luigi/contrib/hadoop.py
Original file line number Diff line number Diff line change
Expand Up @@ -22,8 +22,6 @@
an example of how to run a Hadoop job.
"""

from __future__ import print_function

import abc
import datetime
import glob
Expand Down
2 changes: 0 additions & 2 deletions luigi/contrib/lsf_runner.py
Original file line number Diff line number Diff line change
Expand Up @@ -18,8 +18,6 @@
limitations under the License.
"""

from __future__ import print_function

import os
import sys
try:
Expand Down
2 changes: 0 additions & 2 deletions luigi/contrib/mrrunner.py
Original file line number Diff line number Diff line change
Expand Up @@ -27,8 +27,6 @@
mapper, combiner, or reducer on the Hadoop nodes.
"""

from __future__ import print_function

import pickle
import logging
import os
Expand Down
2 changes: 0 additions & 2 deletions luigi/contrib/pyspark_runner.py
Original file line number Diff line number Diff line change
Expand Up @@ -26,8 +26,6 @@
"""

from __future__ import print_function

import pickle
import logging
import sys
Expand Down
2 changes: 0 additions & 2 deletions luigi/contrib/s3.py
Original file line number Diff line number Diff line change
Expand Up @@ -20,8 +20,6 @@
system operations. The `boto3` library is required to use S3 targets.
"""

from __future__ import division

import datetime
import io
import itertools
Expand Down
2 changes: 0 additions & 2 deletions luigi/contrib/sparkey.py
Original file line number Diff line number Diff line change
Expand Up @@ -15,8 +15,6 @@
# limitations under the License.
#

from __future__ import absolute_import

import luigi


Expand Down
2 changes: 0 additions & 2 deletions luigi/contrib/webhdfs.py
Original file line number Diff line number Diff line change
Expand Up @@ -23,8 +23,6 @@
:class:`luigi.contrib.hdfs.webhdfs_client.WebHdfsClient`
"""

from __future__ import absolute_import

import logging

from luigi.target import FileSystemTarget, AtomicLocalFile
Expand Down
2 changes: 0 additions & 2 deletions luigi/date_interval.py
Original file line number Diff line number Diff line change
Expand Up @@ -31,8 +31,6 @@ class MyTask(luigi.Task):
``--date-interval 2014`` (for a year) and some other notations.
"""

from __future__ import division

from luigi import six

import datetime
Expand Down
1 change: 0 additions & 1 deletion luigi/lock.py
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,6 @@
Uses a pidfile.
This prevents multiple identical workflows to be launched simultaneously.
"""
from __future__ import print_function

import errno
import hashlib
Expand Down
1 change: 0 additions & 1 deletion luigi/process.py
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,6 @@
"""
Contains some helper functions to run luigid in daemon mode
"""
from __future__ import print_function

import datetime
import logging
Expand Down
2 changes: 0 additions & 2 deletions luigi/six.py
Original file line number Diff line number Diff line change
Expand Up @@ -20,8 +20,6 @@
# OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
# SOFTWARE.

from __future__ import absolute_import

import functools
import itertools
import operator
Expand Down
2 changes: 0 additions & 2 deletions luigi/tools/deps.py
Original file line number Diff line number Diff line change
Expand Up @@ -36,8 +36,6 @@
# [--upstream-family MyUpstreamTask]
#


from __future__ import print_function
import luigi.interface
from luigi.contrib.ssh import RemoteTarget
from luigi.contrib.postgres import PostgresTarget
Expand Down
1 change: 0 additions & 1 deletion test/cmdline_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

import mock
import os
Expand Down
1 change: 0 additions & 1 deletion test/contrib/s3_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# License for the specific language governing permissions and limitations under
# the License.
#
from __future__ import print_function

import os
import sys
Expand Down
2 changes: 0 additions & 2 deletions test/contrib/test_ssh.py
Original file line number Diff line number Diff line change
Expand Up @@ -18,8 +18,6 @@
Integration tests for ssh module.
"""

from __future__ import print_function

import os
import random
import socket
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -15,6 +15,4 @@
# limitations under the License.
#

from __future__ import absolute_import

import os # NOQA
1 change: 0 additions & 1 deletion test/decorator_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

import datetime
import pickle
Expand Down
1 change: 0 additions & 1 deletion test/local_target_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

import bz2
import gzip
Expand Down
1 change: 0 additions & 1 deletion test/mock_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

from helpers import unittest

Expand Down
1 change: 0 additions & 1 deletion test/recursion_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

import datetime
from helpers import unittest
Expand Down
1 change: 0 additions & 1 deletion test/scheduler_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

import pickle
import tempfile
Expand Down
1 change: 0 additions & 1 deletion test/scheduler_visualisation_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import division

import os
import tempfile
Expand Down
1 change: 0 additions & 1 deletion test/target_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

from helpers import unittest, skipOnTravis
from mock import Mock
Expand Down
2 changes: 0 additions & 2 deletions test/task_serialize_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -25,8 +25,6 @@
"""

from __future__ import print_function

import string
import luigi
import json
Expand Down
2 changes: 0 additions & 2 deletions test/visualiser/visualiser_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -3,8 +3,6 @@
"""

from __future__ import print_function

import os
import luigi
import subprocess
Expand Down
1 change: 0 additions & 1 deletion test/worker_keep_alive_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

from helpers import LuigiTestCase
from luigi.scheduler import Scheduler
Expand Down
2 changes: 0 additions & 2 deletions test/worker_scheduler_com_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -15,8 +15,6 @@
# limitations under the License.
#

from __future__ import print_function

import os
import time
import threading
Expand Down
1 change: 0 additions & 1 deletion test/worker_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

import email.parser
import functools
Expand Down
1 change: 0 additions & 1 deletion test/wrap_test.py
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@
# See the License for the specific language governing permissions and
# limitations under the License.
#
from __future__ import print_function

import datetime
from helpers import unittest
Expand Down

0 comments on commit f482013

Please sign in to comment.