You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2020/01/17 14:53:29 UTC

Build failed in Jenkins: beam_PostCommit_Py_ValCont #5317

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

Changes:

[iemejia] [BEAM-9143] Make RedisIO code follow standard Beam conventions

[iemejia] [BEAM-9143] Add withOutputParallelization to RedisIO.Read/ReadAll


------------------------------------------
[...truncated 634.09 KB...]
copying apache_beam/typehints/opcodes.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/interactive_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
Writing apache-beam-2.20.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.20.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
setup.py:242: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/setuptools/dist.py>:476: UserWarning: Normalizing '2.20.0.dev' to '2.20.0.dev0'
  normalized_version,
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:224: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
Skipping proto regeneration: all files up to date
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_Py_ValCont/ws/src/sdks/python/apache_beam/__init__.py>:84: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
No handlers could be found for logger "apache_beam.io.gcp.datastore.v1.datastoreio"
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
WARNING:apache_beam.runners.interactive.interactive_environment:Interactive Beam requires Python 3.5.3+.
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 2.7 interpreter.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/transforms/trigger_test.py>:513: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
  for spec in yaml.load_all(open(transcript_filename)):
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ERROR
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ERROR

======================================================================
ERROR: test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 54, in test_wordcount_fnapi_it
    self._run_wordcount_it(wordcount.run, experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 87, in _run_wordcount_it
    save_main_session=False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount.py",> line 119, in run
    result = p.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 461, in run
    self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 474, in run
    return self.runner.run_pipeline(self, self._options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 75, in run_pipeline
    self.result.cancel()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1466, in cancel
    self.job_id(), 'JOB_STATE_CANCELLED'):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/retry.py",> line 226, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 650, in modify_job_state
    self._client.projects_locations_jobs.Update(request)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/clients/dataflow/dataflow_v1b3_client.py",> line 758, in Update
    config, request, global_params=global_params)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/base_api.py",> line 729, in _RunMethod
    http, http_request, **opts)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 346, in MakeRequest
    check_response_func=check_response_func)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 396, in _MakeRequestNoRetry
    redirections=redirections, connection_type=connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 2133, in request
    cachekey,
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1796, in _request
    conn, request_uri, method, body, headers
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1737, in _conn_request
    response = conn.getresponse()
  File "/usr/lib/python2.7/httplib.py", line 1152, in getresponse
    response.begin()
  File "/usr/lib/python2.7/httplib.py", line 463, in begin
    version, status, reason = self._read_status()
  File "/usr/lib/python2.7/httplib.py", line 419, in _read_status
    line = self.fp.readline(_MAXLINE + 1)
  File "/usr/lib/python2.7/socket.py", line 480, in readline
    data = self._sock.recv(self._rbufsize)
  File "/usr/lib/python2.7/ssl.py", line 756, in recv
    return self.read(buflen)
  File "/usr/lib/python2.7/ssl.py", line 643, in read
    v = self._sslobj.read(len)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)'

======================================================================
ERROR: test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 58, in test_metrics_fnapi_it
    result = self.run_pipeline(experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 39, in run_pipeline
    test_pipeline = TestPipeline(is_integration_test=True)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 107, in __init__
    super(TestPipeline, self).__init__(runner, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 184, in __init__
    errors = PipelineOptionsValidator(self._options, runner).validate()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options_validator.py",> line 113, in validate
    errors.extend(self.options.view_as(cls).validate(self))
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 591, in validate
    self.view_as(GoogleCloudOptions).region = self._get_default_gcp_region()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 559, in _get_default_gcp_region
    raw_output = processes.check_output(cmd, stderr=DEVNULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/processes.py",> line 85, in check_output
    out = subprocess.check_output(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 568, in check_output
    output, unused_err = process.communicate()
  File "/usr/lib/python2.7/subprocess.py", line 792, in communicate
    stdout = _eintr_retry_call(self.stdout.read)
  File "/usr/lib/python2.7/subprocess.py", line 476, in _eintr_retry_call
    return func(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)'

----------------------------------------------------------------------
XML: nosetests-python2.7_sdk.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 904.009s

FAILED (errors=2)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-143058
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:1c3bfe22d4b02b772b12e827756c245577ca4fdae5d475ca36d65f097419ce40
Deleted: sha256:0e42bc47383cd10eb10493df017176b467b8e86dc59d053a49a77f2e104d7f5a
Deleted: sha256:b22fb4b73bb93bb20a7dd5511e74bfaecda2ec07fea0b1f8a5fb7589b87b620a
Deleted: sha256:317cedc177c456dc5f14279d66e876ada0461f3b2fbae6de42b0e7aac799cdaa
Deleted: sha256:1a19e548eddde1d32b79db15dc3edd403a6057c4c10b6d604c65887b40b46be9
Deleted: sha256:075687d89d564a55e948293b6157bbe8bd04c7864dd3236098d3e190c9140fc6
Deleted: sha256:cc4513516bdbd5037ddfb6debadfbb90b5b58cf70feac479e10d3e7bcb41ccf7
Deleted: sha256:c8adf34eec832dfbd3edd3462217a5c169e373b6001361348cba3f29cdb98e4a
Deleted: sha256:631b6c06e1debc776a96d0e176b9be3b1d7cf98ec9d272589ab61bf4beb0d8c4
Deleted: sha256:75468500f54c2e9af232e75d62de5e574eff6c7f7766a2904810cf1685a85b2e
Deleted: sha256:ef2c1c51f4b70c05473895b17c3ab9c067c18f3dc5d0b2ca021497afb5b1c944
Deleted: sha256:1a83679848192d3eab0bf27d0768abcab000c93140d564be93900947c9d01073
Deleted: sha256:33a984239dddb748c3e8426d221411ba9f664977d9a7e714adbafc49cfdce890
Deleted: sha256:948cf90cf7f0d3fc6209d5eb6b3787172ad9ee98c5d65b1b2d660a7fea8c5ba2
Deleted: sha256:18c659b7be80865be3d6aaffb0e1aa0e3de150c524ed95b43c62ce09c8cd3084
Deleted: sha256:29c67cbbdb51e667bafe44428490882885395958973fc90b0db0cecca7414b3c
Deleted: sha256:eee7a7a83e56c2da752dffa27c89edbed125b34b526a07cce0a3006b46597657
Deleted: sha256:4246b8694721376f133ef709003c01776be781b32d2045e1bc18db65362f94d9
Deleted: sha256:2d679ae4864aa0f00af063a7262ed767b8ab2bcc9ba8fb12ca04e4a295d722eb
Deleted: sha256:77870855190816b6e62c99d2a98129e5e4e228be07630792fc4873608145f908
Deleted: sha256:ec482e1e8b38847fd45049d5dcec486203d7d3d14edcc0224b4d39fa3b86af05
Digests:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:1c3bfe22d4b02b772b12e827756c245577ca4fdae5d475ca36d65f097419ce40
  Associated tags:
 - 20200117-143058
Tags:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-143058
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-143058].
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:1c3bfe22d4b02b772b12e827756c245577ca4fdae5d475ca36d65f097419ce40].
Removed the container
Build step 'Execute shell' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Jenkins build is back to normal : beam_PostCommit_Py_ValCont #5326

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


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_ValCont #5325

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

Changes:

[github] Merge pull request #10622: [BEAM=6857] Fix timermap test to not use


------------------------------------------
[...truncated 660.71 KB...]
copying apache_beam/typehints/opcodes.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/interactive_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
Writing apache-beam-2.20.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.20.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
setup.py:244: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/setuptools/dist.py>:476: UserWarning: Normalizing '2.20.0.dev' to '2.20.0.dev0'
  normalized_version,
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:224: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
Skipping proto regeneration: all files up to date
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_Py_ValCont/ws/src/sdks/python/apache_beam/__init__.py>:84: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
No handlers could be found for logger "apache_beam.io.gcp.datastore.v1.datastoreio"
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
WARNING:apache_beam.runners.interactive.interactive_environment:Interactive Beam requires Python 3.5.3+.
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 2.7 interpreter.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/transforms/trigger_test.py>:513: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
  for spec in yaml.load_all(open(transcript_filename)):
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ERROR
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ERROR

======================================================================
ERROR: test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 54, in test_wordcount_fnapi_it
    self._run_wordcount_it(wordcount.run, experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 87, in _run_wordcount_it
    save_main_session=False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount.py",> line 119, in run
    result = p.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 461, in run
    self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 474, in run
    return self.runner.run_pipeline(self, self._options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 75, in run_pipeline
    self.result.cancel()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1466, in cancel
    self.job_id(), 'JOB_STATE_CANCELLED'):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/retry.py",> line 226, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 650, in modify_job_state
    self._client.projects_locations_jobs.Update(request)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/clients/dataflow/dataflow_v1b3_client.py",> line 758, in Update
    config, request, global_params=global_params)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/base_api.py",> line 729, in _RunMethod
    http, http_request, **opts)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 346, in MakeRequest
    check_response_func=check_response_func)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 396, in _MakeRequestNoRetry
    redirections=redirections, connection_type=connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 2133, in request
    cachekey,
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1796, in _request
    conn, request_uri, method, body, headers
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1737, in _conn_request
    response = conn.getresponse()
  File "/usr/lib/python2.7/httplib.py", line 1152, in getresponse
    response.begin()
  File "/usr/lib/python2.7/httplib.py", line 463, in begin
    version, status, reason = self._read_status()
  File "/usr/lib/python2.7/httplib.py", line 419, in _read_status
    line = self.fp.readline(_MAXLINE + 1)
  File "/usr/lib/python2.7/socket.py", line 480, in readline
    data = self._sock.recv(self._rbufsize)
  File "/usr/lib/python2.7/ssl.py", line 756, in recv
    return self.read(buflen)
  File "/usr/lib/python2.7/ssl.py", line 643, in read
    v = self._sslobj.read(len)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)'

======================================================================
ERROR: test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 58, in test_metrics_fnapi_it
    result = self.run_pipeline(experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 39, in run_pipeline
    test_pipeline = TestPipeline(is_integration_test=True)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 107, in __init__
    super(TestPipeline, self).__init__(runner, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 184, in __init__
    errors = PipelineOptionsValidator(self._options, runner).validate()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options_validator.py",> line 113, in validate
    errors.extend(self.options.view_as(cls).validate(self))
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 591, in validate
    self.view_as(GoogleCloudOptions).region = self._get_default_gcp_region()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 559, in _get_default_gcp_region
    raw_output = processes.check_output(cmd, stderr=DEVNULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/processes.py",> line 85, in check_output
    out = subprocess.check_output(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 568, in check_output
    output, unused_err = process.communicate()
  File "/usr/lib/python2.7/subprocess.py", line 792, in communicate
    stdout = _eintr_retry_call(self.stdout.read)
  File "/usr/lib/python2.7/subprocess.py", line 476, in _eintr_retry_call
    return func(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)'

----------------------------------------------------------------------
XML: nosetests-python2.7_sdk.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 904.031s

FAILED (errors=2)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200118-021652
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:f24b88653b8a7efddb3cda979b679192057a885ba832214dbc383a00c210f99f
Deleted: sha256:742054836bf66d53abc88bd12ec9be9b9b5624e88e3f1611aabbed45e7c1b540
Deleted: sha256:6e3b1953484b18859227f396300437bb75af537fe8b82f44625b952ed621e27e
Deleted: sha256:e7bf53e1e3c6a39ccc2b437d2899b5f4d02d3aeed40c544060c7994696593119
Deleted: sha256:547add051be12758e8d6783bb213b9b04e80b3bc7409f35fb23499762a92f8a5
Deleted: sha256:fba5484251b541c1d03b9dbf7edec251ec40d35936fde52d97cf901dc3139f1f
Deleted: sha256:2d7fad39e5af16b45f0b712a069cc710822aa2560efb5b1163b926465ff3555a
Deleted: sha256:ae1c3b024bfa5c6ec8b93a58599d733d4ddab20f72c9e80be384892c7a27447b
Deleted: sha256:fd740e9824c8458895296d6e3b78d7e470209608591bf6f83eef7cef8e8b7077
Deleted: sha256:7c8d0604b47013279902c1690847868eda14ea37884087eca62ce7bc634492d1
Deleted: sha256:2f5daa24f3e003d40af1eeb33142cdcb8d3d35a9800ec45b87fd86916bf83730
Deleted: sha256:ab226c96a708b6624af0fbd5c504404ce420448455dc6f8381485cea54d703b3
Deleted: sha256:ae98875b2c798d5126d75371acfca95b0e700c25216356d99395d6186c7cf257
Deleted: sha256:16052cbf8b23338ffb4de556ae28098c27881e3e01f6456293c0fe37f781d54e
Deleted: sha256:46af6dcb8dce77c20a09953131146de84ee26cb667b91fcc392a76bf67581c22
Deleted: sha256:c30a1911053cf2d738fdff3042a5f58443ac6f78d45a1fd8bb369e3906a4bcbf
Deleted: sha256:877734f0e80f4af5d3bdb506aa9d32df5c6f3d7e500bdcf164efe542ce24b0da
Deleted: sha256:bb9459fdc959e98a316849f526278d8465dfcdbdff7f64773e7f7509278d3ee6
Deleted: sha256:457b031f58d1ea1f1054e54a70c908335bd5263ca214187894e9c333affb6bfa
Deleted: sha256:389008496222670cc7670c0032e6e55db88cd0fd5ffe6516f7700db9c15ef9ed
Deleted: sha256:4297b04457a602286fba75b9853d9ffa6091008e9950b7f6a08766167e3809d9
Digests:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:f24b88653b8a7efddb3cda979b679192057a885ba832214dbc383a00c210f99f
  Associated tags:
 - 20200118-021652
Tags:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200118-021652
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200118-021652].
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:f24b88653b8a7efddb3cda979b679192057a885ba832214dbc383a00c210f99f].
Removed the container
Build step 'Execute shell' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_ValCont #5324

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

Changes:


------------------------------------------
[...truncated 657.33 KB...]
copying apache_beam/transforms/display.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/dofn_lifecycle_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/environments.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/environments_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test_it.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test_py37.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/py_dataflow_distribution_counter.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/stats.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/stats_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/timeutil.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/transforms_keyword_only_args_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/userstate.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/userstate_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/write_ptransform_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/typehints/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/opcodes.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/interactive_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
Writing apache-beam-2.20.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.20.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
setup.py:244: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/setuptools/dist.py>:476: UserWarning: Normalizing '2.20.0.dev' to '2.20.0.dev0'
  normalized_version,
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:224: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
Skipping proto regeneration: all files up to date
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_Py_ValCont/ws/src/sdks/python/apache_beam/__init__.py>:84: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
No handlers could be found for logger "apache_beam.io.gcp.datastore.v1.datastoreio"
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
WARNING:apache_beam.runners.interactive.interactive_environment:Interactive Beam requires Python 3.5.3+.
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 2.7 interpreter.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/transforms/trigger_test.py>:513: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
  for spec in yaml.load_all(open(transcript_filename)):
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ERROR
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ERROR

======================================================================
ERROR: test suite for <class 'apache_beam.examples.wordcount_it_test.WordCountIT'>
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/suite.py",> line 177, in __call__
    return self.run(*arg, **kw)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 822, in run
    test.config.plugins.addError(test,err)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/manager.py",> line 99, in __call__
    return self.call(*arg, **kw)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/manager.py",> line 167, in simple
    result = meth(*arg, **kw)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/xunit.py",> line 287, in addError
    tb = format_exception(err, self.encoding)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/pyversion.py",> line 214, in format_exception
    ''.join(traceback.format_exception(*exc_info)),
  File "/usr/lib/python2.7/traceback.py", line 141, in format_exception
    list = list + format_tb(tb, limit)
  File "/usr/lib/python2.7/traceback.py", line 76, in format_tb
    return format_list(extract_tb(tb, limit))
  File "/usr/lib/python2.7/traceback.py", line 101, in extract_tb
    line = linecache.getline(filename, lineno, f.f_globals)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/lib/python2.7/linecache.py",> line 14, in getline
    lines = getlines(filename, module_globals)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/lib/python2.7/linecache.py",> line 41, in getlines
    return updatecache(filename, module_globals)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/lib/python2.7/linecache.py",> line 132, in updatecache
    lines = fp.readlines()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: '<nose.plugins.multiprocess.NoSharedFixtureContextSuite context=WordCountIT>'

======================================================================
ERROR: test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 58, in test_metrics_fnapi_it
    result = self.run_pipeline(experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 39, in run_pipeline
    test_pipeline = TestPipeline(is_integration_test=True)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 107, in __init__
    super(TestPipeline, self).__init__(runner, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 184, in __init__
    errors = PipelineOptionsValidator(self._options, runner).validate()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options_validator.py",> line 113, in validate
    errors.extend(self.options.view_as(cls).validate(self))
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 591, in validate
    self.view_as(GoogleCloudOptions).region = self._get_default_gcp_region()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 559, in _get_default_gcp_region
    raw_output = processes.check_output(cmd, stderr=DEVNULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/processes.py",> line 85, in check_output
    out = subprocess.check_output(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 568, in check_output
    output, unused_err = process.communicate()
  File "/usr/lib/python2.7/subprocess.py", line 792, in communicate
    stdout = _eintr_retry_call(self.stdout.read)
  File "/usr/lib/python2.7/subprocess.py", line 476, in _eintr_retry_call
    return func(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)'

----------------------------------------------------------------------
XML: nosetests-python2.7_sdk.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 904.161s

FAILED (errors=2)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200118-004642
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:643b49222a9f5391488483aef833b0f16650bf1017ea4c0116ec28cfbf481455
Deleted: sha256:3159bfccc82544777d2cf9274b2f6a45cb5b6cfc0bbaa5871b228af1576022dd
Deleted: sha256:d2bbbfb43c645ff93a2b2e92753831a45b815fadfafd88f833833e3a131db73d
Deleted: sha256:91d6f386c05cc829c58baa33e4301e1910dff088e1d46187a511b8075717fa0d
Deleted: sha256:fc5cd11a33758c3dbaa6634080f86f92b01e8d73a466522566701d43741b1080
Deleted: sha256:14d9e324203bfd2c0494a3d6f1a8a2e581ff9fef3d13efcf37d9ed80fd8fe09a
Deleted: sha256:043461abb9618d6ae5cb6c0046438c7a7ef25f36cf5a53e977e2842f72aee2ee
Deleted: sha256:e2ab2083e96beaaba80a4af076083dbee588b8aa733ffa01011f95aff563b0a2
Deleted: sha256:92c07dbc90875b22952a75a8252456282d08b922fb33e564ee5e08b59a7a9e28
Deleted: sha256:13a3375b7bd7e583ab74e99b3bdd3e85621321c39877a3a78963ad106cf249a9
Deleted: sha256:c223d6aa145f6d4ca3810a520ca7c64aab4612aab763ed2477f940df02d7d30f
Deleted: sha256:bafd23c2fb78077df510f4b1da6423ad8e3ba6fda9835a70e4acff2fc2d739b1
Deleted: sha256:7c4b02ae57c4fca61abe65fb5c73b5af41d233d7873189ea5d2d09eb2b681cb8
Deleted: sha256:141705fe2bba1cb63c7c9831ffdaf890ce98274579c5d7274f60b8d59f1975cc
Deleted: sha256:abb84a1c4c7187e45dd812feb144b4fbd5ed66f0688075d438bb6bb12fc10515
Deleted: sha256:f4e3f7d73e8b4004bb50c4dffcfd285ef8e1ad03a8ff58abea1e11ee8123e9e7
Deleted: sha256:cae541bdf67d2abee1ef86a26c60afe7f84584301bfed3e4f2da92e3fdeccd7a
Deleted: sha256:9490ed086f624cb3800e8580c383dd850f76fb1c2693c244b2616adafdad52ac
Deleted: sha256:a43929dd0f6ad525439945b59b40a45c8310d0f5b609d538a5ab6e4fec2c11cf
Deleted: sha256:23ca706340fb84934cf8e7b4ba33f532e9b5edeafda0749d6a11f42a24254cf8
Deleted: sha256:290fed0f81df0a599b5a25f5bfb248aed8d3a3d64e81fde64111841000c59b2e
Digests:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:643b49222a9f5391488483aef833b0f16650bf1017ea4c0116ec28cfbf481455
  Associated tags:
 - 20200118-004642
Tags:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200118-004642
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200118-004642].
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:643b49222a9f5391488483aef833b0f16650bf1017ea4c0116ec28cfbf481455].
Removed the container
Build step 'Execute shell' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_ValCont #5323

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

Changes:

[chadrik] [BEAM-7746] Fix a typing issue where SourceBase was assumed to have a


------------------------------------------
[...truncated 652.73 KB...]
copying apache_beam/testing/benchmarks/nexmark/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/testing/benchmarks/nexmark
copying apache_beam/testing/benchmarks/nexmark/nexmark_launcher.py -> apache-beam-2.20.0.dev0/apache_beam/testing/benchmarks/nexmark
copying apache_beam/testing/benchmarks/nexmark/nexmark_util.py -> apache-beam-2.20.0.dev0/apache_beam/testing/benchmarks/nexmark
copying apache_beam/testing/benchmarks/nexmark/models/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/testing/benchmarks/nexmark/models
copying apache_beam/testing/benchmarks/nexmark/models/nexmark_model.py -> apache-beam-2.20.0.dev0/apache_beam/testing/benchmarks/nexmark/models
copying apache_beam/testing/benchmarks/nexmark/queries/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/testing/benchmarks/nexmark/queries
copying apache_beam/testing/benchmarks/nexmark/queries/query0.py -> apache-beam-2.20.0.dev0/apache_beam/testing/benchmarks/nexmark/queries
copying apache_beam/testing/benchmarks/nexmark/queries/query1.py -> apache-beam-2.20.0.dev0/apache_beam/testing/benchmarks/nexmark/queries
copying apache_beam/testing/benchmarks/nexmark/queries/query2.py -> apache-beam-2.20.0.dev0/apache_beam/testing/benchmarks/nexmark/queries
copying apache_beam/testing/data/trigger_transcripts.yaml -> apache-beam-2.20.0.dev0/apache_beam/testing/data
copying apache_beam/testing/load_tests/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests
copying apache_beam/testing/load_tests/co_group_by_key_test.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests
copying apache_beam/testing/load_tests/combine_test.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests
copying apache_beam/testing/load_tests/group_by_key_test.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests
copying apache_beam/testing/load_tests/load_test.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests
copying apache_beam/testing/load_tests/load_test_metrics_utils.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests
copying apache_beam/testing/load_tests/pardo_test.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests
copying apache_beam/testing/load_tests/sideinput_test.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests
copying apache_beam/testing/load_tests/streaming/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests/streaming
copying apache_beam/testing/load_tests/streaming/group_by_key_streaming_pipeline.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests/streaming
copying apache_beam/testing/load_tests/streaming/group_by_key_streaming_test.py -> apache-beam-2.20.0.dev0/apache_beam/testing/load_tests/streaming
copying apache_beam/tools/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/tools
copying apache_beam/tools/coders_microbenchmark.py -> apache-beam-2.20.0.dev0/apache_beam/tools
copying apache_beam/tools/distribution_counter_microbenchmark.py -> apache-beam-2.20.0.dev0/apache_beam/tools
copying apache_beam/tools/fn_api_runner_microbenchmark.py -> apache-beam-2.20.0.dev0/apache_beam/tools
copying apache_beam/tools/map_fn_microbenchmark.py -> apache-beam-2.20.0.dev0/apache_beam/tools
copying apache_beam/tools/microbenchmarks_test.py -> apache-beam-2.20.0.dev0/apache_beam/tools
copying apache_beam/tools/sideinput_microbenchmark.py -> apache-beam-2.20.0.dev0/apache_beam/tools
copying apache_beam/tools/utils.py -> apache-beam-2.20.0.dev0/apache_beam/tools
copying apache_beam/transforms/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/combiners.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/combiners_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/core.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/core_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/create_source.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/create_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners.pxd -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_combiners.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_dataflow_distribution_counter.pxd -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/cy_dataflow_distribution_counter.pyx -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/dataflow_distribution_counter_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/dofn_lifecycle_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/environments.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/environments_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test_it.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test_py37.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/py_dataflow_distribution_counter.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/stats.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/stats_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/timeutil.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/transforms_keyword_only_args_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/userstate.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/userstate_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/write_ptransform_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/typehints/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/opcodes.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/interactive_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
Writing apache-beam-2.20.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.20.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
setup.py:244: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/setuptools/dist.py>:476: UserWarning: Normalizing '2.20.0.dev' to '2.20.0.dev0'
  normalized_version,
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:224: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
Skipping proto regeneration: all files up to date
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_Py_ValCont/ws/src/sdks/python/apache_beam/__init__.py>:84: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
No handlers could be found for logger "apache_beam.io.gcp.datastore.v1.datastoreio"
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
WARNING:apache_beam.runners.interactive.interactive_environment:Interactive Beam requires Python 3.5.3+.
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 2.7 interpreter.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/transforms/trigger_test.py>:513: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
  for spec in yaml.load_all(open(transcript_filename)):
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ERROR

======================================================================
ERROR: test suite for <class 'apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest'>
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/suite.py",> line 177, in __call__
    return self.run(*arg, **kw)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 822, in run
    test.config.plugins.addError(test,err)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/manager.py",> line 99, in __call__
    return self.call(*arg, **kw)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/manager.py",> line 167, in simple
    result = meth(*arg, **kw)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/xunit.py",> line 287, in addError
    tb = format_exception(err, self.encoding)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/pyversion.py",> line 214, in format_exception
    ''.join(traceback.format_exception(*exc_info)),
  File "/usr/lib/python2.7/traceback.py", line 141, in format_exception
    list = list + format_tb(tb, limit)
  File "/usr/lib/python2.7/traceback.py", line 76, in format_tb
    return format_list(extract_tb(tb, limit))
  File "/usr/lib/python2.7/traceback.py", line 101, in extract_tb
    line = linecache.getline(filename, lineno, f.f_globals)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/lib/python2.7/linecache.py",> line 14, in getline
    lines = getlines(filename, module_globals)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/lib/python2.7/linecache.py",> line 41, in getlines
    return updatecache(filename, module_globals)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/lib/python2.7/linecache.py",> line 132, in updatecache
    lines = fp.readlines()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: '<nose.plugins.multiprocess.NoSharedFixtureContextSuite context=ExerciseMetricsPipelineTest>'

----------------------------------------------------------------------
XML: nosetests-python2.7_sdk.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 1816.248s

FAILED (errors=1)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-235500
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:43706f81fbbcedf0fce214a0a6bd65e9f635fbba9595664369ec743c8ed3e73e
Deleted: sha256:ef3c4faf90873cfa1461de675bb45a7595aea577f019180492c4a9b8035b99b3
Deleted: sha256:7a1d25c7f23bb5215b4628831122c96f3610a932a67f1cb7f292f50f8872826b
Deleted: sha256:0095070826384e5d73d337129f54fce355bbe799228b279f71a23b757650bdcb
Deleted: sha256:4b405e71d90a05c96ae1c1ed17595395c42eca584e29f02731b5975d45d51534
Deleted: sha256:37d30cbad811d9a1763057eb33d3d20ff3681b2bc61e234856cf710f62a0ffda
Deleted: sha256:08d8ec26366b7e91f361afd0a801bf24f160bccbfd5623f994667c480b94fca1
Deleted: sha256:cfc3bb7dbdf5858436f20dd31cce7961e3c66e9149dd6a50f5706f376b1c0d36
Deleted: sha256:4ee3d94b88ba23991728b57bb360ed6e33d8573aeaa6114c3ebd8a8485b6a1e6
Deleted: sha256:b8a3ea8c9238845f2b2b4cb8c463c52f5f5f362d2a73e3812cd3d8a5dd80a94c
Deleted: sha256:50588b7ddbd9d62f722eaa7f81eb484ceba9fff6a4feb888e5a07a7b111e13de
Deleted: sha256:4e9218f75fd516bdf5fb7eb8647c4984a4f44cf96269507d59af1c24879f6d88
Deleted: sha256:d441cb156663a7064a97f71f5acd44da09f5ab05f4a625f37e6ede17bdfd7b65
Deleted: sha256:677c4fe85e74381347956f3e931a38549e98939d4d4cd418f181ab186c60df57
Deleted: sha256:7c8da98ea80614ac07184641afae9331175f2b2d9a78f56f63a9e29b06d5ac14
Deleted: sha256:b62c99cb644e30a285b7a3977e966ad07bddecf5a724239db9e9b8a798d77fb4
Deleted: sha256:c60810ff3de264dad6b5a95e2f4c79838d5caad725ece8cccef5f64c8f5e14bd
Deleted: sha256:8640f2924fa3c085abd786c818b956a4685ea0acbc9a6b03240f99e188abed9b
Deleted: sha256:97d0b82fb268ce50df2d3f70bddb6efe0634eb1aa628e4ad335ab1c176cdd213
Deleted: sha256:ac9670bc0e1678086eabe0e2550fddc8704f9cc0e1d46a9b9c89790efe5b83f4
Deleted: sha256:2e364fe2f3bcad6f26b2a81333795bff3572aff3121843c107ed73b2ba7b5fca
Digests:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:43706f81fbbcedf0fce214a0a6bd65e9f635fbba9595664369ec743c8ed3e73e
  Associated tags:
 - 20200117-235500
Tags:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-235500
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-235500].
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:43706f81fbbcedf0fce214a0a6bd65e9f635fbba9595664369ec743c8ed3e73e].
Removed the container
Build step 'Execute shell' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_ValCont #5322

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

Changes:

[suztomo] Beam's own TimestampConversion

[suztomo] Link in Javadoc


------------------------------------------
[...truncated 659.89 KB...]
copying apache_beam/typehints/native_type_compatibility.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/opcodes.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/interactive_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
Writing apache-beam-2.20.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.20.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
setup.py:244: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/setuptools/dist.py>:476: UserWarning: Normalizing '2.20.0.dev' to '2.20.0.dev0'
  normalized_version,
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:224: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
Skipping proto regeneration: all files up to date
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_Py_ValCont/ws/src/sdks/python/apache_beam/__init__.py>:84: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
No handlers could be found for logger "apache_beam.io.gcp.datastore.v1.datastoreio"
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
WARNING:apache_beam.runners.interactive.interactive_environment:Interactive Beam requires Python 3.5.3+.
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 2.7 interpreter.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/transforms/trigger_test.py>:513: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
  for spec in yaml.load_all(open(transcript_filename)):
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ERROR
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ERROR

======================================================================
ERROR: test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 54, in test_wordcount_fnapi_it
    self._run_wordcount_it(wordcount.run, experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 87, in _run_wordcount_it
    save_main_session=False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount.py",> line 119, in run
    result = p.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 461, in run
    self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 474, in run
    return self.runner.run_pipeline(self, self._options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 75, in run_pipeline
    self.result.cancel()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1466, in cancel
    self.job_id(), 'JOB_STATE_CANCELLED'):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/retry.py",> line 226, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 650, in modify_job_state
    self._client.projects_locations_jobs.Update(request)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/clients/dataflow/dataflow_v1b3_client.py",> line 758, in Update
    config, request, global_params=global_params)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/base_api.py",> line 729, in _RunMethod
    http, http_request, **opts)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 346, in MakeRequest
    check_response_func=check_response_func)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 396, in _MakeRequestNoRetry
    redirections=redirections, connection_type=connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 2133, in request
    cachekey,
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1796, in _request
    conn, request_uri, method, body, headers
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1737, in _conn_request
    response = conn.getresponse()
  File "/usr/lib/python2.7/httplib.py", line 1152, in getresponse
    response.begin()
  File "/usr/lib/python2.7/httplib.py", line 463, in begin
    version, status, reason = self._read_status()
  File "/usr/lib/python2.7/httplib.py", line 419, in _read_status
    line = self.fp.readline(_MAXLINE + 1)
  File "/usr/lib/python2.7/socket.py", line 480, in readline
    data = self._sock.recv(self._rbufsize)
  File "/usr/lib/python2.7/ssl.py", line 756, in recv
    return self.read(buflen)
  File "/usr/lib/python2.7/ssl.py", line 643, in read
    v = self._sslobj.read(len)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)'

======================================================================
ERROR: test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 58, in test_metrics_fnapi_it
    result = self.run_pipeline(experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 39, in run_pipeline
    test_pipeline = TestPipeline(is_integration_test=True)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 107, in __init__
    super(TestPipeline, self).__init__(runner, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 184, in __init__
    errors = PipelineOptionsValidator(self._options, runner).validate()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options_validator.py",> line 113, in validate
    errors.extend(self.options.view_as(cls).validate(self))
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 583, in validate
    if self.view_as(DebugOptions).dataflow_job_file:
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 328, in view_as
    view = cls(self._flags)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 209, in __init__
    self._visible_options, _ = parser.parse_known_args(flags)
  File "/usr/lib/python2.7/argparse.py", line 1733, in parse_known_args
    namespace, args = self._parse_known_args(args, namespace)
  File "/usr/lib/python2.7/argparse.py", line 1763, in _parse_known_args
    for i, arg_string in enumerate(arg_strings_iter):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)'

----------------------------------------------------------------------
XML: nosetests-python2.7_sdk.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 910.770s

FAILED (errors=2)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-224225
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:5e49f35a376e9b757c277e4c14eac201e5607392044cb30596fba4a61a481105
Deleted: sha256:f9bc05febcd07836b4002f9ddd4fe4d0b51be3e4cf4773b26bf99af240943003
Deleted: sha256:3ac60814fe61134e8eee03bc69bbdd742aa1de2b9421e33ec3dd429c913bd755
Deleted: sha256:c80dfb9405f602848f7e7a2da532e831e168c885398a6dbdb293d2d610d88494
Deleted: sha256:660845e8395d661af6c357a91413467e69b021a32a8a7825ad25102e956ce2ab
Deleted: sha256:097507dba4e9494053be9a37b6452a6b2101b8cefe6fe031a83fddda1b983cef
Deleted: sha256:7bd8a30c37768eb1d272fc6c7070c2dc97a906bc0fb0e2508bddbd632e4300d7
Deleted: sha256:94a04377a70ce734f11445de2533d13de8d17594fdc41e73d4aa587fbfa9c5d2
Deleted: sha256:4fe97e50e01471e3899da852f98e5e56a1a06f95be358549ecdabc3c3ca3a419
Deleted: sha256:063b6cfdcec209afbbdecaf820c3425c897dc01f3151795998fc8858b20bf828
Deleted: sha256:580caba89b4ed91566405c377755e96d0c597d56b96c37aec25577611f367c97
Deleted: sha256:8651b85f8677ef535258049186f6dfe7a02c57ef719f1b3a9a85df44c620c25f
Deleted: sha256:d198ffa13393a198c69eae43bbeeeeb9f7f5f8300adfa03007e7e6d9ff3b2ae2
Deleted: sha256:4de2fe396c97a1f3dc63874290989a7e3393fc9b3d39b532207bfa8e4573f044
Deleted: sha256:7c89e3c13a9e10357ef8f126390049f953f01bf40920384f273f38441c6537ac
Deleted: sha256:3bcd820648471c365c49bb5db944618c75d7189155120151c318df3db49e4a1e
Deleted: sha256:10a2a01ef6afcf94f6892baf494271a7aad5f9883095f5df73f6e23650207b63
Deleted: sha256:49589a20eabff345ce4795293bbe9fc290890342e730be5ff656786c57997170
Deleted: sha256:1d3badba539bffa2be140f4deb971a30892229219527294cbbaf07dca7aad2e0
Deleted: sha256:4e7989bf10ffbc69a6d2e3f15199bde699895654276f5a4dfccbb7023e6d29d7
Deleted: sha256:cd5eb6f91f3b61e4fd25c937165535b16f7e4707b8ae046e701b17569347e3d1
Digests:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:5e49f35a376e9b757c277e4c14eac201e5607392044cb30596fba4a61a481105
  Associated tags:
 - 20200117-224225
Tags:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-224225
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-224225].
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:5e49f35a376e9b757c277e4c14eac201e5607392044cb30596fba4a61a481105].
Removed the container
Build step 'Execute shell' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_ValCont #5321

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

Changes:

[rohde.samuel] Make apply_TestStream not a test b/c Nose thinks it is a test


------------------------------------------
[...truncated 660.62 KB...]
copying apache_beam/typehints/opcodes.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/interactive_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
Writing apache-beam-2.20.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.20.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
setup.py:244: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/setuptools/dist.py>:476: UserWarning: Normalizing '2.20.0.dev' to '2.20.0.dev0'
  normalized_version,
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:224: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
Skipping proto regeneration: all files up to date
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_Py_ValCont/ws/src/sdks/python/apache_beam/__init__.py>:84: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
No handlers could be found for logger "apache_beam.io.gcp.datastore.v1.datastoreio"
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
WARNING:apache_beam.runners.interactive.interactive_environment:Interactive Beam requires Python 3.5.3+.
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 2.7 interpreter.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/transforms/trigger_test.py>:513: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
  for spec in yaml.load_all(open(transcript_filename)):
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ERROR
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ERROR

======================================================================
ERROR: test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 54, in test_wordcount_fnapi_it
    self._run_wordcount_it(wordcount.run, experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 87, in _run_wordcount_it
    save_main_session=False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount.py",> line 119, in run
    result = p.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 461, in run
    self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 474, in run
    return self.runner.run_pipeline(self, self._options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 75, in run_pipeline
    self.result.cancel()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1466, in cancel
    self.job_id(), 'JOB_STATE_CANCELLED'):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/retry.py",> line 226, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 650, in modify_job_state
    self._client.projects_locations_jobs.Update(request)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/clients/dataflow/dataflow_v1b3_client.py",> line 758, in Update
    config, request, global_params=global_params)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/base_api.py",> line 729, in _RunMethod
    http, http_request, **opts)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 346, in MakeRequest
    check_response_func=check_response_func)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 396, in _MakeRequestNoRetry
    redirections=redirections, connection_type=connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 2133, in request
    cachekey,
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1796, in _request
    conn, request_uri, method, body, headers
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1737, in _conn_request
    response = conn.getresponse()
  File "/usr/lib/python2.7/httplib.py", line 1152, in getresponse
    response.begin()
  File "/usr/lib/python2.7/httplib.py", line 463, in begin
    version, status, reason = self._read_status()
  File "/usr/lib/python2.7/httplib.py", line 419, in _read_status
    line = self.fp.readline(_MAXLINE + 1)
  File "/usr/lib/python2.7/socket.py", line 480, in readline
    data = self._sock.recv(self._rbufsize)
  File "/usr/lib/python2.7/ssl.py", line 756, in recv
    return self.read(buflen)
  File "/usr/lib/python2.7/ssl.py", line 643, in read
    v = self._sslobj.read(len)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)'

======================================================================
ERROR: test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 58, in test_metrics_fnapi_it
    result = self.run_pipeline(experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 39, in run_pipeline
    test_pipeline = TestPipeline(is_integration_test=True)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 107, in __init__
    super(TestPipeline, self).__init__(runner, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 184, in __init__
    errors = PipelineOptionsValidator(self._options, runner).validate()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options_validator.py",> line 113, in validate
    errors.extend(self.options.view_as(cls).validate(self))
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 591, in validate
    self.view_as(GoogleCloudOptions).region = self._get_default_gcp_region()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 559, in _get_default_gcp_region
    raw_output = processes.check_output(cmd, stderr=DEVNULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/processes.py",> line 85, in check_output
    out = subprocess.check_output(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 568, in check_output
    output, unused_err = process.communicate()
  File "/usr/lib/python2.7/subprocess.py", line 792, in communicate
    stdout = _eintr_retry_call(self.stdout.read)
  File "/usr/lib/python2.7/subprocess.py", line 476, in _eintr_retry_call
    return func(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)'

----------------------------------------------------------------------
XML: nosetests-python2.7_sdk.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 903.703s

FAILED (errors=2)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-221010
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:fa34afffe13b59fb40198e23ec600abc6a537bc54e15d698e51bdb760f2156ad
Deleted: sha256:1d877905a836552184a36a02ce322f3f7e110df6f05e302e8bb182adb35e20c5
Deleted: sha256:2d1074900b5b6f2578f5323eda6385a1c36eed111c4675dc72dc8c9b7f259f6f
Deleted: sha256:f54564a797e2237519674349f966e8ad3310acb502af4179b3f78c02d66db4e7
Deleted: sha256:513a61d74bf9d2f0a1d0423729cfe7717e9867cc15d7063137feacc8bcebb581
Deleted: sha256:54b17e52e52afc4862bef71afd1d8963bbfeaf9854e030575ad1453998ca57f2
Deleted: sha256:351c9d21f9007747457c36e4083015feef79b9ae4b37d370a2dc4299b0594072
Deleted: sha256:bc1ff771ec9acbe85622a874dce703fc44c61827b4cc355d7694c57d54c0f571
Deleted: sha256:80b63411b7801146d0505eed144d5428b92b12076c33a6ac9af3e77f093e04d1
Deleted: sha256:28b6b4d1bb6ab64b413372b93565c8dc633405bcee9693584629330ab78fd874
Deleted: sha256:6cb3ee0c79ec93c0d056aa31a17846a904a94719d79d5cbe4cd1dbd47a0019a2
Deleted: sha256:cb8a530f7da896c6f7c619abff921293815fd88d96c26d2e89be0f167cb63eaa
Deleted: sha256:f86c1024da48cf2702af04b27503c24f32082c71aa307106222955a2074ede2f
Deleted: sha256:c596f0f40a2c9dfdd7a670bc035aa5ab74534d0b16cd54949bda28b893ff695a
Deleted: sha256:c0c2bdff63d32d7c6490f93e21c57dd240546846329c925be0eb11782263a58a
Deleted: sha256:6f0894358bd927ef59d230827cd93c7d0075a8f04fe51ec571e9536f7580f72a
Deleted: sha256:16d9e82267448bfdc1cbdfc225e6d82a9580e35da5a98d5c8dda0ba0255985f3
Deleted: sha256:15a3eb4b91fc2ae5ab975f03f89a383f1a55873b2de1042ce34979bc3e2c496f
Deleted: sha256:51bd23ef712379c1d2e549b4117724f717546e31afb5508ee8d3485f53310e11
Deleted: sha256:df3c3219107218d8fd375ac9118cba66defc193d73c18c1c76cf9f1295b46c40
Deleted: sha256:ed5238929c69dfb510a122a8c2224402e546698c22fe6aa32e81bba1d9734c77
Digests:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:fa34afffe13b59fb40198e23ec600abc6a537bc54e15d698e51bdb760f2156ad
  Associated tags:
 - 20200117-221010
Tags:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-221010
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-221010].
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:fa34afffe13b59fb40198e23ec600abc6a537bc54e15d698e51bdb760f2156ad].
Removed the container
Build step 'Execute shell' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_ValCont #5320

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

Changes:

[chamikara] [BEAM-7246] Add Google Spanner IO Read on Python SDK (#9606)


------------------------------------------
[...truncated 661.06 KB...]
copying apache_beam/typehints/typecheck.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/interactive_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
Writing apache-beam-2.20.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.20.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
setup.py:244: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/setuptools/dist.py>:476: UserWarning: Normalizing '2.20.0.dev' to '2.20.0.dev0'
  normalized_version,
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:224: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
Skipping proto regeneration: all files up to date
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_Py_ValCont/ws/src/sdks/python/apache_beam/__init__.py>:84: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
No handlers could be found for logger "apache_beam.io.gcp.datastore.v1.datastoreio"
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
WARNING:apache_beam.runners.interactive.interactive_environment:Interactive Beam requires Python 3.5.3+.
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 2.7 interpreter.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/transforms/trigger_test.py>:513: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
  for spec in yaml.load_all(open(transcript_filename)):
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ERROR
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ERROR

======================================================================
ERROR: test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 54, in test_wordcount_fnapi_it
    self._run_wordcount_it(wordcount.run, experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 87, in _run_wordcount_it
    save_main_session=False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount.py",> line 119, in run
    result = p.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 461, in run
    self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 474, in run
    return self.runner.run_pipeline(self, self._options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 75, in run_pipeline
    self.result.cancel()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1473, in cancel
    return self.state
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1413, in state
    self._update_job()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1369, in _update_job
    self._job = self._runner.dataflow_client.get_job(self.job_id())
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/retry.py",> line 226, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 680, in get_job
    response = self._client.projects_locations_jobs.Get(request)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/clients/dataflow/dataflow_v1b3_client.py",> line 661, in Get
    config, request, global_params=global_params)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/base_api.py",> line 729, in _RunMethod
    http, http_request, **opts)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 346, in MakeRequest
    check_response_func=check_response_func)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 396, in _MakeRequestNoRetry
    redirections=redirections, connection_type=connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 2133, in request
    cachekey,
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1796, in _request
    conn, request_uri, method, body, headers
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1737, in _conn_request
    response = conn.getresponse()
  File "/usr/lib/python2.7/httplib.py", line 1152, in getresponse
    response.begin()
  File "/usr/lib/python2.7/httplib.py", line 463, in begin
    version, status, reason = self._read_status()
  File "/usr/lib/python2.7/httplib.py", line 419, in _read_status
    line = self.fp.readline(_MAXLINE + 1)
  File "/usr/lib/python2.7/socket.py", line 480, in readline
    data = self._sock.recv(self._rbufsize)
  File "/usr/lib/python2.7/ssl.py", line 756, in recv
    return self.read(buflen)
  File "/usr/lib/python2.7/ssl.py", line 643, in read
    v = self._sslobj.read(len)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)'

======================================================================
ERROR: test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 58, in test_metrics_fnapi_it
    result = self.run_pipeline(experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 39, in run_pipeline
    test_pipeline = TestPipeline(is_integration_test=True)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 107, in __init__
    super(TestPipeline, self).__init__(runner, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 184, in __init__
    errors = PipelineOptionsValidator(self._options, runner).validate()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options_validator.py",> line 113, in validate
    errors.extend(self.options.view_as(cls).validate(self))
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 591, in validate
    self.view_as(GoogleCloudOptions).region = self._get_default_gcp_region()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 559, in _get_default_gcp_region
    raw_output = processes.check_output(cmd, stderr=DEVNULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/processes.py",> line 85, in check_output
    out = subprocess.check_output(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 567, in check_output
    process = Popen(stdout=PIPE, *popenargs, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 711, in __init__
    errread, errwrite)
  File "/usr/lib/python2.7/subprocess.py", line 1319, in _execute_child
    data = _eintr_retry_call(os.read, errpipe_read, 1048576)
  File "/usr/lib/python2.7/subprocess.py", line 476, in _eintr_retry_call
    return func(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)'

----------------------------------------------------------------------
XML: nosetests-python2.7_sdk.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 904.439s

FAILED (errors=2)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-205654
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:735540b82c2fd60bd396b1964f3ead752d3b3eee5012069546bdfcb8171a881d
Deleted: sha256:18684175038b3ee0530aaeb1beeadde903e901cc6a0ec3ef41d1a01e37166970
Deleted: sha256:6b64fe3737e665107bbb7eddaa89a3bdc13ecdf409321994342576bc83dedfd2
Deleted: sha256:0408722041380b9e439ec5adff24c85a11a8bc453770ec67c189ee7b227f09c3
Deleted: sha256:1f81cc55e15ee2faf8b7d59e36e52fb6f941f9b3921ccbb0cf9747d71638d835
Deleted: sha256:9bec5f9d421f6c4d83c8acbfa94ff5e7628794fd0040b80ee99fa8bd625d5442
Deleted: sha256:83bd6ad63c0fb77feb15801e290749eee9ae1803c690a04ee00c84a083078951
Deleted: sha256:5d4f1f68f080a35be2db0704288ce133d3f61362e46c09418c08d77e319ba7f5
Deleted: sha256:7b507dd1599eb64a9d7d820dbc4e259973fd9e190cb967a298de727b1f11c1c4
Deleted: sha256:428890c4dbf7fe60b2ba89a6239519d837dadb15b196e5728f4835c7519366f5
Deleted: sha256:f8b95848e99352d6e2ff41abbdc0af3c02179e35338f82968a38f117c8407113
Deleted: sha256:e7ce735c2134f6f0fbe84c2b9421c2dfde48f89e1cc947bdbcb7fba160bc00c9
Deleted: sha256:a70b93eb7c644cff95fd5bac51d6e73faab695ec06b6a5c15cba8d28fad81aaa
Deleted: sha256:8a9b4a34fbce9460beec7fbd7a9f20c9d376e955817e94938e587302f8d359e0
Deleted: sha256:da61c58e7402995ad43136263e4dbdf8829a4de658cefd4d8eeb887e479431f0
Deleted: sha256:6165502213107fe61bb9d3fb05491fceef0b3b765539a646c399107e50e6db9a
Deleted: sha256:fc3bfb6d5408744b71bf140975cf1a6a9eae6c2f07dd92208ecaca55a4cc487f
Deleted: sha256:d9117fa38c7b60fc3c7ebbd1e7d98822c0942ad4e0b8687a03a74233850262fe
Deleted: sha256:ac8d226868ef74be2b2efd97df452696fe8a94b445f5940d8edd3f39554d9372
Deleted: sha256:448c3dfcc7bb7719bf2259b7446c4ec35ec71df23cae59ede14eaabe4aa42337
Deleted: sha256:b3c64fc033f37f54dfc1f5213783f209bdde79b1b75bb7d75c714df8fe59103c
Digests:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:735540b82c2fd60bd396b1964f3ead752d3b3eee5012069546bdfcb8171a881d
  Associated tags:
 - 20200117-205654
Tags:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-205654
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-205654].
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:735540b82c2fd60bd396b1964f3ead752d3b3eee5012069546bdfcb8171a881d].
Removed the container
Build step 'Execute shell' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_ValCont #5319

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

Changes:

[ehudm] Migrate HDFS IT to use tox env.

[ehudm] Fix for py2


------------------------------------------
[...truncated 630.54 KB...]
copying apache_beam/transforms/display.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/display_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/dofn_lifecycle_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/environments.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/environments_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test_it.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/external_test_py37.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/ptransform_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/py_dataflow_distribution_counter.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/sideinputs_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/stats.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/stats_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/timeutil.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/transforms_keyword_only_args_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/trigger_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/userstate.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/userstate_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/util_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/window_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/transforms/write_ptransform_test.py -> apache-beam-2.20.0.dev0/apache_beam/transforms
copying apache_beam/typehints/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/decorators_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/native_type_compatibility_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/opcodes.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/schemas_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/interactive_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
Writing apache-beam-2.20.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.20.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
setup.py:242: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/setuptools/dist.py>:476: UserWarning: Normalizing '2.20.0.dev' to '2.20.0.dev0'
  normalized_version,
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:224: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
Skipping proto regeneration: all files up to date
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_Py_ValCont/ws/src/sdks/python/apache_beam/__init__.py>:84: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
No handlers could be found for logger "apache_beam.io.gcp.datastore.v1.datastoreio"
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
WARNING:apache_beam.runners.interactive.interactive_environment:Interactive Beam requires Python 3.5.3+.
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 2.7 interpreter.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/transforms/trigger_test.py>:513: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
  for spec in yaml.load_all(open(transcript_filename)):
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ERROR
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ERROR

======================================================================
ERROR: test suite for <class 'apache_beam.examples.wordcount_it_test.WordCountIT'>
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/suite.py",> line 177, in __call__
    return self.run(*arg, **kw)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 822, in run
    test.config.plugins.addError(test,err)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/manager.py",> line 99, in __call__
    return self.call(*arg, **kw)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/manager.py",> line 167, in simple
    result = meth(*arg, **kw)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/xunit.py",> line 287, in addError
    tb = format_exception(err, self.encoding)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/pyversion.py",> line 214, in format_exception
    ''.join(traceback.format_exception(*exc_info)),
  File "/usr/lib/python2.7/traceback.py", line 141, in format_exception
    list = list + format_tb(tb, limit)
  File "/usr/lib/python2.7/traceback.py", line 76, in format_tb
    return format_list(extract_tb(tb, limit))
  File "/usr/lib/python2.7/traceback.py", line 101, in extract_tb
    line = linecache.getline(filename, lineno, f.f_globals)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/lib/python2.7/linecache.py",> line 14, in getline
    lines = getlines(filename, module_globals)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/lib/python2.7/linecache.py",> line 41, in getlines
    return updatecache(filename, module_globals)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/lib/python2.7/linecache.py",> line 132, in updatecache
    lines = fp.readlines()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: '<nose.plugins.multiprocess.NoSharedFixtureContextSuite context=WordCountIT>'

======================================================================
ERROR: test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 58, in test_metrics_fnapi_it
    result = self.run_pipeline(experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 39, in run_pipeline
    test_pipeline = TestPipeline(is_integration_test=True)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 107, in __init__
    super(TestPipeline, self).__init__(runner, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 184, in __init__
    errors = PipelineOptionsValidator(self._options, runner).validate()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options_validator.py",> line 113, in validate
    errors.extend(self.options.view_as(cls).validate(self))
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 591, in validate
    self.view_as(GoogleCloudOptions).region = self._get_default_gcp_region()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 559, in _get_default_gcp_region
    raw_output = processes.check_output(cmd, stderr=DEVNULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/processes.py",> line 85, in check_output
    out = subprocess.check_output(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 568, in check_output
    output, unused_err = process.communicate()
  File "/usr/lib/python2.7/subprocess.py", line 792, in communicate
    stdout = _eintr_retry_call(self.stdout.read)
  File "/usr/lib/python2.7/subprocess.py", line 476, in _eintr_retry_call
    return func(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)'

----------------------------------------------------------------------
XML: nosetests-python2.7_sdk.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 904.063s

FAILED (errors=2)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-191505
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:c248403310a5e04c06f59d71da1f44e851fb2955e290ed729ffd33c4f325a79c
Deleted: sha256:f29b0f21c28fcf4ce08d5c8f7fbc59968b51c14f1da8d578750f71332e6b3480
Deleted: sha256:14fd483f0abc1e482c61938e888625e86268331352f78a0bff1ae774534747cb
Deleted: sha256:4a694d14eb78d53cc105be41681e532f512a62eeeaf8acfa94d80449b1d06272
Deleted: sha256:efac80b37530a106756aea36b77bbcd753954e152555f655da7b1fdb4ba1aec0
Deleted: sha256:09e817e1fb791744c1c6387c5ba1b9c9d3bca4994cf9d55b8c810e164faddc59
Deleted: sha256:ee4b7ae37c33974ce755004694e2efce371afa1fbd49905152be90963c6b3841
Deleted: sha256:ffe0f347b2fc5f1a8f14497897543eb1c3fc16a12fc4abfc4b21c325eb576b52
Deleted: sha256:9544fa8f8df3c0abc17d0540549f377cdb842bacf6b85763995b031724721820
Deleted: sha256:fa088d623f74e020bffacac4b728d598a08ed650a1290639cf79a2cb4b584f4e
Deleted: sha256:bda84e57a5eaf6f05981e493b9ca4204bb8ce6a3d2a4d7f2bd8651aedfd54354
Deleted: sha256:4b3b20864b243c89c325ddbfe649e6d48daea88aab435a6026c4d9cf66c1f804
Deleted: sha256:33278811da21e6cb53e8582b3147ffa61d2859dcb40b0d5fa4116a1dd8dcdc42
Deleted: sha256:92d9c2b3aa5174f3264cd56be52a37d930bda81bc5284d4e206ffd7380ec0d85
Deleted: sha256:58876af067e453073d6dcd5a03192a68c51ab5b96f6b7d72704f882307686151
Deleted: sha256:9ab9eb65df70487e8ec96a55048381111b091dcaafa854f7260a222054a0272a
Deleted: sha256:3482f7e63a2d3d8dce7d3f03bdcf71dd7a9b5b57815e55d88a72495613e9afa4
Deleted: sha256:49a83dd03f4dcd4bda8536d66e25b6cb978f2d2b59213c08f4e99bcdd46483be
Deleted: sha256:526779e4dc062eb4ecf45108590fccddde7118a05dcc7437c3d1b741e40743a4
Deleted: sha256:a65a4b06e74addcb800d23233f652b78ca669b262213f180adc7f73184f1d664
Deleted: sha256:36529ecdb3fb340c8152f7c013b6134670b48ad2f16e17241cf1975310f4a9e5
Digests:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:c248403310a5e04c06f59d71da1f44e851fb2955e290ed729ffd33c4f325a79c
  Associated tags:
 - 20200117-191505
Tags:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-191505
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-191505].
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:c248403310a5e04c06f59d71da1f44e851fb2955e290ed729ffd33c4f325a79c].
Removed the container
Build step 'Execute shell' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Build failed in Jenkins: beam_PostCommit_Py_ValCont #5318

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

Changes:

[lukecwik] [BEAM-8695] Upgrade google-http-client to 1.34.0 (#10614)


------------------------------------------
[...truncated 634.30 KB...]
copying apache_beam/typehints/trivial_inference_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/trivial_inference_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typecheck.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typed_pipeline_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/typehints/typehints_test_py3.py -> apache-beam-2.20.0.dev0/apache_beam/typehints
copying apache_beam/utils/__init__.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/annotations_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/counters_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/interactive_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/plugin.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/processes_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/profiler.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.20.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.20.0.dev0/apache_beam/utils
Writing apache-beam-2.20.0.dev0/setup.cfg
creating dist
Creating tar archive
removing 'apache-beam-2.20.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
setup.py:242: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/setuptools/dist.py>:476: UserWarning: Normalizing '2.20.0.dev' to '2.20.0.dev0'
  normalized_version,
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:224: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
Skipping proto regeneration: all files up to date
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_Py_ValCont/ws/src/sdks/python/apache_beam/__init__.py>:84: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
  'You are using Apache Beam with Python 2. '
No handlers could be found for logger "apache_beam.io.gcp.datastore.v1.datastoreio"
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
WARNING:apache_beam.runners.interactive.interactive_environment:Interactive Beam requires Python 3.5.3+.
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 2.7 interpreter.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/transforms/trigger_test.py>:513: YAMLLoadWarning: calling yaml.load_all() without Loader=... is deprecated, as the default Loader is unsafe. Please read https://msg.pyyaml.org/load for full details.
  for spec in yaml.load_all(open(transcript_filename)):
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
WARNING:apache_beam.options.pipeline_options:--region not set; will default to us-central1. Future releases of Beam will require the user to set --region explicitly, or else have a default set via the gcloud tool. https://cloud.google.com/compute/docs/regions-zones
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ERROR
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... ERROR

======================================================================
ERROR: test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 54, in test_wordcount_fnapi_it
    self._run_wordcount_it(wordcount.run, experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount_it_test.py",> line 87, in _run_wordcount_it
    save_main_session=False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/examples/wordcount.py",> line 119, in run
    result = p.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 461, in run
    self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 474, in run
    return self.runner.run_pipeline(self, self._options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 75, in run_pipeline
    self.result.cancel()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1473, in cancel
    return self.state
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1413, in state
    self._update_job()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 1369, in _update_job
    self._job = self._runner.dataflow_client.get_job(self.job_id())
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/retry.py",> line 226, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 680, in get_job
    response = self._client.projects_locations_jobs.Get(request)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/internal/clients/dataflow/dataflow_v1b3_client.py",> line 661, in Get
    config, request, global_params=global_params)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/base_api.py",> line 729, in _RunMethod
    http, http_request, **opts)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 346, in MakeRequest
    check_response_func=check_response_func)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/apitools/base/py/http_wrapper.py",> line 396, in _MakeRequestNoRetry
    redirections=redirections, connection_type=connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/oauth2client/transport.py",> line 169, in new_request
    redirections, connection_type)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 2133, in request
    cachekey,
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1796, in _request
    conn, request_uri, method, body, headers
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/httplib2/__init__.py",> line 1737, in _conn_request
    response = conn.getresponse()
  File "/usr/lib/python2.7/httplib.py", line 1152, in getresponse
    response.begin()
  File "/usr/lib/python2.7/httplib.py", line 463, in begin
    version, status, reason = self._read_status()
  File "/usr/lib/python2.7/httplib.py", line 419, in _read_status
    line = self.fp.readline(_MAXLINE + 1)
  File "/usr/lib/python2.7/socket.py", line 480, in readline
    data = self._sock.recv(self._rbufsize)
  File "/usr/lib/python2.7/ssl.py", line 756, in recv
    return self.read(buflen)
  File "/usr/lib/python2.7/ssl.py", line 643, in read
    v = self._sslobj.read(len)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT)'

======================================================================
ERROR: test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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_Py_ValCont/ws/src/sdks/python/container/venv/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 393, in __call__
    return self.run(*args, **kwds)
  File "/usr/lib/python2.7/unittest/case.py", line 329, in run
    testMethod()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 58, in test_metrics_fnapi_it
    result = self.run_pipeline(experiment='beam_fn_api')
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 39, in run_pipeline
    test_pipeline = TestPipeline(is_integration_test=True)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 107, in __init__
    super(TestPipeline, self).__init__(runner, options)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/pipeline.py",> line 184, in __init__
    errors = PipelineOptionsValidator(self._options, runner).validate()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options_validator.py",> line 113, in validate
    errors.extend(self.options.view_as(cls).validate(self))
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 591, in validate
    self.view_as(GoogleCloudOptions).region = self._get_default_gcp_region()
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/options/pipeline_options.py",> line 559, in _get_default_gcp_region
    raw_output = processes.check_output(cmd, stderr=DEVNULL)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/utils/processes.py",> line 85, in check_output
    out = subprocess.check_output(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 568, in check_output
    output, unused_err = process.communicate()
  File "/usr/lib/python2.7/subprocess.py", line 792, in communicate
    stdout = _eintr_retry_call(self.stdout.read)
  File "/usr/lib/python2.7/subprocess.py", line 476, in _eintr_retry_call
    return func(*args)
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python/local/lib/python2.7/site-packages/nose/plugins/multiprocess.py",> line 276, in signalhandler
    raise TimedOutException()
TimedOutException: 'test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)'

----------------------------------------------------------------------
XML: nosetests-python2.7_sdk.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 904.038s

FAILED (errors=2)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-181436
Untagged: us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:8a385c312b973892fe0d6c5685c3c031a26893af2711b014458a84f279c36544
Deleted: sha256:9ab4f49e3b0e78345254778fb4ff8065da12a6915e60f6aeffbf557350f2c41e
Deleted: sha256:45122103d63361aeecb7a63bd0f872c003a5a109f1b973568ac4d8c6278ae390
Deleted: sha256:6418ebf4996af401e5a2162e18b207b5d177c043d263d54c5a991745cb808217
Deleted: sha256:0248352063c2ec240a8cd1d76b2dbdb09a1243930a14a36fe5611468ecd6f893
Deleted: sha256:01e015201fb8330505b62fb15de3dd3158a94f2a07e9ddb97d97b13a977c0d17
Deleted: sha256:c17d9b8b69bc6eeff6be73ed316b71ce5b2c82fc24b51876c7c450ddb8fc0d10
Deleted: sha256:f1351db6095d1605b60a45c6f8f798e48c4d27f88871dfe9e0b873e8c22f1cbf
Deleted: sha256:87e3729914eb4477e08ec16218e265bd7a49f48f3d7b5b280f2f2d6a20ebb588
Deleted: sha256:981ab76b01b52d5578437693bb64496b6502e1033a928b3c1ad423daaf0dd2d9
Deleted: sha256:84a7ccb637d308e40c3e462adb7597ea87c6753b2c175b9e58fb9d4cb73471f2
Deleted: sha256:8b093884b5adeba8547c5461d8fb05330411974ef65e99c51553184c02f55401
Deleted: sha256:dfc22e7bf7c21dd7cb94091ff7f028123f478feb67c89ac817d5640af39a8eaa
Deleted: sha256:e272719d9ba596a207a72837ce64c998ad64b3ead4ff35ea385dc6342f7472a8
Deleted: sha256:042a43d10171194e978ef8f5c0da93fc6fe56fa3fc7307d2e69c4228a4d0f547
Deleted: sha256:cda7d660baedb701b2deb7ee4bd859287e038760632cee0acd07b0c7d68b626c
Deleted: sha256:c8010dc3fb309d465f5d57205d7ccf79092e002a4f3e8e57fd0959b52c814768
Deleted: sha256:75234f0d2b1771f6c1f32900dbeb34d44367acc3fdf6412c01ee955867aa701f
Deleted: sha256:22a0c994db6494eb21598b3782c0cc4a71e936f704b246b2aa406fc05d749d1a
Deleted: sha256:06298acfd47a1ce395493418926c9368e8b9cff90e88b955b61e198b65a180b1
Deleted: sha256:1904057bb986bde9e6a2c98766fc02abef70311752833eafe285b9bb9eb70597
Digests:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:8a385c312b973892fe0d6c5685c3c031a26893af2711b014458a84f279c36544
  Associated tags:
 - 20200117-181436
Tags:
- us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-181436
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk:20200117-181436].
Deleted [us.gcr.io/apache-beam-testing/jenkins/python2.7_sdk@sha256:8a385c312b973892fe0d6c5685c3c031a26893af2711b014458a84f279c36544].
Removed the container
Build step 'Execute shell' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org