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

Build failed in Jenkins: beam_PostCommit_Python_Verify #4546

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

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