You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2018/03/30 01:03:28 UTC

Build failed in Jenkins: beam_PostCommit_Python_Verify #4534

See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4534/display/redirect?page=changes>

Changes:

[github] Fix linter error in typehints.

------------------------------------------
[...truncated 291.12 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 01:02:18.564394
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 01:02:19.112097
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 01:02:19.255549
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 01:02:19.269918
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 01:02:19.285763
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 01:02:19.374244
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 01:02:19.645325
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 01:02:19.674693
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 01:02:19.791402
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 01:02:19.831367
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
357.66user 7.02system 2:08.57elapsed 283%CPU (0avgtext+0avgdata 250392maxresident)k
0inputs+168outputs (0major+655009minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='1458941295'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
38.26user 0.34system 0:21.30elapsed 181%CPU (0avgtext+0avgdata 66284maxresident)k
0inputs+0outputs (0major+88610minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Jenkins build is back to normal : beam_PostCommit_Python_Verify #4551

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4551/display/redirect>


Build failed in Jenkins: beam_PostCommit_Python_Verify #4550

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4550/display/redirect?page=changes>

Changes:

[lcwik] [BEAM-3249] Allow for re-use of dependencies within other projects by

[boyuanz] Add distribution_counter_microbenchmark to apache_beam.tools.utils

------------------------------------------
[...truncated 1016.42 KB...]
copying apache_beam/runners/portability/universal_local_runner_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/test/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/runners/test
copying apache_beam/runners/worker/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/bundle_processor.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/data_plane.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/data_plane_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/log_handler.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/log_handler_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/logger.pxd -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/logger.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/logger_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/opcounters.pxd -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/opcounters.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/opcounters_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/operation_specs.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/operations.pxd -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/operations.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker_main.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker_main_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sideinputs.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sideinputs_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler_fast.pyx -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler_slow.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/worker_id_interceptor.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/worker_id_interceptor_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/testing/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/pipeline_verifiers.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/pipeline_verifiers_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_pipeline.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_pipeline_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_stream.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_stream_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_utils.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_utils_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/util.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/util_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/data/standard_coders.yaml -> apache-beam-2.5.0.dev0/apache_beam/testing/data
copying apache_beam/testing/data/trigger_transcripts.yaml -> apache-beam-2.5.0.dev0/apache_beam/testing/data
copying apache_beam/tools/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/tools/distribution_counter_microbenchmark.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/tools/map_fn_microbenchmark.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/tools/utils.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/transforms/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/combiners.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/combiners_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/core.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/create_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners.pxd -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/timeutil.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/write_ptransform_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/typehints/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/opcodes.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
Writing apache-beam-2.5.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.5.0.dev0' (and everything under it)

SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run integration tests on the Google Cloud Dataflow service
# and validate that jobs finish successfully.
echo ">>> RUNNING TEST DATAFLOW RUNNER it tests"
>>> RUNNING TEST DATAFLOW RUNNER it tests
python setup.py nosetests \
  --attr IT \
  --nocapture \
  --processes=4 \
  --process-timeout=900 \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --staging_location=$GCS_LOCATION/staging-it \
    --temp_location=$GCS_LOCATION/temp-it \
    --output=$GCS_LOCATION/py-it-cloud/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1 \
    --sleep_secs=20"
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/setuptools/dist.py>:397: UserWarning: Normalizing '2.5.0.dev' to '2.5.0.dev0'
  normalized_version,
running nosetests
running egg_info
writing requirements to apache_beam.egg-info/requires.txt
writing apache_beam.egg-info/PKG-INFO
writing top-level names to apache_beam.egg-info/top_level.txt
writing dependency_links to apache_beam.egg-info/dependency_links.txt
writing entry points to apache_beam.egg-info/entry_points.txt
reading manifest file 'apache_beam.egg-info/SOURCES.txt'
reading manifest template 'MANIFEST.in'
warning: no files found matching 'README.md'
warning: no files found matching 'NOTICE'
warning: no files found matching 'LICENSE'
writing manifest file 'apache_beam.egg-info/SOURCES.txt'
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py>:168: DeprecationWarning: object() takes no parameters
  super(GcsIO, cls).__new__(cls, storage_client))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py>:168: DeprecationWarning: object() takes no parameters
  super(GcsIO, cls).__new__(cls, storage_client))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py>:743: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  transform_node.inputs[0].pipeline.options.view_as(StandardOptions))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ok
test_bigquery_tornadoes_it (apache_beam.examples.cookbook.bigquery_tornadoes_it_test.BigqueryTornadoesIT) ... ok
test_wordcount_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ok
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_20_27_53-6004781185215055164?project=apache-beam-testing.
test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT) ... ERROR

======================================================================
ERROR: test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 812, in run
    test(orig)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/case.py",> line 45, in __call__
    return self.run(*arg, **kwarg)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/case.py",> line 133, in run
    self.runTest(result)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/case.py",> line 151, in runTest
    test(result)
  File "/usr/lib/python2.7/unittest/case.py", line 395, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 331, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py",> line 113, in test_streaming_wordcount_it
    self.test_pipeline.get_full_options_as_args(**extra_opts))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount.py",> line 92, in run
    result = p.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/pipeline.py",> line 402, in run
    return self.runner.run_pipeline(self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 58, in run_pipeline
    hc_assert_that(self.result, pickler.loads(on_success_matcher))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/assert_that.py",> line 43, in assert_that
    _assert_match(actual=arg1, matcher=arg2, reason=arg3)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/assert_that.py",> line 55, in _assert_match
    matcher.describe_mismatch(actual, description)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/core/allof.py",> line 25, in describe_mismatch
    self.matches(item, mismatch_description)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/core/allof.py",> line 16, in matches
    if not matcher.matches(item):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/base_matcher.py",> line 28, in matches
    match_result = self._matches(item)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/tests/pubsub_matcher.py",> line 81, in _matches
    self.timeout)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/tests/pubsub_matcher.py",> line 90, in _wait_for_messages
    pulled = subscription.pull(max_messages=MAX_MESSAGES_IN_ONE_PULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/cloud/pubsub/subscription.py",> line 367, in pull
    self.full_name, return_immediately, max_messages)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/cloud/pubsub/_gax.py",> line 440, in subscription_pull
    return_immediately=return_immediately)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/cloud/gapic/pubsub/v1/subscriber_client.py",> line 706, in pull
    return self._pull(request, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/api_callable.py",> line 452, in inner
    return api_caller(api_call, this_settings, request)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/api_callable.py",> line 438, in base_caller
    return api_call(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/api_callable.py",> line 376, in inner
    return a_func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/retry.py",> line 121, in inner
    return to_call(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/retry.py",> line 68, in inner
    return a_func(*updated_args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/grpc/_channel.py",> line 486, in __call__
    credentials)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/grpc/_channel.py",> line 480, in _blocking
    _handle_event(completion_queue.poll(), state,
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT)'

----------------------------------------------------------------------
Ran 4 tests in 901.754s

FAILED (errors=1)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_20_27_40-2053081329910483990?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_20_27_41-17869299411526392348?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_20_27_41-6788343534643819835?project=apache-beam-testing.
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4549

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4549/display/redirect>

------------------------------------------
[...truncated 1016.15 KB...]
copying apache_beam/runners/job/utils.py -> apache-beam-2.5.0.dev0/apache_beam/runners/job
copying apache_beam/runners/portability/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/fn_api_runner.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/fn_api_runner_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/universal_local_runner.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/universal_local_runner_main.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/universal_local_runner_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/test/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/runners/test
copying apache_beam/runners/worker/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/bundle_processor.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/data_plane.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/data_plane_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/log_handler.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/log_handler_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/logger.pxd -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/logger.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/logger_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/opcounters.pxd -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/opcounters.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/opcounters_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/operation_specs.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/operations.pxd -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/operations.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker_main.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker_main_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sideinputs.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sideinputs_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler_fast.pyx -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler_slow.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/worker_id_interceptor.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/worker_id_interceptor_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/testing/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/pipeline_verifiers.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/pipeline_verifiers_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_pipeline.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_pipeline_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_stream.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_stream_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_utils.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_utils_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/util.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/util_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/data/standard_coders.yaml -> apache-beam-2.5.0.dev0/apache_beam/testing/data
copying apache_beam/testing/data/trigger_transcripts.yaml -> apache-beam-2.5.0.dev0/apache_beam/testing/data
copying apache_beam/tools/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/tools/distribution_counter_microbenchmark.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/tools/map_fn_microbenchmark.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/tools/utils.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/transforms/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/combiners.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/combiners_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/core.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/create_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners.pxd -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/timeutil.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/write_ptransform_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/typehints/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/opcodes.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
Writing apache-beam-2.5.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.5.0.dev0' (and everything under it)

SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run integration tests on the Google Cloud Dataflow service
# and validate that jobs finish successfully.
echo ">>> RUNNING TEST DATAFLOW RUNNER it tests"
>>> RUNNING TEST DATAFLOW RUNNER it tests
python setup.py nosetests \
  --attr IT \
  --nocapture \
  --processes=4 \
  --process-timeout=900 \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --staging_location=$GCS_LOCATION/staging-it \
    --temp_location=$GCS_LOCATION/temp-it \
    --output=$GCS_LOCATION/py-it-cloud/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1 \
    --sleep_secs=20"
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/setuptools/dist.py>:397: UserWarning: Normalizing '2.5.0.dev' to '2.5.0.dev0'
  normalized_version,
running nosetests
running egg_info
writing requirements to apache_beam.egg-info/requires.txt
writing apache_beam.egg-info/PKG-INFO
writing top-level names to apache_beam.egg-info/top_level.txt
writing dependency_links to apache_beam.egg-info/dependency_links.txt
writing entry points to apache_beam.egg-info/entry_points.txt
reading manifest file 'apache_beam.egg-info/SOURCES.txt'
reading manifest template 'MANIFEST.in'
warning: no files found matching 'README.md'
warning: no files found matching 'NOTICE'
warning: no files found matching 'LICENSE'
writing manifest file 'apache_beam.egg-info/SOURCES.txt'
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py>:168: DeprecationWarning: object() takes no parameters
  super(GcsIO, cls).__new__(cls, storage_client))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py>:168: DeprecationWarning: object() takes no parameters
  super(GcsIO, cls).__new__(cls, storage_client))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py>:743: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  transform_node.inputs[0].pipeline.options.view_as(StandardOptions))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ok
test_bigquery_tornadoes_it (apache_beam.examples.cookbook.bigquery_tornadoes_it_test.BigqueryTornadoesIT) ... ok
test_wordcount_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ok
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_19_44_02-9341975140510436042?project=apache-beam-testing.
test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT) ... ERROR

======================================================================
ERROR: test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 812, in run
    test(orig)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/case.py",> line 45, in __call__
    return self.run(*arg, **kwarg)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/case.py",> line 133, in run
    self.runTest(result)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/case.py",> line 151, in runTest
    test(result)
  File "/usr/lib/python2.7/unittest/case.py", line 395, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 331, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py",> line 113, in test_streaming_wordcount_it
    self.test_pipeline.get_full_options_as_args(**extra_opts))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount.py",> line 92, in run
    result = p.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/pipeline.py",> line 402, in run
    return self.runner.run_pipeline(self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 58, in run_pipeline
    hc_assert_that(self.result, pickler.loads(on_success_matcher))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/assert_that.py",> line 43, in assert_that
    _assert_match(actual=arg1, matcher=arg2, reason=arg3)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/assert_that.py",> line 55, in _assert_match
    matcher.describe_mismatch(actual, description)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/core/allof.py",> line 25, in describe_mismatch
    self.matches(item, mismatch_description)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/core/allof.py",> line 16, in matches
    if not matcher.matches(item):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/base_matcher.py",> line 28, in matches
    match_result = self._matches(item)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/tests/pubsub_matcher.py",> line 81, in _matches
    self.timeout)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/tests/pubsub_matcher.py",> line 90, in _wait_for_messages
    pulled = subscription.pull(max_messages=MAX_MESSAGES_IN_ONE_PULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/cloud/pubsub/subscription.py",> line 367, in pull
    self.full_name, return_immediately, max_messages)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/cloud/pubsub/_gax.py",> line 440, in subscription_pull
    return_immediately=return_immediately)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/cloud/gapic/pubsub/v1/subscriber_client.py",> line 706, in pull
    return self._pull(request, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/api_callable.py",> line 452, in inner
    return api_caller(api_call, this_settings, request)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/api_callable.py",> line 438, in base_caller
    return api_call(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/api_callable.py",> line 376, in inner
    return a_func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/retry.py",> line 135, in inner
    time.sleep(to_sleep / _MILLIS_PER_SECOND)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT)'

----------------------------------------------------------------------
Ran 4 tests in 901.325s

FAILED (errors=1)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_19_43_52-13527892008758511651?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_19_43_52-8546107972197467192?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_19_43_52-16966293485223729253?project=apache-beam-testing.
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4548

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4548/display/redirect>

------------------------------------------
[...truncated 1.08 MB...]
copying apache_beam/runners/job/utils.py -> apache-beam-2.5.0.dev0/apache_beam/runners/job
copying apache_beam/runners/portability/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/fn_api_runner.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/fn_api_runner_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/universal_local_runner.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/universal_local_runner_main.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/portability/universal_local_runner_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/portability
copying apache_beam/runners/test/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/runners/test
copying apache_beam/runners/worker/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/bundle_processor.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/data_plane.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/data_plane_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/log_handler.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/log_handler_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/logger.pxd -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/logger.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/logger_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/opcounters.pxd -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/opcounters.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/opcounters_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/operation_specs.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/operations.pxd -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/operations.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker_main.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker_main_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sdk_worker_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sideinputs.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/sideinputs_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler_fast.pyx -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler_slow.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/statesampler_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/worker_id_interceptor.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/runners/worker/worker_id_interceptor_test.py -> apache-beam-2.5.0.dev0/apache_beam/runners/worker
copying apache_beam/testing/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/pipeline_verifiers.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/pipeline_verifiers_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_pipeline.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_pipeline_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_stream.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_stream_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_utils.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/test_utils_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/util.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/util_test.py -> apache-beam-2.5.0.dev0/apache_beam/testing
copying apache_beam/testing/data/standard_coders.yaml -> apache-beam-2.5.0.dev0/apache_beam/testing/data
copying apache_beam/testing/data/trigger_transcripts.yaml -> apache-beam-2.5.0.dev0/apache_beam/testing/data
copying apache_beam/tools/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/tools/distribution_counter_microbenchmark.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/tools/map_fn_microbenchmark.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/tools/utils.py -> apache-beam-2.5.0.dev0/apache_beam/tools
copying apache_beam/transforms/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/combiners.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/combiners_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/core.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/create_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners.pxd -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/timeutil.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/transforms/write_ptransform_test.py -> apache-beam-2.5.0.dev0/apache_beam/transforms
copying apache_beam/typehints/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/opcodes.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.5.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.5.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.5.0.dev0/apache_beam/utils
Writing apache-beam-2.5.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.5.0.dev0' (and everything under it)

SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run integration tests on the Google Cloud Dataflow service
# and validate that jobs finish successfully.
echo ">>> RUNNING TEST DATAFLOW RUNNER it tests"
>>> RUNNING TEST DATAFLOW RUNNER it tests
python setup.py nosetests \
  --attr IT \
  --nocapture \
  --processes=4 \
  --process-timeout=900 \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --staging_location=$GCS_LOCATION/staging-it \
    --temp_location=$GCS_LOCATION/temp-it \
    --output=$GCS_LOCATION/py-it-cloud/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1 \
    --sleep_secs=20"
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/setuptools/dist.py>:397: UserWarning: Normalizing '2.5.0.dev' to '2.5.0.dev0'
  normalized_version,
running nosetests
running egg_info
writing requirements to apache_beam.egg-info/requires.txt
writing apache_beam.egg-info/PKG-INFO
writing top-level names to apache_beam.egg-info/top_level.txt
writing dependency_links to apache_beam.egg-info/dependency_links.txt
writing entry points to apache_beam.egg-info/entry_points.txt
reading manifest file 'apache_beam.egg-info/SOURCES.txt'
reading manifest template 'MANIFEST.in'
warning: no files found matching 'README.md'
warning: no files found matching 'NOTICE'
warning: no files found matching 'LICENSE'
writing manifest file 'apache_beam.egg-info/SOURCES.txt'
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py>:168: DeprecationWarning: object() takes no parameters
  super(GcsIO, cls).__new__(cls, storage_client))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py>:168: DeprecationWarning: object() takes no parameters
  super(GcsIO, cls).__new__(cls, storage_client))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py>:743: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  transform_node.inputs[0].pipeline.options.view_as(StandardOptions))
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py>:49: DeprecationWarning: options is deprecated since First stable release.. References to <pipeline>.options will not be supported
  print('Found: %s.' % self.build_console_url(pipeline.options))
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ok
test_bigquery_tornadoes_it (apache_beam.examples.cookbook.bigquery_tornadoes_it_test.BigqueryTornadoesIT) ... ok
test_wordcount_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ok
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_19_00_45-9316448145584535552?project=apache-beam-testing.
test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT) ... ERROR

======================================================================
ERROR: test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 812, in run
    test(orig)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/case.py",> line 45, in __call__
    return self.run(*arg, **kwarg)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/case.py",> line 133, in run
    self.runTest(result)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/case.py",> line 151, in runTest
    test(result)
  File "/usr/lib/python2.7/unittest/case.py", line 395, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 331, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py",> line 113, in test_streaming_wordcount_it
    self.test_pipeline.get_full_options_as_args(**extra_opts))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount.py",> line 92, in run
    result = p.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/pipeline.py",> line 402, in run
    return self.runner.run_pipeline(self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 58, in run_pipeline
    hc_assert_that(self.result, pickler.loads(on_success_matcher))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/assert_that.py",> line 43, in assert_that
    _assert_match(actual=arg1, matcher=arg2, reason=arg3)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/assert_that.py",> line 55, in _assert_match
    matcher.describe_mismatch(actual, description)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/core/allof.py",> line 25, in describe_mismatch
    self.matches(item, mismatch_description)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/core/allof.py",> line 16, in matches
    if not matcher.matches(item):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/hamcrest/core/base_matcher.py",> line 28, in matches
    match_result = self._matches(item)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/tests/pubsub_matcher.py",> line 81, in _matches
    self.timeout)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/tests/pubsub_matcher.py",> line 90, in _wait_for_messages
    pulled = subscription.pull(max_messages=MAX_MESSAGES_IN_ONE_PULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/cloud/pubsub/subscription.py",> line 367, in pull
    self.full_name, return_immediately, max_messages)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/cloud/pubsub/_gax.py",> line 440, in subscription_pull
    return_immediately=return_immediately)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/cloud/gapic/pubsub/v1/subscriber_client.py",> line 706, in pull
    return self._pull(request, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/api_callable.py",> line 452, in inner
    return api_caller(api_call, this_settings, request)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/api_callable.py",> line 438, in base_caller
    return api_call(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/api_callable.py",> line 376, in inner
    return a_func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/google/gax/retry.py",> line 135, in inner
    time.sleep(to_sleep / _MILLIS_PER_SECOND)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT)'

----------------------------------------------------------------------
Ran 4 tests in 901.314s

FAILED (errors=1)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_19_00_34-7360918190272255732?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_19_00_35-6634183406654185572?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-03-30_19_00_35-6447135140435672752?project=apache-beam-testing.
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4547

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4547/display/redirect>

------------------------------------------
[...truncated 291.27 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-31 00:29:49.657561
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-31 00:29:50.209306
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-31 00:29:50.352455
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-31 00:29:50.366336
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-31 00:29:50.381745
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-31 00:29:50.467310
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-31 00:29:50.735394
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-31 00:29:50.764264
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-31 00:29:50.879186
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-31 00:29:50.918781
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
345.95user 6.71system 2:11.22elapsed 268%CPU (0avgtext+0avgdata 248684maxresident)k
0inputs+168outputs (0major+636924minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='1012932711'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
30.23user 0.29system 0:10.27elapsed 297%CPU (0avgtext+0avgdata 66252maxresident)k
0inputs+0outputs (0major+88223minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4546

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4546/display/redirect>

------------------------------------------
[...truncated 291.07 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 23:26:10.697928
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 23:26:12.877420
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 23:26:13.254729
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 23:26:13.281832
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 23:26:13.311403
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 23:26:13.637509
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 23:26:14.516240
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 23:26:14.605611
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 23:26:15.090165
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 23:26:15.223065
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
358.26user 11.80system 3:50.66elapsed 160%CPU (0avgtext+0avgdata 240604maxresident)k
8inputs+168outputs (0major+639761minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='332607943'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
37.87user 0.89system 0:32.95elapsed 117%CPU (0avgtext+0avgdata 66088maxresident)k
0inputs+0outputs (0major+87846minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4545

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4545/display/redirect>

------------------------------------------
[...truncated 984.20 KB...]
test_compatibility (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_getitem_param_must_be_tuple (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_getitem_param_must_have_length_2 (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_key_type_must_be_valid_composite_param (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_match_type_variables (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_repr (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_type_check_invalid_key_type (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_type_check_invalid_value_type (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_type_check_valid_composite_type (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_type_check_valid_simple_type (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_type_checks_not_dict (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_value_type_must_be_valid_composite_param (apache_beam.typehints.typehints_test.DictHintTestCase) ... ok
test_compatibility (apache_beam.typehints.typehints_test.GeneratorHintTestCase) ... ok
test_generator_argument_hint_invalid_yield_type (apache_beam.typehints.typehints_test.GeneratorHintTestCase) ... ok
test_generator_return_hint_invalid_yield_type (apache_beam.typehints.typehints_test.GeneratorHintTestCase) ... ok
test_repr (apache_beam.typehints.typehints_test.GeneratorHintTestCase) ... ok
test_compatibility (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok
test_getitem_invalid_composite_type_param (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok
test_repr (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok
test_tuple_compatibility (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok
test_type_check_must_be_iterable (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok
test_type_check_violation_invalid_composite_type (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok
test_type_check_violation_invalid_simple_type (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok
test_type_check_violation_valid_composite_type (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok
test_type_check_violation_valid_simple_type (apache_beam.typehints.typehints_test.IterableHintTestCase) ... ok
test_enforce_kv_type_constraint (apache_beam.typehints.typehints_test.KVHintTestCase) ... ok
test_getitem_param_must_be_tuple (apache_beam.typehints.typehints_test.KVHintTestCase) ... ok
test_getitem_param_must_have_length_2 (apache_beam.typehints.typehints_test.KVHintTestCase) ... ok
test_getitem_proxy_to_tuple (apache_beam.typehints.typehints_test.KVHintTestCase) ... ok
test_enforce_list_type_constraint_invalid_composite_type (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok
test_enforce_list_type_constraint_invalid_simple_type (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok
test_enforce_list_type_constraint_valid_composite_type (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok
test_enforce_list_type_constraint_valid_simple_type (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok
test_getitem_invalid_composite_type_param (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok
test_list_constraint_compatibility (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok
test_list_repr (apache_beam.typehints.typehints_test.ListHintTestCase) ... ok
test_getitem_proxy_to_union (apache_beam.typehints.typehints_test.OptionalHintTestCase) ... ok
test_getitem_sequence_not_allowed (apache_beam.typehints.typehints_test.OptionalHintTestCase) ... ok
test_any_return_type_hint (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok
test_must_be_primitive_type_or_type_constraint (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok
test_must_be_single_return_type (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok
test_no_kwargs_accepted (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok
test_type_check_composite_type (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok
test_type_check_simple_type (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok
test_type_check_violation (apache_beam.typehints.typehints_test.ReturnsDecoratorTestCase) ... ok
test_compatibility (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok
test_getitem_invalid_composite_type_param (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok
test_repr (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok
test_type_check_invalid_elem_type (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok
test_type_check_must_be_set (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok
test_type_check_valid_elem_composite_type (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok
test_type_check_valid_elem_simple_type (apache_beam.typehints.typehints_test.SetHintTestCase) ... ok
test_any_argument_type_hint (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_basic_type_assertion (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_composite_type_assertion (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_invalid_only_positional_arguments (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_must_be_primitive_type_or_constraint (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_valid_mix_positional_and_keyword_arguments (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_valid_only_positional_arguments (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_valid_simple_type_arguments (apache_beam.typehints.typehints_test.TakesDecoratorTestCase) ... ok
test_functions_as_regular_generator (apache_beam.typehints.typehints_test.TestGeneratorWrapper) ... ok
test_compatibility (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_compatibility_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_getitem_invalid_ellipsis_type_param (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_getitem_params_must_be_type_or_constraint (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_raw_tuple (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_repr (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_invalid_composite_type (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_invalid_composite_type_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_invalid_simple_type_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_invalid_simple_types (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_must_be_tuple (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_must_have_same_arity (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_valid_composite_type_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_valid_composite_types (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_valid_simple_type_arbitrary_length (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_type_check_valid_simple_types (apache_beam.typehints.typehints_test.TupleHintTestCase) ... ok
test_getitem_duplicates_ignored (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_getitem_must_be_valid_type_param (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_getitem_must_be_valid_type_param_cant_be_object_instance (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_getitem_nested_unions_flattened (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_nested_compatibility (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_compatibility (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_enforcement_composite_type_in_union (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_enforcement_not_part_of_union (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_enforcement_part_of_union (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_union_hint_repr (apache_beam.typehints.typehints_test.UnionHintTestCase) ... ok
test_deprecated_with_since_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_deprecated_with_since_current_message (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_deprecated_without_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_deprecated_without_since_should_fail (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_experimental_with_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_experimental_with_current_message (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_experimental_without_current (apache_beam.utils.annotations_test.AnnotationTests) ... ok
test_frequency (apache_beam.utils.annotations_test.AnnotationTests)
Tests that the filter 'once' is sufficient to print once per ... ok
test_equal_objects (apache_beam.utils.counters_test.CounterNameTest) ... ok
test_hash_two_objects (apache_beam.utils.counters_test.CounterNameTest) ... ok
test_method_forwarding_not_windows (apache_beam.utils.processes_test.Exec) ... ok
test_method_forwarding_windows (apache_beam.utils.processes_test.Exec) ... ok
test_call_two_objects (apache_beam.utils.retry_test.RetryStateTest) ... ok
test_single_failure (apache_beam.utils.retry_test.RetryStateTest) ... ok
test_two_failures (apache_beam.utils.retry_test.RetryStateTest) ... ok
test_log_calls_for_permanent_failure (apache_beam.utils.retry_test.RetryTest) ... ok
test_log_calls_for_transient_failure (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_default_number_of_retries (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_explicit_decorator (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_explicit_initial_delay (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_explicit_number_of_retries (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_http_error_that_should_be_retried (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_http_error_that_should_not_be_retried (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_no_retry_decorator (apache_beam.utils.retry_test.RetryTest) ... ok
test_with_real_clock (apache_beam.utils.retry_test.RetryTest) ... ok
test_arithmetic (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_of (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_precision (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_sort_order (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_str (apache_beam.utils.timestamp_test.DurationTest) ... ok
test_arithmetic (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_from_rfc3339 (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_from_rfc3339_failure (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_from_utc_datetime (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_of (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_precision (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_sort_order (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_str (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_utc_timestamp (apache_beam.utils.timestamp_test.TimestampTest) ... ok
test_equality (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_hash (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_pickle (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_timestamps (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_with_value (apache_beam.utils.windowed_value_test.WindowedValueTest) ... ok
test_no_partial_writeouts (apache_beam.pipeline_test.DirectRunnerRetryTests) ... ok
test_retry_fork_graph (apache_beam.pipeline_test.DirectRunnerRetryTests) ... ok
test_element (apache_beam.pipeline_test.DoFnTest) ... ok
test_side_input_no_tag (apache_beam.pipeline_test.DoFnTest) ... ok
test_side_input_tagged (apache_beam.pipeline_test.DoFnTest) ... ok
test_timestamp_param (apache_beam.pipeline_test.DoFnTest) ... ok
test_timestamp_param_map (apache_beam.pipeline_test.DoFnTest) ... ok
test_window_param (apache_beam.pipeline_test.DoFnTest) ... ok
test_attribute_setting (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_defaults (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_dir (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_flag_parsing (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_keyword_parsing (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_view_as (apache_beam.pipeline_test.PipelineOptionsTest) ... ok
test_aggregator_empty_input (apache_beam.pipeline_test.PipelineTest) ... ok
test_apply_custom_transform (apache_beam.pipeline_test.PipelineTest) ... ok
test_create (apache_beam.pipeline_test.PipelineTest) ... ok
test_create_singleton_pcollection (apache_beam.pipeline_test.PipelineTest) ... ok
test_fake_read (apache_beam.pipeline_test.PipelineTest) ... ok
test_flatmap_builtin (apache_beam.pipeline_test.PipelineTest) ... ok
test_memory_usage (apache_beam.pipeline_test.PipelineTest) ... ok
test_metrics_in_fake_source (apache_beam.pipeline_test.PipelineTest) ... ok
test_pipeline_as_context (apache_beam.pipeline_test.PipelineTest) ... ok
test_ptransform_override_type_hints (apache_beam.pipeline_test.PipelineTest) ... ok
test_ptransform_overrides (apache_beam.pipeline_test.PipelineTest) ... ok
test_reuse_cloned_custom_transform_instance (apache_beam.pipeline_test.PipelineTest) ... ok
test_reuse_custom_transform_instance (apache_beam.pipeline_test.PipelineTest) ... ok
test_transform_no_super_init (apache_beam.pipeline_test.PipelineTest) ... ok
test_visit_entire_graph (apache_beam.pipeline_test.PipelineTest) ... ok
test_parent_pointer (apache_beam.pipeline_test.RunnerApiTest) ... ok
test_pickling (apache_beam.pipeline_test.RunnerApiTest) ... ok
test_simple (apache_beam.pipeline_test.RunnerApiTest)
Tests serializing, deserializing, and running a simple pipeline. ... ok
test_assingleton_multi_element (apache_beam.pvalue_test.PValueTest) ... ok
test_pvalue_expected_arguments (apache_beam.pvalue_test.PValueTest) ... ok
test_file_checksum_matchcer_invalid_sleep_time (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_read_failed (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_service_error (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_sleep_before_verify (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_file_checksum_matcher_success (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest) ... ok
test_pipeline_state_matcher_fails (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest)
Test PipelineStateMatcher fails when using default expected state ... ok
test_pipeline_state_matcher_given_state (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest)
Test PipelineStateMatcher successes when matches given state ... ok
test_pipeline_state_matcher_success (apache_beam.testing.pipeline_verifiers_test.PipelineVerifiersTest)
Test PipelineStateMatcher successes when using default expected state ... ok
test_append_extra_options (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_append_verifier_in_extra_opt (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_create_test_pipeline_options (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_empty_option_args_parsing (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_get_option (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_option_args_parsing (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... ok
test_skip_IT (apache_beam.testing.test_pipeline_test.TestPipelineTest) ... SKIP: IT is skipped because --test-pipeline-options is not specified
test_basic_execution (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_basic_execution_sideinputs (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_basic_execution_sideinputs_batch (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_basic_test_stream (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_gbk_execution_after_processing_trigger_fired (apache_beam.testing.test_stream_test.TestStreamTest)
Advance TestClock to (X + delta) and see the pipeline does finish. ... ok
test_gbk_execution_after_watermark_trigger (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_gbk_execution_no_triggers (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_test_stream_errors (apache_beam.testing.test_stream_test.TestStreamTest) ... ok
test_cleanup_subscriptions (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_cleanup_topics (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_delete_files_fails_with_invalid_arg (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_delete_files_fails_with_io_error (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_delete_files_succeeds (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_temp_dir_removes_files (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_temp_file_field_correct (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_wait_for_subscriptions_created_fails (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_wait_for_subscriptions_created_succeeds (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_wait_for_topics_created_fails (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_wait_for_topics_created_succeeds (apache_beam.testing.test_utils_test.TestUtilsTest) ... ok
test_assert_that_fails (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_fails_on_empty_expected (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_fails_on_empty_input (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_passes (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_passes_empty_equal_to (apache_beam.testing.util_test.UtilTest) ... ok
test_assert_that_passes_empty_is_empty (apache_beam.testing.util_test.UtilTest) ... ok
test_windowed_value_assert_fail_unmatched_timestamp (apache_beam.testing.util_test.UtilTest) ... ok
test_windowed_value_assert_fail_unmatched_value (apache_beam.testing.util_test.UtilTest) ... ok
test_windowed_value_assert_fail_unmatched_window (apache_beam.testing.util_test.UtilTest) ... ok
test_windowed_value_passes (apache_beam.testing.util_test.UtilTest) ... ok

----------------------------------------------------------------------
Ran 1551 tests in 536.395s

OK (skipped=44)
___________________________________ summary ____________________________________
  cover: commands succeeded
  docs: commands succeeded
ERROR:   lint_py2: commands failed
  lint_py3: commands succeeded
  py27: commands succeeded
  py27cython: commands succeeded
  py27gcp: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4544

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4544/display/redirect?page=changes>

Changes:

[wcn] Fix golint issues

[robertwb] Optimize reshuffle.

[robertwb] Add PipelineRunner.run_async for non-blocking execution.

------------------------------------------
[...truncated 291.17 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 20:50:18.030522
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 20:50:19.053095
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 20:50:19.316035
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 20:50:19.344472
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 20:50:19.376030
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 20:50:19.553258
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 20:50:20.065747
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 20:50:20.121111
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 20:50:20.342453
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 20:50:20.414042
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
356.72user 7.62system 2:08.06elapsed 284%CPU (0avgtext+0avgdata 246532maxresident)k
32inputs+168outputs (0major+648220minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='1538324538'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
29.79user 0.24system 0:09.90elapsed 303%CPU (0avgtext+0avgdata 66132maxresident)k
0inputs+0outputs (0major+88579minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4543

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4543/display/redirect>

------------------------------------------
[...truncated 291.66 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 20:10:47.203184
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 20:10:47.750753
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 20:10:47.896686
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 20:10:47.911453
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 20:10:47.930540
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 20:10:48.021240
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 20:10:48.319363
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 20:10:48.351366
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 20:10:48.487426
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 20:10:48.533206
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
355.84user 6.93system 2:07.50elapsed 284%CPU (0avgtext+0avgdata 246044maxresident)k
2920inputs+168outputs (0major+652639minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='3673781195'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
35.56user 0.26system 0:13.07elapsed 273%CPU (0avgtext+0avgdata 66260maxresident)k
200inputs+0outputs (0major+89084minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4542

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4542/display/redirect>

------------------------------------------
[...truncated 321.12 KB...]
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 18:43:26.387188
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 18:43:26.535481
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 18:43:26.552227
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 18:43:26.569098
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 18:43:26.657528
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 18:43:26.932264
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 18:43:26.961988
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 18:43:27.079310
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 18:43:27.117904
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
344.36user 6.85system 1:51.61elapsed 314%CPU (0avgtext+0avgdata 261684maxresident)k
48inputs+168outputs (0major+651752minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py27-lint finish: runtests after 111.92 seconds
py3-lint start: getenv <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
setting PATH=<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin>:/home/jenkins/tools/java/latest1.8/bin:/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin:/usr/games:/usr/local/games
  <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox$> /usr/bin/python -m virtualenv --python /usr/bin/python py3-lint ><https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/log/py3-lint-0.log>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
setting PATH=<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin>:/home/jenkins/tools/java/latest1.8/bin:/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin:/usr/games:/usr/local/games
  <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python$> <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin/pip> install pycodestyle==2.3.1 pylint==1.7.2 future==0.16.0 isort==4.2.15 flake8==3.5.0 ><https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/log/py3-lint-1.log>
py3-lint finish: getenv after 5.55 seconds
py3-lint start: installpkg <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
setting PATH=<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin>:/home/jenkins/tools/java/latest1.8/bin:/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin:/usr/games:/usr/local/games
  <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python$> <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin/pip> install <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip> ><https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/log/py3-lint-2.log>
py3-lint finish: installpkg after 12.96 seconds
py3-lint start: envreport 
setting PATH=<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin>:/home/jenkins/tools/java/latest1.8/bin:/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin:/usr/games:/usr/local/games
  <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python$> <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin/pip> freeze ><https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/log/py3-lint-3.log>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint finish: envreport after 0.51 seconds
py3-lint start: runtests 
py3-lint runtests: PYTHONHASHSEED='601194479'
py3-lint runtests: commands[0] | python --version
setting PATH=<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin>:/home/jenkins/tools/java/latest1.8/bin:/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin:/usr/games:/usr/local/games
  <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python$> <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin/python> --version 
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
setting PATH=<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin>:/home/jenkins/tools/java/latest1.8/bin:/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin:/usr/games:/usr/local/games
  <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python$> <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin/pip> --version 
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
setting PATH=<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/bin>:/home/jenkins/tools/java/latest1.8/bin:/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin:/usr/games:/usr/local/games
  <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python$> /usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh> 
Running flake8 for module apache_beam:
0
36.10user 0.35system 0:13.54elapsed 269%CPU (0avgtext+0avgdata 66132maxresident)k
0inputs+0outputs (0major+88812minor)pagefaults 0swaps
py3-lint finish: runtests after 13.85 seconds
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4541

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4541/display/redirect?page=changes>

Changes:

[XuMingmin] [BEAM-591] Support custom timestamps & CreateTime support (#4935)

------------------------------------------
[...truncated 291.15 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 18:04:02.353860
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 18:04:03.439745
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 18:04:03.721009
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 18:04:03.747269
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 18:04:03.777179
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 18:04:03.947560
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 18:04:04.482339
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 18:04:04.539205
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 18:04:04.765161
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 18:04:04.831268
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
358.58user 7.22system 2:12.74elapsed 275%CPU (0avgtext+0avgdata 261096maxresident)k
1056inputs+168outputs (1major+640653minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='2327255111'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
38.17user 0.39system 0:22.49elapsed 171%CPU (0avgtext+0avgdata 66232maxresident)k
8inputs+0outputs (0major+88372minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4540

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4540/display/redirect?page=changes>

Changes:

[tgroh] Reintroduce MetricName#name[space]

------------------------------------------
[...truncated 291.14 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 17:11:05.319706
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 17:11:05.878493
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 17:11:06.029433
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 17:11:06.044637
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 17:11:06.063024
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 17:11:06.155024
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 17:11:06.440482
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 17:11:06.470993
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 17:11:06.593281
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 17:11:06.632681
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
347.18user 7.41system 1:41.72elapsed 348%CPU (0avgtext+0avgdata 246628maxresident)k
0inputs+168outputs (0major+652036minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='85257674'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
30.61user 0.29system 0:10.69elapsed 288%CPU (0avgtext+0avgdata 66244maxresident)k
0inputs+0outputs (0major+88461minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4539

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4539/display/redirect>

------------------------------------------
[...truncated 291.74 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 16:41:14.632868
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 16:41:15.550691
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 16:41:15.773957
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 16:41:15.802215
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 16:41:15.832677
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 16:41:16.006088
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 16:41:16.612547
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 16:41:16.735093
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 16:41:17.042811
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 16:41:17.117034
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
374.03user 7.33system 2:58.93elapsed 213%CPU (0avgtext+0avgdata 260240maxresident)k
0inputs+168outputs (0major+658420minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='4271808472'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
38.34user 0.32system 0:21.24elapsed 182%CPU (0avgtext+0avgdata 66208maxresident)k
0inputs+0outputs (0major+88722minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4538

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4538/display/redirect>

------------------------------------------
[...truncated 291.10 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 15:11:17.170971
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 15:11:17.732634
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 15:11:17.882672
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 15:11:17.898483
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 15:11:17.917817
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 15:11:18.025478
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 15:11:18.330736
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 15:11:18.361342
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 15:11:18.486238
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 15:11:18.525168
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
351.85user 8.54system 1:44.80elapsed 343%CPU (0avgtext+0avgdata 252040maxresident)k
0inputs+168outputs (0major+652020minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='46615879'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
28.45user 0.30system 0:09.78elapsed 293%CPU (0avgtext+0avgdata 66464maxresident)k
0inputs+0outputs (0major+88350minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4537

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4537/display/redirect>

------------------------------------------
[...truncated 291.11 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 09:43:42.902130
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 09:43:43.575680
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 09:43:43.756622
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 09:43:43.776157
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 09:43:43.797258
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 09:43:43.909021
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 09:43:44.243322
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 09:43:44.274523
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 09:43:44.399698
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 09:43:44.439560
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
343.45user 9.42system 1:41.60elapsed 347%CPU (0avgtext+0avgdata 257648maxresident)k
2616inputs+168outputs (0major+655137minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='1842172683'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
29.63user 0.26system 0:10.54elapsed 283%CPU (0avgtext+0avgdata 65132maxresident)k
8inputs+0outputs (0major+90633minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4536

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4536/display/redirect>

------------------------------------------
[...truncated 291.11 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 03:20:47.608517
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 03:20:48.157118
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 03:20:48.307296
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 03:20:48.322701
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 03:20:48.338581
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 03:20:48.426230
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 03:20:48.698064
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 03:20:48.728723
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 03:20:48.848374
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 03:20:48.886697
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
343.89user 7.60system 1:39.78elapsed 352%CPU (0avgtext+0avgdata 254672maxresident)k
0inputs+168outputs (0major+646013minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='2024082232'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
29.57user 0.30system 0:10.00elapsed 298%CPU (0avgtext+0avgdata 66392maxresident)k
0inputs+0outputs (0major+88935minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4535

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/4535/display/redirect>

------------------------------------------
[...truncated 291.73 KB...]
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.test_utils import delete_files
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class WordCountIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:before	2018-03-23 17:50:29.204663
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py>:after	2018-03-30 03:10:54.575040
@@ -29,15 +29,14 @@
 import unittest
 import uuid
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import streaming_wordcount
 from apache_beam.io.gcp.tests.pubsub_matcher import PubSubMessageMatcher
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 INPUT_TOPIC = 'wc_topic_input'
 OUTPUT_TOPIC = 'wc_topic_output'
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:before	2018-01-24 00:22:36.719312
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py>:after	2018-03-30 03:10:55.182525
@@ -21,14 +21,13 @@
 import time
 import unittest
 
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples.cookbook import bigquery_tornadoes
 from apache_beam.io.gcp.tests import utils
 from apache_beam.io.gcp.tests.bigquery_matcher import BigqueryMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.core.allof import all_of
+from nose.plugins.attrib import attr
 
 
 class BigqueryTornadoesIT(unittest.TestCase):
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline_test.py>:after	2018-03-30 03:10:55.333805
@@ -20,12 +20,11 @@
 import logging
 import unittest
 
-from hamcrest.core.assert_that import assert_that as hc_assert_that
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.testing.test_pipeline import TestPipeline
+from hamcrest.core.assert_that import assert_that as hc_assert_that
+from hamcrest.core.base_matcher import BaseMatcher
 
 
 # A simple matcher that is ued for testing extra options appending.
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:before	2018-01-24 00:22:36.959311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py>:after	2018-03-30 03:10:55.350012
@@ -25,12 +25,11 @@
 import logging
 import time
 
-from hamcrest.core.base_matcher import BaseMatcher
-
 from apache_beam.io.filesystems import FileSystems
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import test_utils as utils
 from apache_beam.utils import retry
+from hamcrest.core.base_matcher import BaseMatcher
 
 __all__ = [
     'PipelineStateMatcher',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:before	2018-02-14 17:17:58.815289
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers_test.py>:after	2018-03-30 03:10:55.367426
@@ -21,7 +21,6 @@
 import tempfile
 import unittest
 
-from hamcrest import assert_that as hc_assert_that
 from mock import Mock
 from mock import patch
 
@@ -30,6 +29,7 @@
 from apache_beam.runners.runner import PipelineState
 from apache_beam.testing import pipeline_verifiers as verifiers
 from apache_beam.testing.test_utils import patch_retry
+from hamcrest import assert_that as hc_assert_that
 
 try:
   # pylint: disable=wrong-import-order, wrong-import-position
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:before	2018-03-21 03:17:48.486161
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py>:after	2018-03-30 03:10:55.465639
@@ -20,12 +20,11 @@
 import argparse
 import shlex
 
-from nose.plugins.skip import SkipTest
-
 from apache_beam.internal import pickler
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.pipeline import Pipeline
 from apache_beam.runners.runner import PipelineState
+from nose.plugins.skip import SkipTest
 
 __all__ = [
     'TestPipeline',
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:before	2018-02-14 00:08:23.317406
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/combiners_test.py>:after	2018-03-30 03:10:55.759254
@@ -19,10 +19,9 @@
 
 import unittest
 
-import hamcrest as hc
-
 import apache_beam as beam
 import apache_beam.transforms.combiners as combine
+import hamcrest as hc
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:before	2018-03-06 17:44:37.983556
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/display_test.py>:after	2018-03-30 03:10:55.791896
@@ -22,16 +22,16 @@
 import unittest
 from datetime import datetime
 
+import six
+
+import apache_beam as beam
 # pylint: disable=ungrouped-imports
 import hamcrest as hc
-import six
-from hamcrest.core.base_matcher import BaseMatcher
-
-import apache_beam as beam
 from apache_beam.options.pipeline_options import PipelineOptions
 from apache_beam.transforms.display import DisplayData
 from apache_beam.transforms.display import DisplayDataItem
 from apache_beam.transforms.display import HasDisplayData
+from hamcrest.core.base_matcher import BaseMatcher
 
 # pylint: enable=ungrouped-imports
 
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:before	2018-03-01 20:03:53.966026
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py>:after	2018-03-30 03:10:55.913582
@@ -26,13 +26,11 @@
 import unittest
 from functools import reduce
 
-import hamcrest as hc
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 import apache_beam.pvalue as pvalue
 import apache_beam.transforms.combiners as combine
 import apache_beam.typehints as typehints
+import hamcrest as hc
 from apache_beam.io.iobase import Read
 from apache_beam.metrics import Metrics
 from apache_beam.metrics.metric import MetricsFilter
@@ -49,6 +47,7 @@
 from apache_beam.typehints import with_output_types
 from apache_beam.typehints.typehints_test import TypeHintTestCase
 from apache_beam.utils.windowed_value import WindowedValue
+from nose.plugins.attrib import attr
 
 # Disable frequent lint warning due to pipe operator for chaining transforms.
 # pylint: disable=expression-not-assigned
ERROR: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py> Imports are incorrectly sorted.
--- <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:before	2018-01-24 00:22:36.983311
+++ <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/transforms/sideinputs_test.py>:after	2018-03-30 03:10:55.955656
@@ -20,13 +20,12 @@
 import logging
 import unittest
 
-from nose.plugins.attrib import attr
-
 import apache_beam as beam
 from apache_beam.testing.test_pipeline import TestPipeline
 from apache_beam.testing.util import assert_that
 from apache_beam.testing.util import equal_to
 from apache_beam.transforms import window
+from nose.plugins.attrib import attr
 
 
 class SideInputsTest(unittest.TestCase):
Command exited with non-zero status 1
348.43user 9.36system 1:42.65elapsed 348%CPU (0avgtext+0avgdata 249848maxresident)k
80inputs+168outputs (0major+645752minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh'>
py3-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint>
py3-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py3-lint inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py3-lint installed: apache-beam==2.5.0.dev0,astroid==1.6.2,avro==1.8.2,backports.functools-lru-cache==1.5,certifi==2018.1.18,chardet==3.0.4,configparser==3.5.0,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,flake8==3.5.0,funcsigs==1.0.2,future==0.16.0,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,isort==4.2.15,lazy-object-proxy==1.3.1,mccabe==0.6.1,mock==2.0.0,oauth2client==4.1.2,pbr==4.0.0,protobuf==3.5.2.post1,pyasn1==0.4.2,pyasn1-modules==0.2.1,pycodestyle==2.3.1,pyflakes==1.6.0,pylint==1.7.2,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,singledispatch==3.4.0.3,six==1.11.0,typing==3.6.4,urllib3==1.22,wrapt==1.10.11
py3-lint runtests: PYTHONHASHSEED='348519100'
py3-lint runtests: commands[0] | python --version
Python 2.7.6
py3-lint runtests: commands[1] | pip --version
pip 9.0.3 from <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py3-lint/local/lib/python2.7/site-packages> (python 2.7)
py3-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_mini_py3lint.sh>
Running flake8 for module apache_beam:
0
29.41user 0.21system 0:10.01elapsed 295%CPU (0avgtext+0avgdata 66236maxresident)k
8inputs+0outputs (0major+88441minor)pagefaults 0swaps
___________________________________ summary ____________________________________
  cover: commands succeeded
ERROR:   docs: commands failed
ERROR:   py27: commands failed
ERROR:   py27-cython2: commands failed
ERROR:   py27-gcp: commands failed
ERROR:   py27-lint: commands failed
  py3-lint: commands succeeded
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aromanenko.dev@gmail.com