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/23 19:27:32 UTC

Build failed in Jenkins: beam_PostCommit_Python_Verify #4492

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

Changes:

[coheigea] Put the String literal first when comparing it to an Object

[jb] [BEAM-3500] "Attach" JDBC connection to the bundle (improve the pooling)

[jb] [BEAM-3500] Test if the user provides both withDataSourceConfiguration()

[jb] [BEAM-3500] Wrap the datasource as a poolable datasource and expose

[jb] [BEAM-3500] Add commons-pool2 dependency

[jb] [BEAM-3500] Only expose max number of connections in the pool to the

[jb] [BEAM-3500] Cleanup pool configuration parameters

[jb] [BEAM-3500] Remove dataSourceFactory

[jb] [BEAM-3500] Remove unecessary check on dataSourceConfiguration

[mariand] Switched AvroIO default codec to snappyCodec().

[aaltay] [BEAM-3738] Enable py3 lint and cleanup tox.ini. (#4877)

------------------------------------------
[...truncated 290.28 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-23 19:26:43.761648
@@ -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-23 19:26:44.298138
@@ -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-23 19:26:44.443558
@@ -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-23 19:26:44.458369
@@ -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-23 19:26:44.475372
@@ -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-23 19:26:44.564841
@@ -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-23 19:26:44.848531
@@ -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-23 19:26:44.879364
@@ -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-23 19:26:45.003122
@@ -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-23 19:26:45.050930
@@ -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
346.45user 6.78system 1:59.63elapsed 295%CPU (0avgtext+0avgdata 242264maxresident)k
2776inputs+168outputs (1major+645237minor)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==3.1.1,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,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='3583413236'
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
27.46user 0.24system 0:10.19elapsed 271%CPU (0avgtext+0avgdata 68324maxresident)k
8inputs+0outputs (0major+89651minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@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

Build failed in Jenkins: beam_PostCommit_Python_Verify #4534

Posted by Apache Jenkins Server <je...@builds.apache.org>.
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

Build failed in Jenkins: beam_PostCommit_Python_Verify #4533

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

Changes:

[altay] Update streaming wordcount example and allign with the batch example.

------------------------------------------
[...truncated 260.74 KB...]
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
41.47user 2.28system 0:18.71elapsed 233%CPU (0avgtext+0avgdata 153704maxresident)k
0inputs+40848outputs (0major+498984minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='9398634'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='9398634'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='9398634'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='9398634'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, -0.00)

Command exited with non-zero status 16
306.00user 9.50system 1:30.84elapsed 347%CPU (0avgtext+0avgdata 241484maxresident)k
0inputs+168outputs (0major+535337minor)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='9398634'
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.95user 0.26system 0:10.08elapsed 299%CPU (0avgtext+0avgdata 66464maxresident)k
0inputs+0outputs (0major+88758minor)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 #4532

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

------------------------------------------
[...truncated 260.86 KB...]
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
42.27user 2.16system 0:18.48elapsed 240%CPU (0avgtext+0avgdata 152756maxresident)k
304inputs+40848outputs (2major+493343minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='3460092797'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='3460092797'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='3460092797'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='3460092797'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00)

Command exited with non-zero status 16
300.10user 8.53system 1:22.15elapsed 375%CPU (0avgtext+0avgdata 246100maxresident)k
2568inputs+168outputs (0major+540309minor)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='3460092797'
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
27.28user 0.24system 0:10.13elapsed 271%CPU (0avgtext+0avgdata 68176maxresident)k
56inputs+0outputs (0major+89037minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user aromanenko.dev@gmail.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4531

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

Changes:

[wcn] Remove include directives for proto well-known-types.

------------------------------------------
[...truncated 260.88 KB...]
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
41.72user 2.33system 0:18.58elapsed 237%CPU (0avgtext+0avgdata 152640maxresident)k
312inputs+40912outputs (2major+496720minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='1902418334'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='1902418334'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='1902418334'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='1902418334'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00)

Command exited with non-zero status 16
298.09user 6.60system 1:20.82elapsed 376%CPU (0avgtext+0avgdata 251896maxresident)k
2576inputs+168outputs (0major+547321minor)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='1902418334'
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.16user 0.20system 0:10.85elapsed 261%CPU (0avgtext+0avgdata 68248maxresident)k
56inputs+0outputs (0major+88990minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user aromanenko.dev@gmail.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4530

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

------------------------------------------
[...truncated 260.87 KB...]
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
42.04user 2.10system 0:18.75elapsed 235%CPU (0avgtext+0avgdata 153792maxresident)k
0inputs+40832outputs (0major+492134minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='1613378511'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='1613378511'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='1613378511'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='1613378511'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00)

Command exited with non-zero status 16
301.20user 8.23system 1:25.03elapsed 363%CPU (0avgtext+0avgdata 243824maxresident)k
0inputs+168outputs (0major+551108minor)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='1613378511'
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.12user 0.25system 0:10.79elapsed 272%CPU (0avgtext+0avgdata 68456maxresident)k
0inputs+0outputs (0major+88881minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user aromanenko.dev@gmail.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4529

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

------------------------------------------
[...truncated 260.87 KB...]
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
44.11user 2.21system 0:19.05elapsed 243%CPU (0avgtext+0avgdata 151960maxresident)k
360inputs+40856outputs (2major+487183minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='3949638591'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='3949638591'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='3949638591'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='3949638591'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00)

Command exited with non-zero status 16
296.28user 8.16system 1:20.38elapsed 378%CPU (0avgtext+0avgdata 243932maxresident)k
2568inputs+168outputs (0major+541485minor)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='3949638591'
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.62user 0.22system 0:10.91elapsed 264%CPU (0avgtext+0avgdata 68324maxresident)k
56inputs+0outputs (0major+88889minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user aromanenko.dev@gmail.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4528

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

------------------------------------------
[...truncated 260.87 KB...]
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
41.79user 2.33system 0:18.93elapsed 233%CPU (0avgtext+0avgdata 150656maxresident)k
192inputs+40856outputs (0major+489335minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='2501701503'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='2501701503'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='2501701503'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='2501701503'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00)

Command exited with non-zero status 16
304.46user 8.46system 1:27.76elapsed 356%CPU (0avgtext+0avgdata 250192maxresident)k
0inputs+168outputs (0major+544393minor)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='2501701503'
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
26.98user 0.23system 0:10.71elapsed 254%CPU (0avgtext+0avgdata 68248maxresident)k
0inputs+0outputs (0major+88900minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user aromanenko.dev@gmail.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4527

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

Changes:

[lcwik] [BEAM-3326] Address additional comments from PR/4963.

[lcwik] [BEAM-3104] Set up state interfaces, wire into SDK harness client.

------------------------------------------
[...truncated 260.92 KB...]
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
41.70user 2.22system 0:18.81elapsed 233%CPU (0avgtext+0avgdata 153500maxresident)k
976inputs+40888outputs (2major+497150minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='56224873'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='56224873'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='56224873'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='56224873'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00)

Command exited with non-zero status 16
294.78user 6.76system 1:19.53elapsed 379%CPU (0avgtext+0avgdata 246636maxresident)k
2704inputs+168outputs (1major+544322minor)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='56224873'
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
27.89user 0.22system 0:11.22elapsed 250%CPU (0avgtext+0avgdata 68372maxresident)k
56inputs+0outputs (0major+88975minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user aromanenko.dev@gmail.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4526

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

------------------------------------------
[...truncated 260.89 KB...]
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
50.44user 2.17system 0:24.52elapsed 214%CPU (0avgtext+0avgdata 153268maxresident)k
568inputs+40808outputs (3major+506259minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='2480455699'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='2480455699'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='2480455699'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='2480455699'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, -0.00)

Command exited with non-zero status 16
309.72user 7.20system 1:37.40elapsed 325%CPU (0avgtext+0avgdata 243356maxresident)k
2272inputs+168outputs (0major+544768minor)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='2480455699'
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
39.34user 0.36system 0:26.03elapsed 152%CPU (0avgtext+0avgdata 68332maxresident)k
56inputs+0outputs (0major+89405minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user aromanenko.dev@gmail.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4525

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

Changes:

[mairbek] [BEAM-3932] Adds handling of array null values to MutationSizeEstimator

[aromanenko.dev] [BEAM-3819] Add withRequestRecordsLimit() option to KinesisIO

[altay] [BEAM-3738] Add more flake8 tests to run_pylint.sh

------------------------------------------
[...truncated 260.97 KB...]
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
41.78user 2.52system 0:18.62elapsed 237%CPU (0avgtext+0avgdata 151420maxresident)k
48inputs+40888outputs (2major+505861minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='240766130'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='240766130'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='240766130'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='240766130'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, -0.00)

Command exited with non-zero status 16
302.65user 6.82system 1:23.58elapsed 370%CPU (0avgtext+0avgdata 247672maxresident)k
328inputs+168outputs (0major+550211minor)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='240766130'
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.93user 0.23system 0:10.27elapsed 283%CPU (0avgtext+0avgdata 68256maxresident)k
0inputs+0outputs (0major+89488minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user aromanenko.dev@gmail.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4524

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

Changes:

[lcwik] [BEAM-3326] Abstract away closing the inbound receiver, waiting for the

------------------------------------------
[...truncated 260.85 KB...]
Creating file target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst.
Creating file target/docs/source/apache_beam.io.gcp.gcsio.rst.
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
40.74user 2.61system 0:18.53elapsed 233%CPU (0avgtext+0avgdata 152084maxresident)k
328inputs+40816outputs (3major+499271minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='1580158648'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='1580158648'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='1580158648'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='1580158648'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00)

Command exited with non-zero status 16
298.89user 6.13system 1:19.51elapsed 383%CPU (0avgtext+0avgdata 276460maxresident)k
1256inputs+168outputs (0major+550479minor)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='1580158648'
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
26.79user 0.20system 0:10.33elapsed 261%CPU (0avgtext+0avgdata 68248maxresident)k
56inputs+0outputs (0major+89167minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4523

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

------------------------------------------
[...truncated 260.73 KB...]
Creating file target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst.
Creating file target/docs/source/apache_beam.io.gcp.gcsio.rst.
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
40.02user 2.45system 0:18.36elapsed 231%CPU (0avgtext+0avgdata 153132maxresident)k
296inputs+40832outputs (1major+499857minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='1965470360'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='1965470360'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='1965470360'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='1965470360'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00)

Command exited with non-zero status 16
299.26user 7.12system 1:21.06elapsed 377%CPU (0avgtext+0avgdata 253688maxresident)k
2152inputs+168outputs (0major+566450minor)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='1965470360'
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.58user 0.20system 0:10.93elapsed 263%CPU (0avgtext+0avgdata 68124maxresident)k
64inputs+0outputs (0major+89396minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4522

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

Changes:

[herohde] Migrate container instructions and builds to Gradle

[herohde] CR: added comments to container helper function

[herohde] CR: make containerImageName take named parameters

------------------------------------------
[...truncated 260.77 KB...]
Creating file target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst.
Creating file target/docs/source/apache_beam.io.gcp.gcsio.rst.
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
54.15user 3.36system 0:53.75elapsed 107%CPU (0avgtext+0avgdata 150244maxresident)k
616inputs+40856outputs (1major+503634minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='844402220'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='844402220'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='844402220'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='844402220'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, +0.00)

Command exited with non-zero status 16
310.36user 9.38system 2:53.06elapsed 184%CPU (0avgtext+0avgdata 261472maxresident)k
2608inputs+168outputs (1major+556320minor)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='844402220'
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.08user 1.10system 0:36.51elapsed 107%CPU (0avgtext+0avgdata 63788maxresident)k
56inputs+0outputs (0major+90638minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4521

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

Changes:

[rober] Go SDK usercounters

[ccy] Revert #4781 which broke Python postsubmits

------------------------------------------
[...truncated 260.77 KB...]
Creating file target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst.
Creating file target/docs/source/apache_beam.io.gcp.gcsio.rst.
Creating file target/docs/source/apache_beam.io.gcp.pubsub.rst.
Creating file target/docs/source/apache_beam.io.gcp.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.adaptive_throttler.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.datastoreio.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.fake_datastore.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.helper.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.query_splitter.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.util.rst.
Creating file target/docs/source/apache_beam.io.gcp.datastore.v1.rst.
Creating file target/docs/source/apache_beam.metrics.cells.rst.
Creating file target/docs/source/apache_beam.metrics.metric.rst.
Creating file target/docs/source/apache_beam.metrics.metricbase.rst.
Creating file target/docs/source/apache_beam.metrics.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options.rst.
Creating file target/docs/source/apache_beam.options.pipeline_options_validator.rst.
Creating file target/docs/source/apache_beam.options.value_provider.rst.
Creating file target/docs/source/apache_beam.options.rst.
Creating file target/docs/source/apache_beam.portability.common_urns.rst.
Creating file target/docs/source/apache_beam.portability.python_urns.rst.
Creating file target/docs/source/apache_beam.portability.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_artifact_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_fn_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_job_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_provision_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.beam_runner_api_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.endpoints_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.standard_window_fns_pb2_grpc.rst.
Creating file target/docs/source/apache_beam.portability.api.rst.
Creating file target/docs/source/apache_beam.runners.pipeline_context.rst.
Creating file target/docs/source/apache_beam.runners.runner.rst.
Creating file target/docs/source/apache_beam.runners.sdf_common.rst.
Creating file target/docs/source/apache_beam.runners.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_metrics.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.ptransform_overrides.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.test_dataflow_runner.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.iobase.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.streaming_create.rst.
Creating file target/docs/source/apache_beam.runners.dataflow.native_io.rst.
Creating file target/docs/source/apache_beam.runners.direct.bundle_factory.rst.
Creating file target/docs/source/apache_beam.runners.direct.clock.rst.
Creating file target/docs/source/apache_beam.runners.direct.consumer_tracking_pipeline_visitor.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_metrics.rst.
Creating file target/docs/source/apache_beam.runners.direct.direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.evaluation_context.rst.
Creating file target/docs/source/apache_beam.runners.direct.executor.rst.
Creating file target/docs/source/apache_beam.runners.direct.helper_transforms.rst.
Creating file target/docs/source/apache_beam.runners.direct.sdf_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.direct.transform_evaluator.rst.
Creating file target/docs/source/apache_beam.runners.direct.util.rst.
Creating file target/docs/source/apache_beam.runners.direct.watermark_manager.rst.
Creating file target/docs/source/apache_beam.runners.direct.rst.
Creating file target/docs/source/apache_beam.runners.experimental.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.python_rpc_direct_runner.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.server.rst.
Creating file target/docs/source/apache_beam.runners.experimental.python_rpc_direct.rst.
Creating file target/docs/source/apache_beam.runners.job.manager.rst.
Creating file target/docs/source/apache_beam.runners.job.utils.rst.
Creating file target/docs/source/apache_beam.runners.job.rst.
Creating file target/docs/source/apache_beam.testing.pipeline_verifiers.rst.
Creating file target/docs/source/apache_beam.testing.test_pipeline.rst.
Creating file target/docs/source/apache_beam.testing.test_stream.rst.
Creating file target/docs/source/apache_beam.testing.test_utils.rst.
Creating file target/docs/source/apache_beam.testing.util.rst.
Creating file target/docs/source/apache_beam.testing.rst.
Creating file target/docs/source/apache_beam.tools.rst.
Creating file target/docs/source/apache_beam.transforms.combiners.rst.
Creating file target/docs/source/apache_beam.transforms.core.rst.
Creating file target/docs/source/apache_beam.transforms.display.rst.
Creating file target/docs/source/apache_beam.transforms.ptransform.rst.
Creating file target/docs/source/apache_beam.transforms.sideinputs.rst.
Creating file target/docs/source/apache_beam.transforms.timeutil.rst.
Creating file target/docs/source/apache_beam.transforms.trigger.rst.
Creating file target/docs/source/apache_beam.transforms.util.rst.
Creating file target/docs/source/apache_beam.transforms.window.rst.
Creating file target/docs/source/apache_beam.transforms.rst.
Creating file target/docs/source/apache_beam.typehints.decorators.rst.
Creating file target/docs/source/apache_beam.typehints.native_type_compatibility.rst.
Creating file target/docs/source/apache_beam.typehints.opcodes.rst.
Creating file target/docs/source/apache_beam.typehints.trivial_inference.rst.
Creating file target/docs/source/apache_beam.typehints.typecheck.rst.
Creating file target/docs/source/apache_beam.typehints.typehints.rst.
Creating file target/docs/source/apache_beam.typehints.rst.
Creating file target/docs/source/apache_beam.utils.annotations.rst.
Creating file target/docs/source/apache_beam.utils.plugin.rst.
Creating file target/docs/source/apache_beam.utils.processes.rst.
Creating file target/docs/source/apache_beam.utils.profiler.rst.
Creating file target/docs/source/apache_beam.utils.proto_utils.rst.
Creating file target/docs/source/apache_beam.utils.retry.rst.
Creating file target/docs/source/apache_beam.utils.timestamp.rst.
Creating file target/docs/source/apache_beam.utils.urns.rst.
Creating file target/docs/source/apache_beam.utils.rst.
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/util/requests.py>:64: UserWarning: Some links may return broken results due to being unable to check the Server Name Indication (SNI) in the returned SSL cert against the hostname in the url requested. Recommended to install "requests[security]" as a dependency or upgrade to a python version with SNI support (Python 3 and Python 2.7.9+).
  'Some links may return broken results due to being unable to '
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/urllib3/util/ssl_.py>:339: SNIMissingWarning: An HTTPS request has been made, but the SNI (Subject Name Indication) extension to TLS is not available on this platform. This may cause the server to present an incorrect TLS certificate, which can cause validation failures. You can upgrade to a newer version of Python to solve this. For more information, see https://urllib3.readthedocs.io/en/latest/advanced-usage.html#ssl-warnings
  SNIMissingWarning
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsfilesystem.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsfilesystem'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsfilesystem.py",> line 27, in <module>
    from apache_beam.io.gcp import gcsio
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.io.gcp.gcsio.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.io.gcp.gcsio'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/gcsio.py",> line 59, in <module>
    'Google Cloud Storage I/O not supported for this execution environment '
ImportError: Google Cloud Storage I/O not supported for this execution environment (could not import storage API client).
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.pipeline_verifiers.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.pipeline_verifiers'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/pipeline_verifiers.py",> line 28, in <module>
    from hamcrest.core.base_matcher import BaseMatcher
ImportError: No module named hamcrest.core.base_matcher
<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/docs/source/apache_beam.testing.test_pipeline.rst>:4: WARNING: autodoc: failed to import module u'apache_beam.testing.test_pipeline'; the following exception was raised:
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/docs/local/lib/python2.7/site-packages/sphinx/ext/autodoc.py",> line 658, in import_object
    __import__(self.modname)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
Command exited with non-zero status 1
42.03user 2.53system 0:18.64elapsed 239%CPU (0avgtext+0avgdata 153392maxresident)k
944inputs+40848outputs (2major+508356minor)pagefaults 0swaps
ERROR: InvocationError: '/usr/bin/time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/generate_pydoc.sh'>
py27 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27>
py27 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27 runtests: PYTHONHASHSEED='3322486575'
py27 runtests: commands[0] | python --version
Python 2.7.6
py27 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/py27/local/lib/python2.7/site-packages> (python 2.7)
py27 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-cython2 create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2>
py27-cython2 installdeps: cython==0.26.1
py27-cython2 inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-cython2 installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,Cython==0.26.1,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-cython2 runtests: PYTHONHASHSEED='3322486575'
py27-cython2 runtests: commands[0] | python --version
Python 2.7.6
py27-cython2 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/py27-cython2/local/lib/python2.7/site-packages> (python 2.7)
py27-cython2 runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-cython2 runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-cython2/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-gcp create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp>
py27-gcp inst: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/dist/apache-beam-2.5.0.dev0.zip>
py27-gcp installed: apache-beam==2.5.0.dev0,avro==1.8.2,certifi==2018.1.18,chardet==3.0.4,crcmod==1.7,dill==0.2.6,docopt==0.6.2,enum34==1.1.6,funcsigs==1.0.2,futures==3.2.0,grpcio==1.10.0,hdfs==2.1.0,httplib2==0.9.2,idna==2.6,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,pytz==2018.3,PyVCF==0.6.8,PyYAML==3.12,requests==2.18.4,rsa==3.4.2,six==1.11.0,typing==3.6.4,urllib3==1.22
py27-gcp runtests: PYTHONHASHSEED='3322486575'
py27-gcp runtests: commands[0] | python --version
Python 2.7.6
py27-gcp 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/py27-gcp/local/lib/python2.7/site-packages> (python 2.7)
py27-gcp runtests: commands[2] | <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_tox_cleanup.sh>
py27-gcp runtests: commands[3] | python apache_beam/examples/complete/autocomplete_test.py
Traceback (most recent call last):
  File "apache_beam/examples/complete/autocomplete_test.py", line 24, in <module>
    from apache_beam.testing.test_pipeline import TestPipeline
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/local/lib/python2.7/site-packages/apache_beam/testing/test_pipeline.py",> line 23, in <module>
    from nose.plugins.skip import SkipTest
ImportError: No module named nose.plugins.skip
ERROR: InvocationError: '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-gcp/bin/python> apache_beam/examples/complete/autocomplete_test.py'
py27-lint create: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/target/.tox/py27-lint>
py27-lint installdeps: pycodestyle==2.3.1, pylint==1.7.2, future==0.16.0, isort==4.2.15, flake8==3.5.0
py27-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>
py27-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
py27-lint runtests: PYTHONHASHSEED='3322486575'
py27-lint runtests: commands[0] | python --version
Python 2.7.6
py27-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/py27-lint/local/lib/python2.7/site-packages> (python 2.7)
py27-lint runtests: commands[2] | time <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/run_pylint.sh>
Skipping lint for generated files: bigquery_v2_client.py, bigquery_v2_messages.py, dataflow_v1b3_client.py, dataflow_v1b3_messages.py, storage_v1_client.py, storage_v1_messages.py, proto2_coder_test_messages_pb2.py, beam_artifact_api_pb2_grpc.py, beam_artifact_api_pb2.py, beam_fn_api_pb2_grpc.py, beam_fn_api_pb2.py, beam_job_api_pb2_grpc.py, beam_job_api_pb2.py, beam_provision_api_pb2_grpc.py, beam_provision_api_pb2.py, beam_runner_api_pb2_grpc.py, beam_runner_api_pb2.py, endpoints_pb2_grpc.py, endpoints_pb2.py, standard_window_fns_pb2_grpc.py, standard_window_fns_pb2.py
Running pylint for module apache_beam:
************* Module apache_beam.typehints.typehints
C:1101, 0: Trailing newlines (trailing-newlines)

--------------------------------------------------------------------
Your code has been rated at 10.00/10 (previous run: 10.00/10, -0.00)

Command exited with non-zero status 16
304.05user 6.89system 1:24.11elapsed 369%CPU (0avgtext+0avgdata 241100maxresident)k
2952inputs+168outputs (0major+548221minor)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='3322486575'
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
33.08user 0.28system 0:12.05elapsed 276%CPU (0avgtext+0avgdata 68352maxresident)k
56inputs+0outputs (0major+89328minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user rober@frantil.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4520

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

Changes:

[tgroh] Cleanups in GroupAlsoByWindowEvaluatorFactory

[tgroh] Allow Fusion to Continue with unknown PTransforms

[tgroh] fixup! Allow Fusion to Continue with unknown PTransforms

[tgroh] fixup! fixup! Allow Fusion to Continue with unknown PTransforms

[chamikara] [BEAM-3744] Expand Pubsub read API for Python. (#4901)

------------------------------------------
[...truncated 291.28 KB...]
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 23:31:42.087540
@@ -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-27 23:31:42.847013
@@ -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-27 23:31:43.094108
@@ -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-27 23:31:43.123137
@@ -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-27 23:31:43.154884
@@ -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-27 23:31:43.323650
@@ -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-27 23:31:43.683206
@@ -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-27 23:31:43.714757
@@ -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-27 23:31:43.833021
@@ -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-27 23:31:43.883226
@@ -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
365.06user 7.86system 2:28.10elapsed 251%CPU (0avgtext+0avgdata 247240maxresident)k
2584inputs+168outputs (0major+653498minor)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='3777436987'
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
36.94user 0.30system 0:17.23elapsed 216%CPU (0avgtext+0avgdata 68036maxresident)k
8inputs+0outputs (0major+88548minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4519

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

------------------------------------------
[...truncated 290.23 KB...]
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 21:09:34.211296
@@ -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-27 21:09:34.770462
@@ -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-27 21:09:34.924515
@@ -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-27 21:09:34.938766
@@ -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-27 21:09:34.958238
@@ -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-27 21:09:35.063953
@@ -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-27 21:09:35.368337
@@ -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-27 21:09:35.398836
@@ -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-27 21:09:35.514931
@@ -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-27 21:09:35.564043
@@ -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.58user 7.77system 1:43.41elapsed 339%CPU (0avgtext+0avgdata 251956maxresident)k
8inputs+168outputs (0major+647018minor)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,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='1006003864'
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
27.76user 0.29system 0:10.39elapsed 269%CPU (0avgtext+0avgdata 68400maxresident)k
0inputs+0outputs (0major+89309minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4518

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

Changes:

[wcn] Fix documentation around pipeline creation.

------------------------------------------
[...truncated 290.24 KB...]
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 20:46:21.617160
@@ -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-27 20:46:22.146742
@@ -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-27 20:46:22.291014
@@ -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-27 20:46:22.306284
@@ -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-27 20:46:22.322953
@@ -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-27 20:46:22.413034
@@ -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-27 20:46:22.695605
@@ -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-27 20:46:22.728397
@@ -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-27 20:46:22.846190
@@ -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-27 20:46:22.885004
@@ -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.53user 7.16system 1:46.70elapsed 328%CPU (0avgtext+0avgdata 254324maxresident)k
1632inputs+168outputs (0major+644389minor)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,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='3708149440'
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.30user 0.26system 0:11.10elapsed 266%CPU (0avgtext+0avgdata 68368maxresident)k
8inputs+0outputs (0major+89427minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4517

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

Changes:

[dawid] [BEAM-2831] Do not wrap IOException in SerializableCoder

------------------------------------------
[...truncated 290.23 KB...]
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 18:30:08.641331
@@ -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-27 18:30:09.159732
@@ -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-27 18:30:09.301554
@@ -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-27 18:30:09.316018
@@ -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-27 18:30:09.332157
@@ -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-27 18:30:09.421399
@@ -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-27 18:30:09.693870
@@ -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-27 18:30:09.723681
@@ -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-27 18:30:09.838274
@@ -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-27 18:30:09.876828
@@ -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
341.14user 7.16system 1:40.06elapsed 348%CPU (0avgtext+0avgdata 247056maxresident)k
968inputs+168outputs (0major+648111minor)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==3.1.1,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,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='3926754265'
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
27.48user 0.40system 0:10.61elapsed 262%CPU (0avgtext+0avgdata 68284maxresident)k
8inputs+0outputs (0major+89457minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user dawid@getindata.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4516

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

------------------------------------------
[...truncated 290.24 KB...]
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 15:13:10.703033
@@ -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-27 15:13:11.219433
@@ -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-27 15:13:11.363370
@@ -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-27 15:13:11.378451
@@ -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-27 15:13:11.394413
@@ -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-27 15:13:11.481371
@@ -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-27 15:13:11.752115
@@ -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-27 15:13:11.782312
@@ -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-27 15:13:11.898112
@@ -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-27 15:13:11.936502
@@ -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.96user 7.23system 1:42.49elapsed 346%CPU (0avgtext+0avgdata 253064maxresident)k
1400inputs+168outputs (0major+646600minor)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==3.1.1,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,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='2016293441'
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
27.27user 0.23system 0:10.68elapsed 257%CPU (0avgtext+0avgdata 68456maxresident)k
8inputs+0outputs (0major+88992minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4515

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

------------------------------------------
[...truncated 290.24 KB...]
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 09:53:24.788261
@@ -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-27 09:53:25.313710
@@ -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-27 09:53:25.467825
@@ -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-27 09:53:25.481946
@@ -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-27 09:53:25.497861
@@ -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-27 09:53:25.595865
@@ -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-27 09:53:25.938747
@@ -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-27 09:53:25.978847
@@ -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-27 09:53:26.129052
@@ -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-27 09:53:26.179968
@@ -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
341.72user 7.08system 1:45.29elapsed 331%CPU (0avgtext+0avgdata 246616maxresident)k
2648inputs+168outputs (0major+652285minor)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==3.1.1,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,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='388605322'
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
33.62user 0.27system 0:11.97elapsed 282%CPU (0avgtext+0avgdata 68292maxresident)k
8inputs+0outputs (0major+89422minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4514

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

Changes:

[iemejia] [BEAM-3931] Remove commons-text dependency from Spark runner

------------------------------------------
[...truncated 290.26 KB...]
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 07:48:04.662292
@@ -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-27 07:48:05.194156
@@ -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-27 07:48:05.340619
@@ -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-27 07:48:05.354976
@@ -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-27 07:48:05.371158
@@ -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-27 07:48:05.457660
@@ -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-27 07:48:05.736169
@@ -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-27 07:48:05.766922
@@ -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-27 07:48:05.882481
@@ -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-27 07:48:05.926667
@@ -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
338.03user 8.64system 1:40.40elapsed 345%CPU (0avgtext+0avgdata 257968maxresident)k
0inputs+168outputs (0major+651766minor)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==3.1.1,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,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='2663711275'
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.79user 0.27system 0:10.49elapsed 277%CPU (0avgtext+0avgdata 68504maxresident)k
0inputs+0outputs (0major+89648minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4513

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

Changes:

[aljoscha.krettek] [BEAM-622] Add checkpointing tests for DoFnOperator and

[aljoscha.krettek] [BEAM-3087] Make reader state update and element emission atomic

[aljoscha.krettek] [BEAM-2393] Make BoundedSource fault-tolerant

------------------------------------------
[...truncated 290.31 KB...]
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 07:14:20.015406
@@ -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-27 07:14:20.533060
@@ -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-27 07:14:20.671941
@@ -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-27 07:14:20.685920
@@ -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-27 07:14:20.702018
@@ -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-27 07:14:20.787804
@@ -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-27 07:14:21.054361
@@ -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-27 07:14:21.083886
@@ -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-27 07:14:21.201452
@@ -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-27 07:14:21.239257
@@ -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
339.83user 10.16system 1:40.11elapsed 349%CPU (0avgtext+0avgdata 255988maxresident)k
1784inputs+168outputs (9major+646459minor)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==3.1.1,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,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='1269107773'
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.79user 0.40system 0:11.14elapsed 261%CPU (0avgtext+0avgdata 68420maxresident)k
0inputs+0outputs (0major+89838minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4512

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

Changes:

[ehudm] Fix test_pre_finalize_error to test exceptions.

------------------------------------------
[...truncated 290.19 KB...]
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 04:36:26.076255
@@ -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-27 04:36:26.641964
@@ -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-27 04:36:26.802871
@@ -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-27 04:36:26.818487
@@ -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-27 04:36:26.836247
@@ -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-27 04:36:26.933473
@@ -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-27 04:36:27.244579
@@ -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-27 04:36:27.278305
@@ -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-27 04:36:27.411156
@@ -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-27 04:36:27.455859
@@ -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.55user 8.82system 1:54.51elapsed 309%CPU (0avgtext+0avgdata 251916maxresident)k
288inputs+168outputs (2major+636278minor)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==3.1.1,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,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='1448963031'
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
33.85user 0.41system 0:12.64elapsed 271%CPU (0avgtext+0avgdata 68092maxresident)k
0inputs+0outputs (0major+89873minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4511

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

------------------------------------------
[...truncated 290.17 KB...]
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 03:29:31.906515
@@ -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-27 03:29:32.473091
@@ -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-27 03:29:32.650853
@@ -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-27 03:29:32.667921
@@ -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-27 03:29:32.683952
@@ -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-27 03:29:32.773815
@@ -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-27 03:29:33.088647
@@ -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-27 03:29:33.126182
@@ -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-27 03:29:33.266292
@@ -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-27 03:29:33.315179
@@ -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
340.15user 7.00system 1:44.96elapsed 330%CPU (0avgtext+0avgdata 240552maxresident)k
32inputs+168outputs (0major+647185minor)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==3.1.1,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,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='3724713863'
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
27.73user 0.20system 0:10.69elapsed 261%CPU (0avgtext+0avgdata 68276maxresident)k
8inputs+0outputs (0major+88880minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4510

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

Changes:

[github] Updated to Ubuntu 16 version of python 2

------------------------------------------
[...truncated 290.19 KB...]
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-27 00:37:26.752944
@@ -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-27 00:37:27.323411
@@ -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-27 00:37:27.497816
@@ -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-27 00:37:27.512230
@@ -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-27 00:37:27.529033
@@ -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-27 00:37:27.625827
@@ -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-27 00:37:27.924886
@@ -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-27 00:37:27.958086
@@ -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-27 00:37:28.098347
@@ -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-27 00:37:28.143168
@@ -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
340.04user 7.24system 1:43.36elapsed 335%CPU (0avgtext+0avgdata 279436maxresident)k
2048inputs+168outputs (0major+634513minor)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==3.1.1,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,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='3444374173'
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
33.42user 0.29system 0:12.15elapsed 277%CPU (0avgtext+0avgdata 68256maxresident)k
8inputs+0outputs (0major+89177minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4509

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

------------------------------------------
[...truncated 290.16 KB...]
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-26 21:41:51.353371
@@ -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-26 21:41:51.874260
@@ -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-26 21:41:52.013890
@@ -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-26 21:41:52.028268
@@ -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-26 21:41:52.044280
@@ -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-26 21:41:52.131054
@@ -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-26 21:41:52.401953
@@ -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-26 21:41:52.431688
@@ -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-26 21:41:52.548448
@@ -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-26 21:41:52.588915
@@ -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
338.00user 6.98system 1:38.65elapsed 349%CPU (0avgtext+0avgdata 263996maxresident)k
2656inputs+168outputs (0major+660859minor)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==3.1.1,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,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='2672169147'
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.42user 0.23system 0:10.93elapsed 262%CPU (0avgtext+0avgdata 68288maxresident)k
24inputs+0outputs (0major+89273minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4508

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

------------------------------------------
[...truncated 290.28 KB...]
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-26 16:11:42.559555
@@ -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-26 16:11:43.131539
@@ -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-26 16:11:43.293339
@@ -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-26 16:11:43.307942
@@ -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-26 16:11:43.324458
@@ -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-26 16:11:43.425194
@@ -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-26 16:11:43.742448
@@ -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-26 16:11:43.775242
@@ -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-26 16:11:43.919391
@@ -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-26 16:11:43.969688
@@ -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
338.41user 6.93system 1:39.95elapsed 345%CPU (0avgtext+0avgdata 250632maxresident)k
0inputs+168outputs (0major+647342minor)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==3.1.1,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,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='1953718376'
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
27.65user 0.23system 0:10.51elapsed 265%CPU (0avgtext+0avgdata 68320maxresident)k
0inputs+0outputs (0major+89409minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4507

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

------------------------------------------
[...truncated 290.15 KB...]
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-26 15:56:42.614265
@@ -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-26 15:56:43.133979
@@ -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-26 15:56:43.273515
@@ -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-26 15:56:43.287467
@@ -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-26 15:56:43.303091
@@ -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-26 15:56:43.389428
@@ -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-26 15:56:43.659768
@@ -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-26 15:56:43.690227
@@ -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-26 15:56:43.804654
@@ -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-26 15:56:43.842921
@@ -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
339.91user 8.95system 1:39.81elapsed 349%CPU (0avgtext+0avgdata 254216maxresident)k
0inputs+168outputs (0major+653202minor)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==3.1.1,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,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='790254716'
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.83user 0.28system 0:10.88elapsed 267%CPU (0avgtext+0avgdata 68360maxresident)k
0inputs+0outputs (0major+88927minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4506

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

Changes:

[echauchot] [BEAM-3892] Make MetricQueryResults and related classes more

------------------------------------------
[...truncated 290.18 KB...]
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-26 15:10:57.964281
@@ -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-26 15:10:58.488785
@@ -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-26 15:10:58.632020
@@ -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-26 15:10:58.646353
@@ -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-26 15:10:58.662463
@@ -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-26 15:10:58.752009
@@ -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-26 15:10:59.022592
@@ -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-26 15:10:59.052739
@@ -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-26 15:10:59.172038
@@ -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-26 15:10:59.210584
@@ -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
336.06user 7.03system 1:39.33elapsed 345%CPU (0avgtext+0avgdata 261400maxresident)k
2896inputs+168outputs (0major+660413minor)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==3.1.1,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,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='3650347632'
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.36user 0.26system 0:10.52elapsed 271%CPU (0avgtext+0avgdata 68348maxresident)k
8inputs+0outputs (0major+89433minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4505

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

Changes:

[grzegorz.kolakowski] [BEAM-3800] Set uids on Flink operators

------------------------------------------
[...truncated 290.16 KB...]
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-26 11:51:53.116114
@@ -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-26 11:51:53.665143
@@ -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-26 11:51:53.812290
@@ -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-26 11:51:53.827252
@@ -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-26 11:51:53.843203
@@ -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-26 11:51:53.933716
@@ -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-26 11:51:54.210985
@@ -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-26 11:51:54.243640
@@ -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-26 11:51:54.360994
@@ -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-26 11:51:54.400197
@@ -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.10user 7.39system 1:42.17elapsed 343%CPU (0avgtext+0avgdata 253912maxresident)k
256inputs+168outputs (1major+648338minor)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==3.1.1,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,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='2055229411'
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
27.46user 0.21system 0:10.71elapsed 258%CPU (0avgtext+0avgdata 68332maxresident)k
0inputs+0outputs (0major+90036minor)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 grzegorz.kolakowski@getindata.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4504

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

------------------------------------------
[...truncated 290.12 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-26 09:26:42.944511
@@ -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-26 09:26:43.485502
@@ -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-26 09:26:43.631601
@@ -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-26 09:26:43.645825
@@ -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-26 09:26:43.662910
@@ -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-26 09:26:43.749138
@@ -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-26 09:26:44.023328
@@ -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-26 09:26:44.056618
@@ -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-26 09:26:44.181720
@@ -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-26 09:26:44.224106
@@ -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.62user 8.03system 1:43.51elapsed 341%CPU (0avgtext+0avgdata 251696maxresident)k
2640inputs+168outputs (0major+653712minor)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==3.1.1,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,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='1768164610'
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.80user 0.25system 0:10.79elapsed 269%CPU (0avgtext+0avgdata 68456maxresident)k
8inputs+0outputs (0major+89649minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4503

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

------------------------------------------
[...truncated 290.12 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-26 03:36:50.946238
@@ -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-26 03:36:51.478445
@@ -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-26 03:36:51.621914
@@ -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-26 03:36:51.636542
@@ -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-26 03:36:51.653305
@@ -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-26 03:36:51.748038
@@ -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-26 03:36:52.033177
@@ -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-26 03:36:52.064001
@@ -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-26 03:36:52.180769
@@ -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-26 03:36:52.219713
@@ -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
346.58user 8.74system 1:47.00elapsed 332%CPU (0avgtext+0avgdata 260000maxresident)k
2704inputs+168outputs (0major+642136minor)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==3.1.1,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,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='3633909680'
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.30user 0.31system 0:12.33elapsed 248%CPU (0avgtext+0avgdata 68440maxresident)k
8inputs+0outputs (0major+89546minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4502

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

------------------------------------------
[...truncated 290.20 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-25 21:09:56.782176
@@ -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-25 21:09:57.310637
@@ -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-25 21:09:57.455403
@@ -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-25 21:09:57.469902
@@ -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-25 21:09:57.486236
@@ -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-25 21:09:57.574372
@@ -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-25 21:09:57.858772
@@ -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-25 21:09:57.889364
@@ -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-25 21:09:58.008567
@@ -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-25 21:09:58.047628
@@ -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
346.58user 8.70system 1:43.42elapsed 343%CPU (0avgtext+0avgdata 245852maxresident)k
0inputs+168outputs (0major+633831minor)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==3.1.1,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,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='2832046607'
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
27.80user 0.23system 0:10.50elapsed 267%CPU (0avgtext+0avgdata 68464maxresident)k
0inputs+0outputs (0major+89887minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4501

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

------------------------------------------
[...truncated 290.12 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-25 15:09:35.421955
@@ -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-25 15:09:35.979421
@@ -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-25 15:09:36.141155
@@ -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-25 15:09:36.159067
@@ -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-25 15:09:36.178748
@@ -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-25 15:09:36.277759
@@ -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-25 15:09:36.555502
@@ -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-25 15:09:36.585194
@@ -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-25 15:09:36.712180
@@ -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-25 15:09:36.750813
@@ -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
341.01user 9.00system 1:48.04elapsed 323%CPU (0avgtext+0avgdata 246512maxresident)k
0inputs+168outputs (0major+647119minor)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==3.1.1,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,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='1604060843'
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
26.93user 0.26system 0:10.31elapsed 263%CPU (0avgtext+0avgdata 68428maxresident)k
0inputs+0outputs (0major+89102minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4500

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

------------------------------------------
[...truncated 290.12 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-25 09:09:42.527987
@@ -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-25 09:09:43.175720
@@ -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-25 09:09:43.350336
@@ -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-25 09:09:43.368930
@@ -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-25 09:09:43.390007
@@ -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-25 09:09:43.487659
@@ -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-25 09:09:43.799152
@@ -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-25 09:09:43.839103
@@ -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-25 09:09:43.989904
@@ -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-25 09:09:44.041522
@@ -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.92user 9.94system 1:43.30elapsed 344%CPU (0avgtext+0avgdata 248776maxresident)k
0inputs+168outputs (0major+651618minor)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==3.1.1,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,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='3075720948'
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
31.07user 0.27system 0:11.29elapsed 277%CPU (0avgtext+0avgdata 68252maxresident)k
0inputs+0outputs (0major+89677minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4499

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

------------------------------------------
[...truncated 290.12 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-25 03:09:41.337551
@@ -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-25 03:09:42.293274
@@ -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-25 03:09:42.471370
@@ -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-25 03:09:42.488965
@@ -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-25 03:09:42.509145
@@ -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-25 03:09:42.602040
@@ -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-25 03:09:42.950088
@@ -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-25 03:09:42.990531
@@ -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-25 03:09:43.136531
@@ -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-25 03:09:43.186379
@@ -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.02user 8.47system 1:49.76elapsed 322%CPU (0avgtext+0avgdata 262528maxresident)k
0inputs+168outputs (0major+656731minor)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==3.1.1,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,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='1950250777'
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.87user 0.30system 0:11.29elapsed 267%CPU (0avgtext+0avgdata 68200maxresident)k
0inputs+0outputs (0major+89878minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4498

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

------------------------------------------
[...truncated 290.12 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-24 21:09:26.605181
@@ -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-24 21:09:27.178116
@@ -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-24 21:09:27.342745
@@ -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-24 21:09:27.360761
@@ -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-24 21:09:27.382479
@@ -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-24 21:09:27.495797
@@ -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-24 21:09:27.771570
@@ -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-24 21:09:27.809950
@@ -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-24 21:09:27.938679
@@ -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-24 21:09:27.978559
@@ -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.36user 9.32system 1:48.62elapsed 324%CPU (0avgtext+0avgdata 239276maxresident)k
0inputs+168outputs (0major+645860minor)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==3.1.1,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,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='2190104406'
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.53user 0.28system 0:10.79elapsed 276%CPU (0avgtext+0avgdata 68224maxresident)k
0inputs+0outputs (0major+89363minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4497

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

------------------------------------------
[...truncated 290.12 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-24 15:09:25.817733
@@ -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-24 15:09:26.463524
@@ -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-24 15:09:26.626510
@@ -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-24 15:09:26.642178
@@ -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-24 15:09:26.659412
@@ -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-24 15:09:26.764035
@@ -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-24 15:09:27.106794
@@ -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-24 15:09:27.148143
@@ -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-24 15:09:27.296707
@@ -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-24 15:09:27.346845
@@ -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.19user 10.17system 1:53.08elapsed 324%CPU (0avgtext+0avgdata 248120maxresident)k
0inputs+168outputs (0major+645399minor)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==3.1.1,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,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='3372956463'
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.08user 0.27system 0:10.79elapsed 262%CPU (0avgtext+0avgdata 64180maxresident)k
0inputs+0outputs (0major+90434minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4496

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

------------------------------------------
[...truncated 290.11 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-24 09:09:22.836612
@@ -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-24 09:09:23.397605
@@ -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-24 09:09:23.541815
@@ -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-24 09:09:23.555981
@@ -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-24 09:09:23.571560
@@ -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-24 09:09:23.655759
@@ -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-24 09:09:23.934006
@@ -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-24 09:09:23.972170
@@ -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-24 09:09:24.100959
@@ -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-24 09:09:24.148681
@@ -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
341.43user 9.60system 1:45.34elapsed 333%CPU (0avgtext+0avgdata 242044maxresident)k
0inputs+168outputs (0major+642785minor)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==3.1.1,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,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='48259413'
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.40user 0.23system 0:10.39elapsed 275%CPU (0avgtext+0avgdata 68344maxresident)k
0inputs+0outputs (0major+89245minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4495

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

------------------------------------------
[...truncated 290.12 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-24 03:09:42.687154
@@ -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-24 03:09:43.217807
@@ -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-24 03:09:43.361293
@@ -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-24 03:09:43.376873
@@ -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-24 03:09:43.393095
@@ -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-24 03:09:43.480863
@@ -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-24 03:09:43.771236
@@ -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-24 03:09:43.802474
@@ -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-24 03:09:43.920319
@@ -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-24 03:09:43.959114
@@ -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.87user 9.74system 1:47.46elapsed 329%CPU (0avgtext+0avgdata 244592maxresident)k
2624inputs+168outputs (0major+634339minor)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==3.1.1,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,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='2762554573'
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.15user 0.26system 0:10.91elapsed 260%CPU (0avgtext+0avgdata 68324maxresident)k
8inputs+0outputs (0major+89436minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4494

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

Changes:

[wcn] Updating generated files.

------------------------------------------
[...truncated 264.89 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-23 23:59:26.858301
@@ -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-23 23:59:27.394002
@@ -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-23 23:59:27.535269
@@ -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-23 23:59:27.549958
@@ -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-23 23:59:27.565876
@@ -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-23 23:59:27.654488
@@ -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-23 23:59:27.932098
@@ -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-23 23:59:27.965952
@@ -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-23 23:59:28.090184
@@ -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-23 23:59:28.129558
@@ -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
339.20user 6.67system 1:39.82elapsed 346%CPU (0avgtext+0avgdata 245064maxresident)k
56inputs+168outputs (0major+636758minor)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==3.1.1,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,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='1144163912'
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.60user 0.27system 0:11.21elapsed 266%CPU (0avgtext+0avgdata 68416maxresident)k
8inputs+0outputs (0major+89481minor)pagefaults 0swaps
___________________________________ summary ____________________________________
ERROR:   cover: commands failed
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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_Verify #4493

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

------------------------------------------
[...truncated 290.24 KB...]
-from hamcrest.core.core.allof import all_of
-from nose.plugins.attrib import attr
-
 from apache_beam.examples import wordcount
 from apache_beam.examples import wordcount_fnapi
 from apache_beam.testing.pipeline_verifiers import FileChecksumMatcher
 from apache_beam.testing.pipeline_verifiers import PipelineStateMatcher
 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-23 21:45:33.046206
@@ -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-23 21:45:33.577484
@@ -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-23 21:45:33.719489
@@ -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-23 21:45:33.733857
@@ -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-23 21:45:33.749746
@@ -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-23 21:45:33.838003
@@ -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-23 21:45:34.124235
@@ -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-23 21:45:34.155367
@@ -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-23 21:45:34.273100
@@ -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-23 21:45:34.312456
@@ -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
341.44user 7.77system 1:41.39elapsed 344%CPU (0avgtext+0avgdata 265644maxresident)k
2840inputs+168outputs (0major+653663minor)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==3.1.1,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,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='1339397244'
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.80user 0.25system 0:11.21elapsed 259%CPU (0avgtext+0avgdata 68456maxresident)k
8inputs+0outputs (0major+89482minor)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 ccy@google.com
Not sending mail to unregistered user ehudm@google.com
Not sending mail to unregistered user boyuanz@google.com
Not sending mail to unregistered user markliu@google.com
Not sending mail to unregistered user XuMingmin@users.noreply.github.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user jb@nanthrax.net
Not sending mail to unregistered user mariand@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user andreas.ehrencrona@velik.it
Not sending mail to unregistered user ankurgoenka@gmail.com