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

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1489

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

Changes:

[Pablo] Creation of utils.py whit CountingSource class on it.

[Pablo] Changed import from examples.snippets to io.utils

------------------------------------------
Started by GitHub push by pabloem
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 9d75d06643f0d443ede4d172cca2c5d8b3c5ef65 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 9d75d06643f0d443ede4d172cca2c5d8b3c5ef65
Commit message: "Changed import from examples.snippets to io.utils"
 > git rev-list --no-walk 8faad955eebd3e160659bb2c31156729502c7c8f # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8748153274389667668.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Jenkins build is back to normal : beam_PostCommit_Python_ValidatesRunner_Dataflow #1580

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


Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1579

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

------------------------------------------
[...truncated 80.60 KB...]
Collecting mock (from -r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/mock-2.0.0.tar.gz
Collecting setuptools (from pyhamcrest->-r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/setuptools-39.1.0.zip
Collecting six (from pyhamcrest->-r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/six-1.11.0.tar.gz
Collecting funcsigs>=1 (from mock->-r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/funcsigs-1.0.2.tar.gz
Collecting pbr>=0.11 (from mock->-r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/pbr-4.0.2.tar.gz
Successfully downloaded pyhamcrest mock setuptools six funcsigs pbr
test_as_singleton_with_different_defaults (apache_beam.transforms.sideinputs_test.SideInputsTest) ... ok
Collecting pyhamcrest (from -r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/PyHamcrest-1.9.0.tar.gz
Collecting mock (from -r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/mock-2.0.0.tar.gz
Collecting setuptools (from pyhamcrest->-r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/setuptools-39.1.0.zip
Collecting six (from pyhamcrest->-r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/six-1.11.0.tar.gz
Collecting funcsigs>=1 (from mock->-r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/funcsigs-1.0.2.tar.gz
Collecting pbr>=0.11 (from mock->-r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/pbr-4.0.2.tar.gz
Successfully downloaded pyhamcrest mock setuptools six funcsigs pbr
test_as_singleton_without_unique_labels (apache_beam.transforms.sideinputs_test.SideInputsTest) ... ok
Collecting pyhamcrest (from -r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/PyHamcrest-1.9.0.tar.gz
Collecting mock (from -r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/mock-2.0.0.tar.gz
Collecting setuptools (from pyhamcrest->-r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/setuptools-39.1.0.zip
Collecting six (from pyhamcrest->-r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/six-1.11.0.tar.gz
Collecting funcsigs>=1 (from mock->-r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/funcsigs-1.0.2.tar.gz
Collecting pbr>=0.11 (from mock->-r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/pbr-4.0.2.tar.gz
Successfully downloaded pyhamcrest mock setuptools six funcsigs pbr
test_default_value_singleton_side_input (apache_beam.transforms.sideinputs_test.SideInputsTest) ... ok
Collecting pyhamcrest (from -r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/PyHamcrest-1.9.0.tar.gz
Collecting mock (from -r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/mock-2.0.0.tar.gz
Collecting setuptools (from pyhamcrest->-r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/setuptools-39.1.0.zip
Collecting six (from pyhamcrest->-r postcommit_requirements.txt (line 1))
  File was already downloaded /tmp/dataflow-requirements-cache/six-1.11.0.tar.gz
Collecting funcsigs>=1 (from mock->-r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/funcsigs-1.0.2.tar.gz
Collecting pbr>=0.11 (from mock->-r postcommit_requirements.txt (line 2))
  File was already downloaded /tmp/dataflow-requirements-cache/pbr-4.0.2.tar.gz
Successfully downloaded pyhamcrest mock setuptools six funcsigs pbr
test_flattened_side_input (apache_beam.transforms.sideinputs_test.SideInputsTest) ... ok
test_empty_singleton_side_input (apache_beam.transforms.sideinputs_test.SideInputsTest) ... ok
test_iterable_side_input (apache_beam.transforms.sideinputs_test.SideInputsTest) ... ok
test_multi_valued_singleton_side_input (apache_beam.transforms.sideinputs_test.SideInputsTest) ... ok

======================================================================
ERROR: test_flatten_multiple_pcollections_having_multiple_consumers (apache_beam.transforms.ptransform_test.PTransformTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py",> line 558, in test_flatten_multiple_pcollections_having_multiple_consumers
    pipeline.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 102, in run
    result = super(TestPipeline, self).run(test_runner_api)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 389, in run
    self.to_runner_api(), self.runner, self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 402, in run
    return self.runner.run_pipeline(self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 48, in run_pipeline
    self.result = super(TestDataflowRunner, self).run_pipeline(pipeline)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 363, in run_pipeline
    self.dataflow_client.create_job(self.job), self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/retry.py",> line 180, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 470, in create_job
    self.create_job_description(job)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 500, in create_job_description
    job.options, file_copy=self._gcs_file_copy)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 329, in stage_job_resources
    setup_options.requirements_file, requirements_cache_path)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 263, in _populate_requirements_cache
    processes.check_call(cmd_args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/processes.py",> line 44, in check_call
    return subprocess.check_call(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 541, in check_call
    raise CalledProcessError(retcode, cmd)
CalledProcessError: Command '['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']' returned non-zero exit status 2
-------------------- >> begin captured logging << --------------------
root: DEBUG: PValue computed by Start/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag even_length): refcount: 2 => 1
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag odd_length): refcount: 2 => 1
root: DEBUG: PValue computed by Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag even_length): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag odd_length): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Unkey (tag None): refcount: 1 => 0
root: DEBUG: Connecting using Google Application Default Credentials.
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509223026-345524.1525905026.345728/pipeline.pb...
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509223026-345524.1525905026.345728/pipeline.pb
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509223026-345524.1525905026.345728/requirements.txt...
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509223026-345524.1525905026.345728/requirements.txt
root: INFO: Executing command: ['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_multiple_empty_outputs (apache_beam.transforms.ptransform_test.PTransformTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py",> line 271, in test_multiple_empty_outputs
    pipeline.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 102, in run
    result = super(TestPipeline, self).run(test_runner_api)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 389, in run
    self.to_runner_api(), self.runner, self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 402, in run
    return self.runner.run_pipeline(self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 48, in run_pipeline
    self.result = super(TestDataflowRunner, self).run_pipeline(pipeline)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 363, in run_pipeline
    self.dataflow_client.create_job(self.job), self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/retry.py",> line 180, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 470, in create_job
    self.create_job_description(job)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 500, in create_job_description
    job.options, file_copy=self._gcs_file_copy)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 329, in stage_job_resources
    setup_options.requirements_file, requirements_cache_path)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 263, in _populate_requirements_cache
    processes.check_call(cmd_args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/processes.py",> line 44, in check_call
    return subprocess.check_call(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 541, in check_call
    raise CalledProcessError(retcode, cmd)
CalledProcessError: Command '['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']' returned non-zero exit status 2
-------------------- >> begin captured logging << --------------------
root: DEBUG: PValue computed by Some Numbers/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(<lambda at ptransform_test.py:265>) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(<lambda at ptransform_test.py:265>) (tag odd): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(<lambda at ptransform_test.py:265>) (tag even): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Unkey (tag None): refcount: 1 => 0
root: DEBUG: Connecting using Google Application Default Credentials.
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509223026-351431.1525905026.351616/pipeline.pb...
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509223026-351431.1525905026.351616/pipeline.pb
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509223026-351431.1525905026.351616/requirements.txt...
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509223026-351431.1525905026.351616/requirements.txt
root: INFO: Executing command: ['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']
--------------------- >> end captured logging << ---------------------

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 16 tests in 1671.694s

FAILED (errors=2)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_30_34-15053285416510490174?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_37_51-435612596807968102?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_44_48-8584141932090587935?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_51_40-16942186272340966402?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_30_32-720265797592504064?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_37_54-11373314483770573963?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_44_41-10356588637746762?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_51_33-17895820244858090268?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_30_33-9035027160105350523?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_37_30-780458391648212929?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_45_02-4668222810510647622?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_30_32-13000502888616669917?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_38_19-7023835511014930752?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_45_26-18324242706211742251?project=apache-beam-testing.
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1578

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

------------------------------------------
GitHub pull request #5302 of commit 93fcc6c6d3ad0ee3b425c1e4c11956f5075f1bb9, no merge conflicts.
Setting status of 93fcc6c6d3ad0ee3b425c1e4c11956f5075f1bb9 to PENDING with url https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/1578/ and message: 'Build started sha1 is merged.'
Using context: Jenkins: Google Cloud Dataflow Runner Python ValidatesRunner Tests
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/5302/*:refs/remotes/origin/pr/5302/*
 > git rev-parse refs/remotes/origin/pr/5302/merge^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/pr/5302/merge^{commit} # timeout=10
Checking out Revision 9777983435d89c1a9697f67d22d45a046ec7b173 (refs/remotes/origin/pr/5302/merge)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 9777983435d89c1a9697f67d22d45a046ec7b173
Commit message: "Merge 93fcc6c6d3ad0ee3b425c1e4c11956f5075f1bb9 into 2976e9f84d20ca3fbab7c3d304dae71188de92ff"
First time build. Skipping changelog.
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3932424041737278408.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1577

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

------------------------------------------
GitHub pull request #5053 of commit cc8bc3fd88d7989cf28ab062117fede102e35bed, no merge conflicts.
Setting status of cc8bc3fd88d7989cf28ab062117fede102e35bed to PENDING with url https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/1577/ and message: 'Build started sha1 is merged.'
Using context: Jenkins: Google Cloud Dataflow Runner Python ValidatesRunner Tests
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/5053/*:refs/remotes/origin/pr/5053/*
 > git rev-parse refs/remotes/origin/pr/5053/merge^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/pr/5053/merge^{commit} # timeout=10
Checking out Revision 52e183109f0de7b57821d0a19dae73e20da649a7 (refs/remotes/origin/pr/5053/merge)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 52e183109f0de7b57821d0a19dae73e20da649a7
Commit message: "Merge cc8bc3fd88d7989cf28ab062117fede102e35bed into 2976e9f84d20ca3fbab7c3d304dae71188de92ff"
First time build. Skipping changelog.
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3321960360778221739.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1576

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

Changes:

[kirpichov] [BEAM-4242] Fixes O(n) complexity of Wait.on() due to combiner lifting

------------------------------------------
[...truncated 88.19 KB...]
    self.result = super(TestDataflowRunner, self).run_pipeline(pipeline)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 363, in run_pipeline
    self.dataflow_client.create_job(self.job), self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/retry.py",> line 180, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 470, in create_job
    self.create_job_description(job)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 500, in create_job_description
    job.options, file_copy=self._gcs_file_copy)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 329, in stage_job_resources
    setup_options.requirements_file, requirements_cache_path)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 263, in _populate_requirements_cache
    processes.check_call(cmd_args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/processes.py",> line 44, in check_call
    return subprocess.check_call(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 541, in check_call
    raise CalledProcessError(retcode, cmd)
CalledProcessError: Command '['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']' returned non-zero exit status 2
-------------------- >> begin captured logging << --------------------
root: DEBUG: PValue computed by Some Numbers/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(some_fn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(some_fn) (tag odd): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(some_fn) (tag even): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Unkey (tag None): refcount: 1 => 0
root: DEBUG: Connecting using Google Application Default Credentials.
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-881203.1525902590.881385/pipeline.pb...
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-881203.1525902590.881385/pipeline.pb
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-881203.1525902590.881385/requirements.txt...
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-881203.1525902590.881385/requirements.txt
root: INFO: Executing command: ['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_multiple_empty_outputs (apache_beam.transforms.ptransform_test.PTransformTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py",> line 271, in test_multiple_empty_outputs
    pipeline.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 102, in run
    result = super(TestPipeline, self).run(test_runner_api)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 389, in run
    self.to_runner_api(), self.runner, self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 402, in run
    return self.runner.run_pipeline(self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 48, in run_pipeline
    self.result = super(TestDataflowRunner, self).run_pipeline(pipeline)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 363, in run_pipeline
    self.dataflow_client.create_job(self.job), self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/retry.py",> line 180, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 470, in create_job
    self.create_job_description(job)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 500, in create_job_description
    job.options, file_copy=self._gcs_file_copy)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 329, in stage_job_resources
    setup_options.requirements_file, requirements_cache_path)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 263, in _populate_requirements_cache
    processes.check_call(cmd_args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/processes.py",> line 44, in check_call
    return subprocess.check_call(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 541, in check_call
    raise CalledProcessError(retcode, cmd)
CalledProcessError: Command '['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']' returned non-zero exit status 2
-------------------- >> begin captured logging << --------------------
root: DEBUG: PValue computed by Some Numbers/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(<lambda at ptransform_test.py:265>) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(<lambda at ptransform_test.py:265>) (tag odd): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(<lambda at ptransform_test.py:265>) (tag even): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Unkey (tag None): refcount: 1 => 0
root: DEBUG: Connecting using Google Application Default Credentials.
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-864802.1525902590.864974/pipeline.pb...
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-864802.1525902590.864974/pipeline.pb
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-864802.1525902590.864974/requirements.txt...
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-864802.1525902590.864974/requirements.txt
root: INFO: Executing command: ['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_flatten_multiple_pcollections_having_multiple_consumers (apache_beam.transforms.ptransform_test.PTransformTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py",> line 558, in test_flatten_multiple_pcollections_having_multiple_consumers
    pipeline.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 102, in run
    result = super(TestPipeline, self).run(test_runner_api)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 389, in run
    self.to_runner_api(), self.runner, self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 402, in run
    return self.runner.run_pipeline(self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 48, in run_pipeline
    self.result = super(TestDataflowRunner, self).run_pipeline(pipeline)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 363, in run_pipeline
    self.dataflow_client.create_job(self.job), self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/retry.py",> line 180, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 470, in create_job
    self.create_job_description(job)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 500, in create_job_description
    job.options, file_copy=self._gcs_file_copy)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 329, in stage_job_resources
    setup_options.requirements_file, requirements_cache_path)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 263, in _populate_requirements_cache
    processes.check_call(cmd_args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/processes.py",> line 44, in check_call
    return subprocess.check_call(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 541, in check_call
    raise CalledProcessError(retcode, cmd)
CalledProcessError: Command '['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']' returned non-zero exit status 2
-------------------- >> begin captured logging << --------------------
root: DEBUG: PValue computed by Start/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag even_length): refcount: 2 => 1
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag odd_length): refcount: 2 => 1
root: DEBUG: PValue computed by Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag even_length): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag odd_length): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Unkey (tag None): refcount: 1 => 0
root: DEBUG: Connecting using Google Application Default Credentials.
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-854316.1525902590.854509/pipeline.pb...
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-854316.1525902590.854509/pipeline.pb
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-854316.1525902590.854509/requirements.txt...
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509214950-854316.1525902590.854509/requirements.txt
root: INFO: Executing command: ['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']
--------------------- >> end captured logging << ---------------------

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 16 tests in 1675.112s

FAILED (errors=3)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_14_49_56-12663594647486466179?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_14_57_13-10145537363398323545?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_03_52-5982344620917636870?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_10_33-16661123036421896501?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_14_49_58-2638734840693554774?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_14_57_00-15710063172365089658?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_03_58-7181644830512778332?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_14_49_59-12168101413471597157?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_14_57_11-5467743974767872232?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_03_58-11419619622261263613?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_14_49_57-6652566308920616224?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_14_56_59-16062179470909170751?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_15_03_44-8766320220905908605?project=apache-beam-testing.
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1575

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision fa2afde7be6e9063167f73163c7308d9140fe8b5 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f fa2afde7be6e9063167f73163c7308d9140fe8b5
Commit message: "Merge pull request #5318: [BEAM-3417] Fix calcite assertions"
 > git rev-list --no-walk fa2afde7be6e9063167f73163c7308d9140fe8b5 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1088174619961944328.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1574

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

Changes:

[apilloud] [SQL] Simplify planner usage, fix assertions

[apilloud] [SQL] Cleanup BeamAggregation rule and rel to fix

[apilloud] [SQL] Fix assertion failures in test

------------------------------------------
Started by GitHub push by kennknowles
[EnvInject] - Loading node environment variables.
Building remotely on beam6 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision fa2afde7be6e9063167f73163c7308d9140fe8b5 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f fa2afde7be6e9063167f73163c7308d9140fe8b5
Commit message: "Merge pull request #5318: [BEAM-3417] Fix calcite assertions"
 > git rev-list --no-walk da8fa25f4b65831c851ed76a2fc09420091c7f3e # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins7758329806447778395.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1573

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

------------------------------------------
GitHub pull request #5053 of commit cc8bc3fd88d7989cf28ab062117fede102e35bed, no merge conflicts.
GitHub pull request #5053 of commit cc8bc3fd88d7989cf28ab062117fede102e35bed, no merge conflicts.
Setting status of cc8bc3fd88d7989cf28ab062117fede102e35bed to PENDING with url https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/1573/ and message: 'Build started sha1 is merged.'
Using context: Jenkins: Google Cloud Dataflow Runner Python ValidatesRunner Tests
[EnvInject] - Loading node environment variables.
Building remotely on beam13 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/5053/*:refs/remotes/origin/pr/5053/*
 > git rev-parse refs/remotes/origin/pr/5053/merge^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/pr/5053/merge^{commit} # timeout=10
Checking out Revision b04abd1472d8c72e6ccded99b6e584cdb7536118 (refs/remotes/origin/pr/5053/merge)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f b04abd1472d8c72e6ccded99b6e584cdb7536118
Commit message: "Merge cc8bc3fd88d7989cf28ab062117fede102e35bed into fa2afde7be6e9063167f73163c7308d9140fe8b5"
First time build. Skipping changelog.
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8688789985888858372.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1572

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

------------------------------------------
GitHub pull request #5302 of commit 4cd60132627cde94c50a9b56b10b2d6e0924229c, no merge conflicts.
Setting status of 4cd60132627cde94c50a9b56b10b2d6e0924229c to PENDING with url https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/1572/ and message: 'Build started sha1 is merged.'
Using context: Jenkins: Google Cloud Dataflow Runner Python ValidatesRunner Tests
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/5302/*:refs/remotes/origin/pr/5302/*
 > git rev-parse refs/remotes/origin/pr/5302/merge^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/pr/5302/merge^{commit} # timeout=10
Checking out Revision 938cea786e0273801c7b0074efa151e3178f6e65 (refs/remotes/origin/pr/5302/merge)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 938cea786e0273801c7b0074efa151e3178f6e65
Commit message: "Merge 4cd60132627cde94c50a9b56b10b2d6e0924229c into da8fa25f4b65831c851ed76a2fc09420091c7f3e"
First time build. Skipping changelog.
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins4075037702291611179.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1571

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

Changes:

[kedin] [SQL] Change DDL parser to create Beam Schema types instead of Calcite

[kedin] [SQL] Support arrays of primitive types in DDL

[kedin] [SQL] Parse Row fields

[kedin] [SQL] Remove Column. Replace with Schema

[kedin] [SQL] Validate Table schemas in BeamSqlCliTest

[kedin] [SQL] Add support for angular brackets array definition

[kedin] [SQL] Add support for Maps in DDL

[kedin] [SQL] Add support for angular brackets Row syntax

[kedin] [SQL] Fix rebase conflicts

[kedin] [SQL] Add QuickCheck and tests for DDL schema verification

[kedin] [SQL] Remove support for postfix array declaration in DDL

------------------------------------------
[...truncated 126.16 KB...]
        "serialized_fn": "%0AD%22B%0A%1Dref_Coder_GlobalWindowCoder_1%12%21%0A%1F%0A%1D%0A%1Bbeam%3Acoder%3Aglobal_window%3Av1jT%0A%25%0A%23%0A%21beam%3Awindowfn%3Aglobal_windows%3Av0.1%10%01%1A%1Dref_Coder_GlobalWindowCoder_1%22%02%3A%00%28%010%018%01H%01", 
        "user_name": "assert_that/Group/GroupByKey"
      }
    }, 
    {
      "kind": "ParallelDo", 
      "name": "s13", 
      "properties": {
        "display_data": [
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "_merge_tagged_vals_under_key"
          }, 
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.ParDo", 
            "shortValue": "CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "apache_beam.transforms.core.CallableWrapperDoFn"
          }
        ], 
        "non_parallel_inputs": {}, 
        "output_info": [
          {
            "encoding": {
              "@type": "kind:windowed_value", 
              "component_encodings": [
                {
                  "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                  "component_encodings": [
                    {
                      "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                      "component_encodings": []
                    }, 
                    {
                      "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                      "component_encodings": []
                    }
                  ], 
                  "is_pair_like": true
                }, 
                {
                  "@type": "kind:global_window"
                }
              ], 
              "is_wrapper": true
            }, 
            "output_name": "out", 
            "user_name": "assert_that/Group/Map(_merge_tagged_vals_under_key).out"
          }
        ], 
        "parallel_input": {
          "@type": "OutputReference", 
          "output_name": "out", 
          "step_name": "s12"
        }, 
        "serialized_fn": "<string of 1380 bytes>", 
        "user_name": "assert_that/Group/Map(_merge_tagged_vals_under_key)"
      }
    }, 
    {
      "kind": "ParallelDo", 
      "name": "s14", 
      "properties": {
        "display_data": [
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "<lambda>"
          }, 
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.ParDo", 
            "shortValue": "CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "apache_beam.transforms.core.CallableWrapperDoFn"
          }
        ], 
        "non_parallel_inputs": {}, 
        "output_info": [
          {
            "encoding": {
              "@type": "kind:windowed_value", 
              "component_encodings": [
                {
                  "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                  "component_encodings": [
                    {
                      "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                      "component_encodings": []
                    }, 
                    {
                      "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                      "component_encodings": []
                    }
                  ], 
                  "is_pair_like": true
                }, 
                {
                  "@type": "kind:global_window"
                }
              ], 
              "is_wrapper": true
            }, 
            "output_name": "out", 
            "user_name": "assert_that/Unkey.out"
          }
        ], 
        "parallel_input": {
          "@type": "OutputReference", 
          "output_name": "out", 
          "step_name": "s13"
        }, 
        "serialized_fn": "<string of 980 bytes>", 
        "user_name": "assert_that/Unkey"
      }
    }, 
    {
      "kind": "ParallelDo", 
      "name": "s15", 
      "properties": {
        "display_data": [
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "match"
          }, 
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.ParDo", 
            "shortValue": "CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "apache_beam.transforms.core.CallableWrapperDoFn"
          }
        ], 
        "non_parallel_inputs": {}, 
        "output_info": [
          {
            "encoding": {
              "@type": "kind:windowed_value", 
              "component_encodings": [
                {
                  "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                  "component_encodings": [
                    {
                      "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                      "component_encodings": []
                    }, 
                    {
                      "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                      "component_encodings": []
                    }
                  ], 
                  "is_pair_like": true
                }, 
                {
                  "@type": "kind:global_window"
                }
              ], 
              "is_wrapper": true
            }, 
            "output_name": "out", 
            "user_name": "assert_that/Match.out"
          }
        ], 
        "parallel_input": {
          "@type": "OutputReference", 
          "output_name": "out", 
          "step_name": "s14"
        }, 
        "serialized_fn": "<string of 1156 bytes>", 
        "user_name": "assert_that/Match"
      }
    }
  ], 
  "type": "JOB_TYPE_BATCH"
}
root: INFO: Create job: <Job
 createTime: u'2018-05-09T19:12:35.938810Z'
 currentStateTime: u'1970-01-01T00:00:00Z'
 id: u'2018-05-09_12_12_35-15219470534614881236'
 location: u'us-central1'
 name: u'beamapp-jenkins-0509191229-501701'
 projectId: u'apache-beam-testing'
 stageStates: []
 steps: []
 tempFiles: []
 type: TypeValueValuesEnum(JOB_TYPE_BATCH, 1)>
root: INFO: Created job with id: [2018-05-09_12_12_35-15219470534614881236]
root: INFO: To access the Dataflow monitoring console, please navigate to https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_12_35-15219470534614881236?project=apache-beam-testing
--------------------- >> end captured logging << ---------------------

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 16 tests in 1788.673s

FAILED (errors=1)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_11_57_40-1205575867654378239?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_05_47-17275953986697651914?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_12_35-15219470534614881236?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_14_42-3454784612818588732?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_11_57_39-4354768321779810281?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_05_47-4336433687695902562?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_13_26-3823503757339852611?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_20_44-10442373851912683866?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_11_57_40-4304478851947029758?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_06_09-16572769316762970545?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_12_47-5751726314053530745?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_20_35-15763419786676582626?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_11_57_40-17792109755979464399?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_05_12-5625256912819806560?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_12_00-10967801141178383122?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-09_12_19_18-10479970484949123781?project=apache-beam-testing.
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1570

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

Changes:

[github] Revert "Enable githubCommitNotifier for post commits"

------------------------------------------
Started by GitHub push by jasonkuster
[EnvInject] - Loading node environment variables.
Building remotely on beam4 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 27083293394e48c7d437f562dd504f04d55a05af (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 27083293394e48c7d437f562dd504f04d55a05af
Commit message: "Merge pull request #5316: Revert "Enable githubCommitNotifier for post commits""
 > git rev-list --no-walk c7dee989fbccc6d64bd76155b6237476ff658a5c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins4651663796772134499.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
[Set GitHub commit status (universal)] ERROR on repos [GHRepository@377b6eb3[description=Apache Beam,homepage=,name=beam,fork=false,size=58730,milestones={},language=Java,commits={},source=<null>,parent=<null>,responseHeaderFields={null=[HTTP/1.1 200 OK], Access-Control-Allow-Origin=[*], Access-Control-Expose-Headers=[ETag, Link, Retry-After, X-GitHub-OTP, X-RateLimit-Limit, X-RateLimit-Remaining, X-RateLimit-Reset, X-OAuth-Scopes, X-Accepted-OAuth-Scopes, X-Poll-Interval], Cache-Control=[private, max-age=60, s-maxage=60], Content-Encoding=[gzip], Content-Security-Policy=[default-src 'none'], Content-Type=[application/json; charset=utf-8], Date=[Wed, 09 May 2018 16:51:31 GMT], ETag=[W/"105bab69b03a6d16da29866c396e6c38"], Last-Modified=[Wed, 09 May 2018 16:51:10 GMT], OkHttp-Received-Millis=[1525884691331], OkHttp-Response-Source=[NETWORK 200], OkHttp-Selected-Protocol=[http/1.1], OkHttp-Sent-Millis=[1525884691186], Referrer-Policy=[origin-when-cross-origin, strict-origin-when-cross-origin], Server=[GitHub.com], Status=[200 OK], Strict-Transport-Security=[max-age=31536000; includeSubdomains; preload], Transfer-Encoding=[chunked], Vary=[Accept, Authorization, Cookie, X-GitHub-OTP], X-Accepted-OAuth-Scopes=[repo], X-Content-Type-Options=[nosniff], X-Frame-Options=[deny], X-GitHub-Media-Type=[github.v3; format=json], X-GitHub-Request-Id=[CDFC:4F41:119099A:25AEB04:5AF3270B], X-OAuth-Scopes=[admin:repo_hook, repo, repo:status], X-RateLimit-Limit=[5000], X-RateLimit-Remaining=[4961], X-RateLimit-Reset=[1525886159], X-Runtime-rack=[0.058757], X-XSS-Protection=[1; mode=block]},url=https://api.github.com/repos/apache/beam,id=50904245]] (sha:2708329) with context:beam_PostCommit_Python_ValidatesRunner_Dataflow
Setting commit status on GitHub for https://github.com/apache/beam/commit/27083293394e48c7d437f562dd504f04d55a05af
ERROR: Build step failed with exception
java.io.FileNotFoundException: https://api.github.com/repos/apache/beam/statuses/27083293394e48c7d437f562dd504f04d55a05af
	at com.squareup.okhttp.internal.huc.HttpURLConnectionImpl.getInputStream(HttpURLConnectionImpl.java:243)
	at com.squareup.okhttp.internal.huc.DelegatingHttpsURLConnection.getInputStream(DelegatingHttpsURLConnection.java:210)
	at com.squareup.okhttp.internal.huc.HttpsURLConnectionImpl.getInputStream(HttpsURLConnectionImpl.java:25)
	at org.kohsuke.github.Requester.parse(Requester.java:612)
	at org.kohsuke.github.Requester.parse(Requester.java:594)
	at org.kohsuke.github.Requester._to(Requester.java:272)
Caused: org.kohsuke.github.GHFileNotFoundException: {"message":"Not Found","documentation_url":"https://developer.github.com/v3/repos/statuses/#create-a-status"}
	at org.kohsuke.github.Requester.handleApiError(Requester.java:686)
	at org.kohsuke.github.Requester._to(Requester.java:293)
	at org.kohsuke.github.Requester.to(Requester.java:234)
	at org.kohsuke.github.GHRepository.createCommitStatus(GHRepository.java:1075)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:160)
Caused: org.jenkinsci.plugins.github.common.CombineErrorHandler$ErrorHandlingException
	at org.jenkinsci.plugins.github.common.CombineErrorHandler.handle(CombineErrorHandler.java:74)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:164)
	at com.cloudbees.jenkins.GitHubCommitNotifier.perform(GitHubCommitNotifier.java:151)
	at hudson.tasks.BuildStepCompatibilityLayer.perform(BuildStepCompatibilityLayer.java:81)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:744)
	at hudson.model.AbstractBuild$AbstractBuildExecution.performAllBuildSteps(AbstractBuild.java:690)
	at hudson.model.Build$BuildExecution.post2(Build.java:186)
	at hudson.model.AbstractBuild$AbstractBuildExecution.post(AbstractBuild.java:635)
	at hudson.model.Run.execute(Run.java:1749)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
Build step 'Set build status on GitHub commit [deprecated]' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1569

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

Changes:

[yifanzou] update machine numbers to 1..16 for inventory tests

------------------------------------------
Started by GitHub push by jasonkuster
[EnvInject] - Loading node environment variables.
Building remotely on beam12 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision c7dee989fbccc6d64bd76155b6237476ff658a5c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f c7dee989fbccc6d64bd76155b6237476ff658a5c
Commit message: "Merge pull request #5303: update machine numbers to 1..16 for inventory tests"
 > git rev-list --no-walk 1e40357edf3e9940bb898bcd7b6c5516d685f908 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3470450947659524554.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
[Set GitHub commit status (universal)] ERROR on repos [GHRepository@6f4cf41[description=Apache Beam,homepage=,name=beam,fork=false,size=58730,milestones={},language=Java,commits={},source=<null>,parent=<null>,responseHeaderFields={null=[HTTP/1.1 200 OK], Access-Control-Allow-Origin=[*], Access-Control-Expose-Headers=[ETag, Link, Retry-After, X-GitHub-OTP, X-RateLimit-Limit, X-RateLimit-Remaining, X-RateLimit-Reset, X-OAuth-Scopes, X-Accepted-OAuth-Scopes, X-Poll-Interval], Cache-Control=[private, max-age=60, s-maxage=60], Content-Encoding=[gzip], Content-Security-Policy=[default-src 'none'], Content-Type=[application/json; charset=utf-8], Date=[Wed, 09 May 2018 16:41:33 GMT], ETag=[W/"5c9d6c3689c17a1bcebc550b5488695c"], Last-Modified=[Wed, 09 May 2018 16:41:32 GMT], OkHttp-Received-Millis=[1525884093362], OkHttp-Response-Source=[NETWORK 200], OkHttp-Selected-Protocol=[http/1.1], OkHttp-Sent-Millis=[1525884093207], Referrer-Policy=[origin-when-cross-origin, strict-origin-when-cross-origin], Server=[GitHub.com], Status=[200 OK], Strict-Transport-Security=[max-age=31536000; includeSubdomains; preload], Transfer-Encoding=[chunked], Vary=[Accept, Authorization, Cookie, X-GitHub-OTP], X-Accepted-OAuth-Scopes=[repo], X-Content-Type-Options=[nosniff], X-Frame-Options=[deny], X-GitHub-Media-Type=[github.v3; format=json], X-GitHub-Request-Id=[CBCA:4F41:117BE7F:2582505:5AF324B3], X-OAuth-Scopes=[admin:repo_hook, repo, repo:status], X-RateLimit-Limit=[5000], X-RateLimit-Remaining=[4971], X-RateLimit-Reset=[1525886159], X-Runtime-rack=[0.072669], X-XSS-Protection=[1; mode=block]},url=https://api.github.com/repos/apache/beam,id=50904245]] (sha:c7dee98) with context:beam_PostCommit_Python_ValidatesRunner_Dataflow
Setting commit status on GitHub for https://github.com/apache/beam/commit/c7dee989fbccc6d64bd76155b6237476ff658a5c
ERROR: Build step failed with exception
java.io.FileNotFoundException: https://api.github.com/repos/apache/beam/statuses/c7dee989fbccc6d64bd76155b6237476ff658a5c
	at com.squareup.okhttp.internal.huc.HttpURLConnectionImpl.getInputStream(HttpURLConnectionImpl.java:243)
	at com.squareup.okhttp.internal.huc.DelegatingHttpsURLConnection.getInputStream(DelegatingHttpsURLConnection.java:210)
	at com.squareup.okhttp.internal.huc.HttpsURLConnectionImpl.getInputStream(HttpsURLConnectionImpl.java:25)
	at org.kohsuke.github.Requester.parse(Requester.java:612)
	at org.kohsuke.github.Requester.parse(Requester.java:594)
	at org.kohsuke.github.Requester._to(Requester.java:272)
Caused: org.kohsuke.github.GHFileNotFoundException: {"message":"Not Found","documentation_url":"https://developer.github.com/v3/repos/statuses/#create-a-status"}
	at org.kohsuke.github.Requester.handleApiError(Requester.java:686)
	at org.kohsuke.github.Requester._to(Requester.java:293)
	at org.kohsuke.github.Requester.to(Requester.java:234)
	at org.kohsuke.github.GHRepository.createCommitStatus(GHRepository.java:1075)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:160)
Caused: org.jenkinsci.plugins.github.common.CombineErrorHandler$ErrorHandlingException
	at org.jenkinsci.plugins.github.common.CombineErrorHandler.handle(CombineErrorHandler.java:74)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:164)
	at com.cloudbees.jenkins.GitHubCommitNotifier.perform(GitHubCommitNotifier.java:151)
	at hudson.tasks.BuildStepCompatibilityLayer.perform(BuildStepCompatibilityLayer.java:81)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:744)
	at hudson.model.AbstractBuild$AbstractBuildExecution.performAllBuildSteps(AbstractBuild.java:690)
	at hudson.model.Build$BuildExecution.post2(Build.java:186)
	at hudson.model.AbstractBuild$AbstractBuildExecution.post(AbstractBuild.java:635)
	at hudson.model.Run.execute(Run.java:1749)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
Build step 'Set build status on GitHub commit [deprecated]' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user yifanzou@yifanzou-linuxworkstation.sea.corp.google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1568

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

Changes:

[Pablo] StateSampler knows the execution thread it tracks.

------------------------------------------
Started by GitHub push by pabloem
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 1e40357edf3e9940bb898bcd7b6c5516d685f908 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 1e40357edf3e9940bb898bcd7b6c5516d685f908
Commit message: "StateSampler knows the execution thread it tracks."
 > git rev-list --no-walk 60f90c8dcb229c35a82c7be15e64a89678bae058 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1445610769962254372.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
[Set GitHub commit status (universal)] ERROR on repos [GHRepository@728f7ce3[description=Apache Beam,homepage=,name=beam,fork=false,size=58728,milestones={},language=Java,commits={},source=<null>,parent=<null>,responseHeaderFields={null=[HTTP/1.1 200 OK], Access-Control-Allow-Origin=[*], Access-Control-Expose-Headers=[ETag, Link, Retry-After, X-GitHub-OTP, X-RateLimit-Limit, X-RateLimit-Remaining, X-RateLimit-Reset, X-OAuth-Scopes, X-Accepted-OAuth-Scopes, X-Poll-Interval], Cache-Control=[private, max-age=60, s-maxage=60], Content-Encoding=[gzip], Content-Security-Policy=[default-src 'none'], Content-Type=[application/json; charset=utf-8], Date=[Wed, 09 May 2018 15:40:10 GMT], ETag=[W/"e8546411728fd07a5ada7baf7fc038ea"], Last-Modified=[Wed, 09 May 2018 15:39:49 GMT], OkHttp-Received-Millis=[1525880410899], OkHttp-Response-Source=[NETWORK 200], OkHttp-Selected-Protocol=[http/1.1], OkHttp-Sent-Millis=[1525880410713], Referrer-Policy=[origin-when-cross-origin, strict-origin-when-cross-origin], Server=[GitHub.com], Status=[200 OK], Strict-Transport-Security=[max-age=31536000; includeSubdomains; preload], Transfer-Encoding=[chunked], Vary=[Accept, Authorization, Cookie, X-GitHub-OTP], X-Accepted-OAuth-Scopes=[repo], X-Content-Type-Options=[nosniff], X-Frame-Options=[deny], X-GitHub-Media-Type=[github.v3; format=json], X-GitHub-Request-Id=[C012:4F40:CC34F2:1C2AB82:5AF31654], X-OAuth-Scopes=[admin:repo_hook, repo, repo:status], X-RateLimit-Limit=[5000], X-RateLimit-Remaining=[4989], X-RateLimit-Reset=[1525882523], X-Runtime-rack=[0.099106], X-XSS-Protection=[1; mode=block]},url=https://api.github.com/repos/apache/beam,id=50904245]] (sha:1e40357) with context:beam_PostCommit_Python_ValidatesRunner_Dataflow
Setting commit status on GitHub for https://github.com/apache/beam/commit/1e40357edf3e9940bb898bcd7b6c5516d685f908
ERROR: Build step failed with exception
java.io.FileNotFoundException: https://api.github.com/repos/apache/beam/statuses/1e40357edf3e9940bb898bcd7b6c5516d685f908
	at com.squareup.okhttp.internal.huc.HttpURLConnectionImpl.getInputStream(HttpURLConnectionImpl.java:243)
	at com.squareup.okhttp.internal.huc.DelegatingHttpsURLConnection.getInputStream(DelegatingHttpsURLConnection.java:210)
	at com.squareup.okhttp.internal.huc.HttpsURLConnectionImpl.getInputStream(HttpsURLConnectionImpl.java:25)
	at org.kohsuke.github.Requester.parse(Requester.java:612)
	at org.kohsuke.github.Requester.parse(Requester.java:594)
	at org.kohsuke.github.Requester._to(Requester.java:272)
Caused: org.kohsuke.github.GHFileNotFoundException: {"message":"Not Found","documentation_url":"https://developer.github.com/v3/repos/statuses/#create-a-status"}
	at org.kohsuke.github.Requester.handleApiError(Requester.java:686)
	at org.kohsuke.github.Requester._to(Requester.java:293)
	at org.kohsuke.github.Requester.to(Requester.java:234)
	at org.kohsuke.github.GHRepository.createCommitStatus(GHRepository.java:1075)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:160)
Caused: org.jenkinsci.plugins.github.common.CombineErrorHandler$ErrorHandlingException
	at org.jenkinsci.plugins.github.common.CombineErrorHandler.handle(CombineErrorHandler.java:74)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:164)
	at com.cloudbees.jenkins.GitHubCommitNotifier.perform(GitHubCommitNotifier.java:151)
	at hudson.tasks.BuildStepCompatibilityLayer.perform(BuildStepCompatibilityLayer.java:81)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:744)
	at hudson.model.AbstractBuild$AbstractBuildExecution.performAllBuildSteps(AbstractBuild.java:690)
	at hudson.model.Build$BuildExecution.post2(Build.java:186)
	at hudson.model.AbstractBuild$AbstractBuildExecution.post(AbstractBuild.java:635)
	at hudson.model.Run.execute(Run.java:1749)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
Build step 'Set build status on GitHub commit [deprecated]' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1567

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam6 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 60f90c8dcb229c35a82c7be15e64a89678bae058 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 60f90c8dcb229c35a82c7be15e64a89678bae058
Commit message: "Make experiments as set attr of RuntimeValueProvider"
 > git rev-list --no-walk 60f90c8dcb229c35a82c7be15e64a89678bae058 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3296916707805437040.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
[Set GitHub commit status (universal)] ERROR on repos [GHRepository@5fa62ff5[description=Apache Beam,homepage=,name=beam,fork=false,size=58728,milestones={},language=Java,commits={},source=<null>,parent=<null>,responseHeaderFields={null=[HTTP/1.1 200 OK], Access-Control-Allow-Origin=[*], Access-Control-Expose-Headers=[ETag, Link, Retry-After, X-GitHub-OTP, X-RateLimit-Limit, X-RateLimit-Remaining, X-RateLimit-Reset, X-OAuth-Scopes, X-Accepted-OAuth-Scopes, X-Poll-Interval], Cache-Control=[private, max-age=60, s-maxage=60], Content-Encoding=[gzip], Content-Security-Policy=[default-src 'none'], Content-Type=[application/json; charset=utf-8], Date=[Wed, 09 May 2018 15:19:25 GMT], ETag=[W/"3f2fdd2b779aabf429f86f58ffb24cd3"], Last-Modified=[Wed, 09 May 2018 10:15:34 GMT], OkHttp-Received-Millis=[1525879165411], OkHttp-Response-Source=[NETWORK 200], OkHttp-Selected-Protocol=[http/1.1], OkHttp-Sent-Millis=[1525879165155], Referrer-Policy=[origin-when-cross-origin, strict-origin-when-cross-origin], Server=[GitHub.com], Status=[200 OK], Strict-Transport-Security=[max-age=31536000; includeSubdomains; preload], Transfer-Encoding=[chunked], Vary=[Accept, Authorization, Cookie, X-GitHub-OTP], X-Accepted-OAuth-Scopes=[repo], X-Content-Type-Options=[nosniff], X-Frame-Options=[deny], X-GitHub-Media-Type=[github.v3; format=json], X-GitHub-Request-Id=[8D98:4F3F:8CE4D4:14C44F5:5AF3117D], X-OAuth-Scopes=[admin:repo_hook, repo, repo:status], X-RateLimit-Limit=[5000], X-RateLimit-Remaining=[4995], X-RateLimit-Reset=[1525882523], X-Runtime-rack=[0.052867], X-XSS-Protection=[1; mode=block]},url=https://api.github.com/repos/apache/beam,id=50904245]] (sha:60f90c8) with context:beam_PostCommit_Python_ValidatesRunner_Dataflow
Setting commit status on GitHub for https://github.com/apache/beam/commit/60f90c8dcb229c35a82c7be15e64a89678bae058
ERROR: Build step failed with exception
java.io.FileNotFoundException: https://api.github.com/repos/apache/beam/statuses/60f90c8dcb229c35a82c7be15e64a89678bae058
	at com.squareup.okhttp.internal.huc.HttpURLConnectionImpl.getInputStream(HttpURLConnectionImpl.java:243)
	at com.squareup.okhttp.internal.huc.DelegatingHttpsURLConnection.getInputStream(DelegatingHttpsURLConnection.java:210)
	at com.squareup.okhttp.internal.huc.HttpsURLConnectionImpl.getInputStream(HttpsURLConnectionImpl.java:25)
	at org.kohsuke.github.Requester.parse(Requester.java:612)
	at org.kohsuke.github.Requester.parse(Requester.java:594)
	at org.kohsuke.github.Requester._to(Requester.java:272)
Caused: org.kohsuke.github.GHFileNotFoundException: {"message":"Not Found","documentation_url":"https://developer.github.com/v3/repos/statuses/#create-a-status"}
	at org.kohsuke.github.Requester.handleApiError(Requester.java:686)
	at org.kohsuke.github.Requester._to(Requester.java:293)
	at org.kohsuke.github.Requester.to(Requester.java:234)
	at org.kohsuke.github.GHRepository.createCommitStatus(GHRepository.java:1075)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:160)
Caused: org.jenkinsci.plugins.github.common.CombineErrorHandler$ErrorHandlingException
	at org.jenkinsci.plugins.github.common.CombineErrorHandler.handle(CombineErrorHandler.java:74)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:164)
	at com.cloudbees.jenkins.GitHubCommitNotifier.perform(GitHubCommitNotifier.java:151)
	at hudson.tasks.BuildStepCompatibilityLayer.perform(BuildStepCompatibilityLayer.java:81)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:744)
	at hudson.model.AbstractBuild$AbstractBuildExecution.performAllBuildSteps(AbstractBuild.java:690)
	at hudson.model.Build$BuildExecution.post2(Build.java:186)
	at hudson.model.AbstractBuild$AbstractBuildExecution.post(AbstractBuild.java:635)
	at hudson.model.Run.execute(Run.java:1749)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
Build step 'Set build status on GitHub commit [deprecated]' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1566

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam1 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 60f90c8dcb229c35a82c7be15e64a89678bae058 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 60f90c8dcb229c35a82c7be15e64a89678bae058
Commit message: "Make experiments as set attr of RuntimeValueProvider"
 > git rev-list --no-walk 60f90c8dcb229c35a82c7be15e64a89678bae058 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1697493468193197662.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
[Set GitHub commit status (universal)] ERROR on repos [GHRepository@40d17c07[description=Apache Beam,homepage=,name=beam,fork=false,size=58754,milestones={},language=Java,commits={},source=<null>,parent=<null>,responseHeaderFields={null=[HTTP/1.1 200 OK], Access-Control-Allow-Origin=[*], Access-Control-Expose-Headers=[ETag, Link, Retry-After, X-GitHub-OTP, X-RateLimit-Limit, X-RateLimit-Remaining, X-RateLimit-Reset, X-OAuth-Scopes, X-Accepted-OAuth-Scopes, X-Poll-Interval], Cache-Control=[private, max-age=60, s-maxage=60], Content-Encoding=[gzip], Content-Security-Policy=[default-src 'none'], Content-Type=[application/json; charset=utf-8], Date=[Wed, 09 May 2018 09:00:10 GMT], ETag=[W/"edc538b569b8706bee144344d3b1a471"], Last-Modified=[Wed, 09 May 2018 06:33:16 GMT], OkHttp-Received-Millis=[1525856410753], OkHttp-Response-Source=[NETWORK 200], OkHttp-Selected-Protocol=[http/1.1], OkHttp-Sent-Millis=[1525856410615], Referrer-Policy=[origin-when-cross-origin, strict-origin-when-cross-origin], Server=[GitHub.com], Status=[200 OK], Strict-Transport-Security=[max-age=31536000; includeSubdomains; preload], Transfer-Encoding=[chunked], Vary=[Accept, Authorization, Cookie, X-GitHub-OTP], X-Accepted-OAuth-Scopes=[repo], X-Content-Type-Options=[nosniff], X-Frame-Options=[deny], X-GitHub-Media-Type=[github.v3; format=json], X-GitHub-Request-Id=[D80C:4F40:A52187:16BD093:5AF2B863], X-OAuth-Scopes=[admin:repo_hook, repo, repo:status], X-RateLimit-Limit=[5000], X-RateLimit-Remaining=[4999], X-RateLimit-Reset=[1525860010], X-Runtime-rack=[0.057080], X-XSS-Protection=[1; mode=block]},url=https://api.github.com/repos/apache/beam,id=50904245]] (sha:60f90c8) with context:beam_PostCommit_Python_ValidatesRunner_Dataflow
Setting commit status on GitHub for https://github.com/apache/beam/commit/60f90c8dcb229c35a82c7be15e64a89678bae058
ERROR: Build step failed with exception
java.io.FileNotFoundException: https://api.github.com/repos/apache/beam/statuses/60f90c8dcb229c35a82c7be15e64a89678bae058
	at com.squareup.okhttp.internal.huc.HttpURLConnectionImpl.getInputStream(HttpURLConnectionImpl.java:243)
	at com.squareup.okhttp.internal.huc.DelegatingHttpsURLConnection.getInputStream(DelegatingHttpsURLConnection.java:210)
	at com.squareup.okhttp.internal.huc.HttpsURLConnectionImpl.getInputStream(HttpsURLConnectionImpl.java:25)
	at org.kohsuke.github.Requester.parse(Requester.java:612)
	at org.kohsuke.github.Requester.parse(Requester.java:594)
	at org.kohsuke.github.Requester._to(Requester.java:272)
Caused: org.kohsuke.github.GHFileNotFoundException: {"message":"Not Found","documentation_url":"https://developer.github.com/v3/repos/statuses/#create-a-status"}
	at org.kohsuke.github.Requester.handleApiError(Requester.java:686)
	at org.kohsuke.github.Requester._to(Requester.java:293)
	at org.kohsuke.github.Requester.to(Requester.java:234)
	at org.kohsuke.github.GHRepository.createCommitStatus(GHRepository.java:1075)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:160)
Caused: org.jenkinsci.plugins.github.common.CombineErrorHandler$ErrorHandlingException
	at org.jenkinsci.plugins.github.common.CombineErrorHandler.handle(CombineErrorHandler.java:74)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:164)
	at com.cloudbees.jenkins.GitHubCommitNotifier.perform(GitHubCommitNotifier.java:151)
	at hudson.tasks.BuildStepCompatibilityLayer.perform(BuildStepCompatibilityLayer.java:81)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:744)
	at hudson.model.AbstractBuild$AbstractBuildExecution.performAllBuildSteps(AbstractBuild.java:690)
	at hudson.model.Build$BuildExecution.post2(Build.java:186)
	at hudson.model.AbstractBuild$AbstractBuildExecution.post(AbstractBuild.java:635)
	at hudson.model.Run.execute(Run.java:1749)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
Build step 'Set build status on GitHub commit [deprecated]' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1565

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam1 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 60f90c8dcb229c35a82c7be15e64a89678bae058 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 60f90c8dcb229c35a82c7be15e64a89678bae058
Commit message: "Make experiments as set attr of RuntimeValueProvider"
 > git rev-list --no-walk 60f90c8dcb229c35a82c7be15e64a89678bae058 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins498393289354643987.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
[Set GitHub commit status (universal)] ERROR on repos [GHRepository@bc39576[description=Apache Beam,homepage=,name=beam,fork=false,size=58754,milestones={},language=Java,commits={},source=<null>,parent=<null>,responseHeaderFields={null=[HTTP/1.1 200 OK], Access-Control-Allow-Origin=[*], Access-Control-Expose-Headers=[ETag, Link, Retry-After, X-GitHub-OTP, X-RateLimit-Limit, X-RateLimit-Remaining, X-RateLimit-Reset, X-OAuth-Scopes, X-Accepted-OAuth-Scopes, X-Poll-Interval], Cache-Control=[private, max-age=60, s-maxage=60], Content-Encoding=[gzip], Content-Security-Policy=[default-src 'none'], Content-Type=[application/json; charset=utf-8], Date=[Wed, 09 May 2018 03:00:11 GMT], ETag=[W/"f271032ca1513bfd5e28400c832a5d21"], Last-Modified=[Wed, 09 May 2018 00:26:13 GMT], OkHttp-Received-Millis=[1525834811571], OkHttp-Response-Source=[NETWORK 200], OkHttp-Selected-Protocol=[http/1.1], OkHttp-Sent-Millis=[1525834811417], Referrer-Policy=[origin-when-cross-origin, strict-origin-when-cross-origin], Server=[GitHub.com], Status=[200 OK], Strict-Transport-Security=[max-age=31536000; includeSubdomains; preload], Transfer-Encoding=[chunked], Vary=[Accept, Authorization, Cookie, X-GitHub-OTP], X-Accepted-OAuth-Scopes=[repo], X-Content-Type-Options=[nosniff], X-Frame-Options=[deny], X-GitHub-Media-Type=[github.v3; format=json], X-GitHub-Request-Id=[C80A:4F3F:613F65:E692C6:5AF26434], X-OAuth-Scopes=[admin:repo_hook, repo, repo:status], X-RateLimit-Limit=[5000], X-RateLimit-Remaining=[4985], X-RateLimit-Reset=[1525836570], X-Runtime-rack=[0.072147], X-XSS-Protection=[1; mode=block]},url=https://api.github.com/repos/apache/beam,id=50904245]] (sha:60f90c8) with context:beam_PostCommit_Python_ValidatesRunner_Dataflow
Setting commit status on GitHub for https://github.com/apache/beam/commit/60f90c8dcb229c35a82c7be15e64a89678bae058
ERROR: Build step failed with exception
java.io.FileNotFoundException: https://api.github.com/repos/apache/beam/statuses/60f90c8dcb229c35a82c7be15e64a89678bae058
	at com.squareup.okhttp.internal.huc.HttpURLConnectionImpl.getInputStream(HttpURLConnectionImpl.java:243)
	at com.squareup.okhttp.internal.huc.DelegatingHttpsURLConnection.getInputStream(DelegatingHttpsURLConnection.java:210)
	at com.squareup.okhttp.internal.huc.HttpsURLConnectionImpl.getInputStream(HttpsURLConnectionImpl.java:25)
	at org.kohsuke.github.Requester.parse(Requester.java:612)
	at org.kohsuke.github.Requester.parse(Requester.java:594)
	at org.kohsuke.github.Requester._to(Requester.java:272)
Caused: org.kohsuke.github.GHFileNotFoundException: {"message":"Not Found","documentation_url":"https://developer.github.com/v3/repos/statuses/#create-a-status"}
	at org.kohsuke.github.Requester.handleApiError(Requester.java:686)
	at org.kohsuke.github.Requester._to(Requester.java:293)
	at org.kohsuke.github.Requester.to(Requester.java:234)
	at org.kohsuke.github.GHRepository.createCommitStatus(GHRepository.java:1075)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:160)
Caused: org.jenkinsci.plugins.github.common.CombineErrorHandler$ErrorHandlingException
	at org.jenkinsci.plugins.github.common.CombineErrorHandler.handle(CombineErrorHandler.java:74)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:164)
	at com.cloudbees.jenkins.GitHubCommitNotifier.perform(GitHubCommitNotifier.java:151)
	at hudson.tasks.BuildStepCompatibilityLayer.perform(BuildStepCompatibilityLayer.java:81)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:744)
	at hudson.model.AbstractBuild$AbstractBuildExecution.performAllBuildSteps(AbstractBuild.java:690)
	at hudson.model.Build$BuildExecution.post2(Build.java:186)
	at hudson.model.AbstractBuild$AbstractBuildExecution.post(AbstractBuild.java:635)
	at hudson.model.Run.execute(Run.java:1749)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
Build step 'Set build status on GitHub commit [deprecated]' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1564

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

Changes:

[Pablo] Make experiments as set attr of RuntimeValueProvider

------------------------------------------
[...truncated 91.49 KB...]
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(some_fn) (tag odd): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/FlatMap(some_fn) (tag even): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Unkey (tag None): refcount: 1 => 0
root: DEBUG: Connecting using Google Application Default Credentials.
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-738898.1525825943.739107/pipeline.pb...
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-738898.1525825943.739107/pipeline.pb
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-738898.1525825943.739107/requirements.txt...
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-738898.1525825943.739107/requirements.txt
root: INFO: Executing command: ['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_flatten_multiple_pcollections_having_multiple_consumers (apache_beam.transforms.ptransform_test.PTransformTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py",> line 558, in test_flatten_multiple_pcollections_having_multiple_consumers
    pipeline.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 102, in run
    result = super(TestPipeline, self).run(test_runner_api)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 389, in run
    self.to_runner_api(), self.runner, self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 402, in run
    return self.runner.run_pipeline(self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 48, in run_pipeline
    self.result = super(TestDataflowRunner, self).run_pipeline(pipeline)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 363, in run_pipeline
    self.dataflow_client.create_job(self.job), self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/retry.py",> line 180, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 470, in create_job
    self.create_job_description(job)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 500, in create_job_description
    job.options, file_copy=self._gcs_file_copy)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 329, in stage_job_resources
    setup_options.requirements_file, requirements_cache_path)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 263, in _populate_requirements_cache
    processes.check_call(cmd_args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/processes.py",> line 44, in check_call
    return subprocess.check_call(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 541, in check_call
    raise CalledProcessError(retcode, cmd)
CalledProcessError: Command '['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']' returned non-zero exit status 2
-------------------- >> begin captured logging << --------------------
root: DEBUG: PValue computed by Start/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag even_length): refcount: 2 => 1
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag odd_length): refcount: 2 => 1
root: DEBUG: PValue computed by Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag even_length): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by Map(split_even_odd)/Map(split_even_odd) (tag odd_length): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Unkey (tag None): refcount: 1 => 0
root: DEBUG: Connecting using Google Application Default Credentials.
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-704742.1525825943.704942/pipeline.pb...
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-704742.1525825943.704942/pipeline.pb
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-704742.1525825943.704942/requirements.txt...
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-704742.1525825943.704942/requirements.txt
root: INFO: Executing command: ['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_par_do_with_multiple_outputs_and_using_yield (apache_beam.transforms.ptransform_test.PTransformTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/transforms/ptransform_test.py",> line 228, in test_par_do_with_multiple_outputs_and_using_yield
    pipeline.run()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/testing/test_pipeline.py",> line 102, in run
    result = super(TestPipeline, self).run(test_runner_api)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 389, in run
    self.to_runner_api(), self.runner, self._options).run(False)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/pipeline.py",> line 402, in run
    return self.runner.run_pipeline(self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/test_dataflow_runner.py",> line 48, in run_pipeline
    self.result = super(TestDataflowRunner, self).run_pipeline(pipeline)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_runner.py",> line 363, in run_pipeline
    self.dataflow_client.create_job(self.job), self)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/retry.py",> line 180, in wrapper
    return fun(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 470, in create_job
    self.create_job_description(job)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/apiclient.py",> line 500, in create_job_description
    job.options, file_copy=self._gcs_file_copy)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 329, in stage_job_resources
    setup_options.requirements_file, requirements_cache_path)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/runners/dataflow/internal/dependency.py",> line 263, in _populate_requirements_cache
    processes.check_call(cmd_args)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/apache_beam/utils/processes.py",> line 44, in check_call
    return subprocess.check_call(*args, **kwargs)
  File "/usr/lib/python2.7/subprocess.py", line 541, in check_call
    raise CalledProcessError(retcode, cmd)
CalledProcessError: Command '['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']' returned non-zero exit status 2
-------------------- >> begin captured logging << --------------------
root: DEBUG: PValue computed by Some Numbers/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/ParDo(SomeDoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert_that/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/ParDo(SomeDoFn) (tag odd): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:odd/Unkey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by ClassifyNumbers/ParDo(SomeDoFn) (tag even): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/WindowInto(WindowIntoFn) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Create/Read (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/ToVoidKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_0 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/pair_with_1 (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Flatten (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/GroupByKey (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Group/Map(_merge_tagged_vals_under_key) (tag None): refcount: 1 => 0
root: DEBUG: PValue computed by assert:even/Unkey (tag None): refcount: 1 => 0
root: DEBUG: Connecting using Google Application Default Credentials.
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-757095.1525825943.757287/pipeline.pb...
oauth2client.transport: INFO: Attempting refresh to obtain initial access_token
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-757095.1525825943.757287/pipeline.pb
root: INFO: Starting GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-757095.1525825943.757287/requirements.txt...
root: INFO: Completed GCS upload to gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/beamapp-jenkins-0509003223-757095.1525825943.757287/requirements.txt
root: INFO: Executing command: ['<https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/bin/python',> '-m', 'pip', 'download', '--dest', '/tmp/dataflow-requirements-cache', '-r', 'postcommit_requirements.txt', '--no-binary', ':all:']
--------------------- >> end captured logging << ---------------------

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 16 tests in 1561.399s

FAILED (errors=3)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_32_32-15822322837843841965?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_40_34-282908040513398590?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_47_17-11954336676085351356?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_32_38-14539586307123985404?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_39_25-12127952941172755442?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_46_48-15840005048165192114?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_32_31-6301225633507741523?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_38_48-16237874323110446290?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_45_10-11627838554213222784?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_51_57-11530157515128519318?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_32_30-6627087166021082570?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_39_57-16344967351026840266?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-08_17_47_19-9370401854144156660?project=apache-beam-testing.
Build step 'Execute shell' marked build as failure
[Set GitHub commit status (universal)] ERROR on repos [GHRepository@7a3b683d[description=Apache Beam,homepage=,name=beam,fork=false,size=58753,milestones={},language=Java,commits={},source=<null>,parent=<null>,responseHeaderFields={null=[HTTP/1.1 200 OK], Access-Control-Allow-Origin=[*], Access-Control-Expose-Headers=[ETag, Link, Retry-After, X-GitHub-OTP, X-RateLimit-Limit, X-RateLimit-Remaining, X-RateLimit-Reset, X-OAuth-Scopes, X-Accepted-OAuth-Scopes, X-Poll-Interval], Cache-Control=[private, max-age=60, s-maxage=60], Content-Encoding=[gzip], Content-Security-Policy=[default-src 'none'], Content-Type=[application/json; charset=utf-8], Date=[Wed, 09 May 2018 00:58:24 GMT], ETag=[W/"a78804f2fd4af0457a68fcd00bcae057"], Last-Modified=[Wed, 09 May 2018 00:26:13 GMT], OkHttp-Received-Millis=[1525827504632], OkHttp-Response-Source=[NETWORK 200], OkHttp-Selected-Protocol=[http/1.1], OkHttp-Sent-Millis=[1525827504495], Referrer-Policy=[origin-when-cross-origin, strict-origin-when-cross-origin], Server=[GitHub.com], Status=[200 OK], Strict-Transport-Security=[max-age=31536000; includeSubdomains; preload], Transfer-Encoding=[chunked], Vary=[Accept, Authorization, Cookie, X-GitHub-OTP], X-Accepted-OAuth-Scopes=[repo], X-Content-Type-Options=[nosniff], X-Frame-Options=[deny], X-GitHub-Media-Type=[github.v3; format=json], X-GitHub-Request-Id=[B980:4F40:882B9D:126EB5A:5AF2479C], X-OAuth-Scopes=[admin:repo_hook, repo, repo:status], X-RateLimit-Limit=[5000], X-RateLimit-Remaining=[4957], X-RateLimit-Reset=[1525828827], X-Runtime-rack=[0.051503], X-XSS-Protection=[1; mode=block]},url=https://api.github.com/repos/apache/beam,id=50904245]] (sha:60f90c8) with context:beam_PostCommit_Python_ValidatesRunner_Dataflow
Setting commit status on GitHub for https://github.com/apache/beam/commit/60f90c8dcb229c35a82c7be15e64a89678bae058
ERROR: Build step failed with exception
java.io.FileNotFoundException: https://api.github.com/repos/apache/beam/statuses/60f90c8dcb229c35a82c7be15e64a89678bae058
	at com.squareup.okhttp.internal.huc.HttpURLConnectionImpl.getInputStream(HttpURLConnectionImpl.java:243)
	at com.squareup.okhttp.internal.huc.DelegatingHttpsURLConnection.getInputStream(DelegatingHttpsURLConnection.java:210)
	at com.squareup.okhttp.internal.huc.HttpsURLConnectionImpl.getInputStream(HttpsURLConnectionImpl.java:25)
	at org.kohsuke.github.Requester.parse(Requester.java:612)
	at org.kohsuke.github.Requester.parse(Requester.java:594)
	at org.kohsuke.github.Requester._to(Requester.java:272)
Caused: org.kohsuke.github.GHFileNotFoundException: {"message":"Not Found","documentation_url":"https://developer.github.com/v3/repos/statuses/#create-a-status"}
	at org.kohsuke.github.Requester.handleApiError(Requester.java:686)
	at org.kohsuke.github.Requester._to(Requester.java:293)
	at org.kohsuke.github.Requester.to(Requester.java:234)
	at org.kohsuke.github.GHRepository.createCommitStatus(GHRepository.java:1075)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:160)
Caused: org.jenkinsci.plugins.github.common.CombineErrorHandler$ErrorHandlingException
	at org.jenkinsci.plugins.github.common.CombineErrorHandler.handle(CombineErrorHandler.java:74)
	at org.jenkinsci.plugins.github.status.GitHubCommitStatusSetter.perform(GitHubCommitStatusSetter.java:164)
	at com.cloudbees.jenkins.GitHubCommitNotifier.perform(GitHubCommitNotifier.java:151)
	at hudson.tasks.BuildStepCompatibilityLayer.perform(BuildStepCompatibilityLayer.java:81)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:744)
	at hudson.model.AbstractBuild$AbstractBuildExecution.performAllBuildSteps(AbstractBuild.java:690)
	at hudson.model.Build$BuildExecution.post2(Build.java:186)
	at hudson.model.AbstractBuild$AbstractBuildExecution.post(AbstractBuild.java:635)
	at hudson.model.Run.execute(Run.java:1749)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
Build step 'Set build status on GitHub commit [deprecated]' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1563

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

Changes:

[tgroh] Migrate the `portable` subpackage to Portability

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 7848764a070b3bcd02528014838792b88c5ea2e4 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 7848764a070b3bcd02528014838792b88c5ea2e4
Commit message: "Merge pull request #5270: Migrate the `portable` subpackage to use Portable representations"
 > git rev-list --no-walk e7a3578abb919021be95c9c7148fd2d4fc6331fd # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6501802628843931600.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1562

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision e7a3578abb919021be95c9c7148fd2d4fc6331fd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f e7a3578abb919021be95c9c7148fd2d4fc6331fd
Commit message: "Merge pull request #4264: [BEAM-4061] Introduced SpannerWriteResult"
 > git rev-list --no-walk e7a3578abb919021be95c9c7148fd2d4fc6331fd # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins927005579096213696.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1561

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

Changes:

[mairbek] Introduced SpannerWriteResult that

[mairbek] Addressed comments

[mairbek] Happy checkstyle

------------------------------------------
Started by GitHub push by jkff
[EnvInject] - Loading node environment variables.
Building remotely on beam6 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision e7a3578abb919021be95c9c7148fd2d4fc6331fd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f e7a3578abb919021be95c9c7148fd2d4fc6331fd
Commit message: "Merge pull request #4264: [BEAM-4061] Introduced SpannerWriteResult"
 > git rev-list --no-walk 4a9b82625b3242f7561ac4a0b92bb075ecc0cd84 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3959255492282716597.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1560

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

Changes:

[apilloud] Enable githubCommitNotifier for post commits

------------------------------------------
Started by GitHub push by jasonkuster
[EnvInject] - Loading node environment variables.
Building remotely on beam6 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 4a9b82625b3242f7561ac4a0b92bb075ecc0cd84 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 4a9b82625b3242f7561ac4a0b92bb075ecc0cd84
Commit message: "Merge pull request #5305: Enable githubCommitNotifier for post commits"
 > git rev-list --no-walk 08c91f6e80cae7f322a243e547f971743563fac2 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins9031397058745956926.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1559

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

Changes:

[github] Adding a microbenchmark for side input iterables. (#5294)

------------------------------------------
Started by GitHub push by pabloem
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 08c91f6e80cae7f322a243e547f971743563fac2 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 08c91f6e80cae7f322a243e547f971743563fac2
Commit message: "Adding a microbenchmark for side input iterables. (#5294)"
 > git rev-list --no-walk aaf5db884b8f93151827bb2e137923eabb036e61 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6461448280708481026.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1558

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

Changes:

[github] Explictly delcare globals defined elsewhere

------------------------------------------
Started by GitHub push by aaltay
[EnvInject] - Loading node environment variables.
Building remotely on beam6 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision aaf5db884b8f93151827bb2e137923eabb036e61 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f aaf5db884b8f93151827bb2e137923eabb036e61
Commit message: "Merge pull request #5210 from cclauss/patch-1"
 > git rev-list --no-walk cd92c5e2edd275c377793532ac65b07fb571590d # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8599489169184529238.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1557

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

Changes:

[swegner] Create ValidatesRunner task for DirectRunner.

[swegner] Convert some tests from ValidatesRunner -> NeedsRunner

------------------------------------------
Started by GitHub push by kennknowles
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision cd92c5e2edd275c377793532ac65b07fb571590d (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f cd92c5e2edd275c377793532ac65b07fb571590d
Commit message: "Merge pull request #5193: [BEAM-4059] Reduce number of ValidatesRunner tests and reorganize them for better parallelization"
 > git rev-list --no-walk 10869d234fc57c833dd23c99a2b8a96171530356 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6499575403368619828.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1556

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

Changes:

[wcn] Fix missing return in datastore connector.

------------------------------------------
Started by GitHub push by jasonkuster
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 10869d234fc57c833dd23c99a2b8a96171530356 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 10869d234fc57c833dd23c99a2b8a96171530356
Commit message: "Merge pull request #5245: Fix missing return in datastore connector."
 > git rev-list --no-walk 4c1e2feabbf48714ff78cda965186c11ab4a4434 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins5941523308160343987.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1555

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

Changes:

[tgroh] Suppress Thread Leak Test

[tgroh] Rename ExecutorServiceParlallelExecutorTest#test

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 4c1e2feabbf48714ff78cda965186c11ab4a4434 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 4c1e2feabbf48714ff78cda965186c11ab4a4434
Commit message: "Merge pull request #5300: Suppress a test in ExecutorServiceParallelExecutorTest"
 > git rev-list --no-walk d9215f17c1d2ad55a14d2f598773d7bbe1b57034 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins2975297387125321569.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1554

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision d9215f17c1d2ad55a14d2f598773d7bbe1b57034 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f d9215f17c1d2ad55a14d2f598773d7bbe1b57034
Commit message: "Merge pull request #5227: [BEAM-4172] Move textio.FileSystem and its registry to a separate package"
 > git rev-list --no-walk d9215f17c1d2ad55a14d2f598773d7bbe1b57034 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins5918767081893159402.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1553

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

Changes:

[schroederc] Move textio.FileSystem and its registry to a separate package

[schroederc] Move filesystem implementations under beam/io/filesystem package

------------------------------------------
Started by GitHub push by kennknowles
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision d9215f17c1d2ad55a14d2f598773d7bbe1b57034 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f d9215f17c1d2ad55a14d2f598773d7bbe1b57034
Commit message: "Merge pull request #5227: [BEAM-4172] Move textio.FileSystem and its registry to a separate package"
 > git rev-list --no-walk 378ca9468bbc4a2404e55f5eacee56742fdd437a # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins2818463310022009554.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user schroederc@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1552

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

Changes:

[apilloud] [SQL] Cleanout unneeded sqlEnv

[apilloud] [SQL] Hide details of BeamSqlEnv from rel test

[apilloud] [SQL] Simplify TableProvider interface

[apilloud] [SQL] Return map from TableProvider.getTables

[apilloud] [SQL] Add tables via TableStore in CalciteSchema

[apilloud] [SQL] Move Create and Drop Table inline with ddl

------------------------------------------
Started by GitHub push by kennknowles
[EnvInject] - Loading node environment variables.
Building remotely on beam12 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 378ca9468bbc4a2404e55f5eacee56742fdd437a (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 378ca9468bbc4a2404e55f5eacee56742fdd437a
Commit message: "Merge pull request #5224: [BEAM-4044] [SQL] Add tables via TableStore in Schema, execute DDL in Calcite model"
 > git rev-list --no-walk c8b449ae0fc9bdf7defc9dc63e46a5b54bf33ddf # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins27472659800353050.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1551

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision c8b449ae0fc9bdf7defc9dc63e46a5b54bf33ddf (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f c8b449ae0fc9bdf7defc9dc63e46a5b54bf33ddf
Commit message: "Merge pull request #5284: Change to docstring in filesystem.py"
 > git rev-list --no-walk c8b449ae0fc9bdf7defc9dc63e46a5b54bf33ddf # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins548666712644806554.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1550

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

Changes:

[daniel.o.programmer] Change to docstring in filesystem.py

------------------------------------------
Started by GitHub push by chamikaramj
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision c8b449ae0fc9bdf7defc9dc63e46a5b54bf33ddf (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f c8b449ae0fc9bdf7defc9dc63e46a5b54bf33ddf
Commit message: "Merge pull request #5284: Change to docstring in filesystem.py"
 > git rev-list --no-walk 29e01115075bcd3957ceef60039307e39e007b99 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8492360262162692644.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user daniel.o.programmer@gmail.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1549

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 29e01115075bcd3957ceef60039307e39e007b99 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 29e01115075bcd3957ceef60039307e39e007b99
Commit message: "Moving Python PostCommit into a Gradle task. (#5289)"
 > git rev-list --no-walk 29e01115075bcd3957ceef60039307e39e007b99 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3560050606994174773.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1548

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

Changes:

[github] Moving Python PostCommit into a Gradle task. (#5289)

------------------------------------------
Started by GitHub push by pabloem
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 29e01115075bcd3957ceef60039307e39e007b99 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 29e01115075bcd3957ceef60039307e39e007b99
Commit message: "Moving Python PostCommit into a Gradle task. (#5289)"
 > git rev-list --no-walk 3d9259017bf9752e7e14a704881b2eed54c9a80b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6278708592207138185.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1547

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

Changes:

[thw] [BEAM-4246] Remove Maven build directory dependency in Apex runner.

[thw] Upgrade Apex version to 3.7.0 to get rid of poisened netlet 1.3.0

------------------------------------------
Started by GitHub push by iemejia
[EnvInject] - Loading node environment variables.
Building remotely on beam14 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 3d9259017bf9752e7e14a704881b2eed54c9a80b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 3d9259017bf9752e7e14a704881b2eed54c9a80b
Commit message: "Merge pull request #5288: [BEAM-4246] Remove Maven build directory dependency in Apex runner"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3091147380443077516.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1546

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins2659333524156016309.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1545

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1451832638972681468.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1544

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8651099528579246607.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1543

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1108828133529295848.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1542

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins4241691558978189411.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1541

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3932739077274198830.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1540

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins2630059670076883697.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1539

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3000260407774743136.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1538

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins5157448002019872885.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1537

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8674548663927648099.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1536

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3587963657441481339.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1535

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

Changes:

[apilloud] Revert "Merge pull request #5220: [BEAM-3983][SQL] Add BigQuery table

[apilloud] Revert "Merge pull request #4947: [BEAM-3983] Add utils for converting

------------------------------------------
Started by GitHub push by chamikaramj
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 0e1dcccf2fbc3737c72cd52fd3eb2018b586c85c
Commit message: "Merge pull request #5286: [BEAM-4229] Revert BigQuery SQL support so Spanner works"
 > git rev-list --no-walk 21e11f2e22767a9951c9bb35cbb9df2147291aa5 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8349731066978967876.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1534

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 21e11f2e22767a9951c9bb35cbb9df2147291aa5 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 21e11f2e22767a9951c9bb35cbb9df2147291aa5
Commit message: "Combine nested if statements"
 > git rev-list --no-walk 21e11f2e22767a9951c9bb35cbb9df2147291aa5 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins4217079143430745009.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1533

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

Changes:

[coheigea] Combine nested if statements

------------------------------------------
Started by GitHub push by lukecwik
[EnvInject] - Loading node environment variables.
Building remotely on beam14 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 21e11f2e22767a9951c9bb35cbb9df2147291aa5 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 21e11f2e22767a9951c9bb35cbb9df2147291aa5
Commit message: "Combine nested if statements"
 > git rev-list --no-walk 88d1cdcaf08727d83cda24502e6d0e8129bdab2e # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins638656759279430511.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1532

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

Changes:

[mariagh] Update CoGroupByKey docstring

------------------------------------------
Started by GitHub push by aaltay
[EnvInject] - Loading node environment variables.
Building remotely on beam14 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 88d1cdcaf08727d83cda24502e6d0e8129bdab2e (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 88d1cdcaf08727d83cda24502e6d0e8129bdab2e
Commit message: "Merge pull request #5266 from mariapython/docstring"
 > git rev-list --no-walk 90ba47114997e75a3a7daa1e8db92768d05e5432 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins2116008576206615532.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1531

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

Changes:

[sidhom] Use wildcard generics rather than Object in portable translator

[sidhom] [BEAM-4231] Runner utility for coder instantiation

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 90ba47114997e75a3a7daa1e8db92768d05e5432 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 90ba47114997e75a3a7daa1e8db92768d05e5432
Commit message: "Merge pull request #5274: Runner utility for coder instantiation"
 > git rev-list --no-walk d9c0f8ba82ec97be0cfa383ea130262169256fd9 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6629397999613075196.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1530

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

Changes:

[swegner] Remove Gradle worker cap.

[swegner] Re-enable additional Jenkins worker parallelism for Dataflow

[swegner] Adjust Jenkins Gradle memory usage based on max-workers

[swegner] Hard-code jenkins machines total memory until we find a working API

------------------------------------------
Started by GitHub push by lukecwik
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision d9c0f8ba82ec97be0cfa383ea130262169256fd9 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f d9c0f8ba82ec97be0cfa383ea130262169256fd9
Commit message: "Remove Gradle worker cap."
 > git rev-list --no-walk 684fb9f974e1b007544d6e9d57fcf99be355e99e # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8352045528141771988.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1529

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 684fb9f974e1b007544d6e9d57fcf99be355e99e (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 684fb9f974e1b007544d6e9d57fcf99be355e99e
Commit message: "Merge pull request #5278 from iemejia/improve-metricssink"
 > git rev-list --no-walk 684fb9f974e1b007544d6e9d57fcf99be355e99e # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3684501283561767748.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1528

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 684fb9f974e1b007544d6e9d57fcf99be355e99e (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 684fb9f974e1b007544d6e9d57fcf99be355e99e
Commit message: "Merge pull request #5278 from iemejia/improve-metricssink"
 > git rev-list --no-walk 684fb9f974e1b007544d6e9d57fcf99be355e99e # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins5518154928885591481.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1527

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

Changes:

[iemejia] Make MetricsHttpSinkTest more concise and fix typo

------------------------------------------
Started by GitHub push by echauchot
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 684fb9f974e1b007544d6e9d57fcf99be355e99e (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 684fb9f974e1b007544d6e9d57fcf99be355e99e
Commit message: "Merge pull request #5278 from iemejia/improve-metricssink"
 > git rev-list --no-walk 8ef71b6eb1d2d5c63974ec506a01faf3813efe74 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6042524323256456730.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1526

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

Changes:

[apilloud] [SQL] Use the same javacc and fmpp as calcite

[apilloud] [SQL] BeamQueryPlanner uses BeamSqlParserImpl

------------------------------------------
Started by GitHub push by kennknowles
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 8ef71b6eb1d2d5c63974ec506a01faf3813efe74 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 8ef71b6eb1d2d5c63974ec506a01faf3813efe74
Commit message: "Merge pull request #5275: [BEAM-4233] [SQL] Use the same javacc and fmpp as calcite"
 > git rev-list --no-walk 86fdb74fd7cbc016065cfe6dea530155051a6f39 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins329871054207621139.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1525

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 86fdb74fd7cbc016065cfe6dea530155051a6f39 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 86fdb74fd7cbc016065cfe6dea530155051a6f39
Commit message: "Merge pull request #5269: Add an Unsupported StateRequestHandler"
 > git rev-list --no-walk 86fdb74fd7cbc016065cfe6dea530155051a6f39 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins4711700608973881502.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1524

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

Changes:

[tgroh] Add an Unsupported StateRequestHandler

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 86fdb74fd7cbc016065cfe6dea530155051a6f39 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 86fdb74fd7cbc016065cfe6dea530155051a6f39
Commit message: "Merge pull request #5269: Add an Unsupported StateRequestHandler"
 > git rev-list --no-walk bf94e36f67a8bc5d24c795e40697ad2504c8594c # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins2333355961844494983.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1523

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

Changes:

[apilloud] [SQL] Add BeamEnumerableConverter

------------------------------------------
Started by GitHub push by kennknowles
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision bf94e36f67a8bc5d24c795e40697ad2504c8594c (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bf94e36f67a8bc5d24c795e40697ad2504c8594c
Commit message: "Merge pull request #5173: [BEAM-3773][SQL] Add EnumerableConverter for JDBC support"
 > git rev-list --no-walk 4971e7ec48ad85d002a1c7596cb436dc8c8e88ea # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1870420410302368017.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1522

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

Changes:

[tgroh] Add additional methods to QueryablePipeline

[tgroh] Expand the ExecutableGraph interface

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam17 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 4971e7ec48ad85d002a1c7596cb436dc8c8e88ea (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 4971e7ec48ad85d002a1c7596cb436dc8c8e88ea
Commit message: "Merge pull request #5228: Expand ExecutableGraph, and add a Portable Representation"
 > git rev-list --no-walk 184b4a600e49873c015f1c72cd04e65196210fb1 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3121169963595458885.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1521

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

Changes:

[tgroh] Add ProtoOverrides

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam17 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 184b4a600e49873c015f1c72cd04e65196210fb1 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 184b4a600e49873c015f1c72cd04e65196210fb1
Commit message: "Merge pull request #5172: Add ProtoOverrides"
 > git rev-list --no-walk b6dadffb3c35648839909790de3a070fb6c34127 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins2575969427361887179.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1520

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

Changes:

[jasonkuster] Add labels to Go SDK Dataflow Runner.

[jasonkuster] Add verbose error message if unmarshaling fails for label flag.

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision b6dadffb3c35648839909790de3a070fb6c34127 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f b6dadffb3c35648839909790de3a070fb6c34127
Commit message: "Merge pull request #5272: Add labels flag to Go SDK Dataflow Runner."
 > git rev-list --no-walk 5cb3969b53ce7fecb33b347c7113602957f5ee9f # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins5918516035352385300.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1519

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

Changes:

[sidhom] Move SyntheticNodes to top-level construction package and rename

[sidhom] Pull Flink execution environment utilities into static methods

[sidhom] Refactor Runner/SDK wire coder creation into a shared utility

[sidhom] [BEAM-3972] Translate portable batch pipelines by proto

[sidhom] FIXUP: Use ModelCoders to create proto coders and use WireCoders to

[sidhom] FIXUP: Use RunnerApi in WireCoders to prepare for coder instantiation

------------------------------------------
Started by GitHub push by jkff
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 5cb3969b53ce7fecb33b347c7113602957f5ee9f (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 5cb3969b53ce7fecb33b347c7113602957f5ee9f
Commit message: "Merge pull request #5226: [BEAM-3972] Translate portable batch pipelines by proto"
 > git rev-list --no-walk ca4e28484eac3911f03159fd5602f3290fad1e71 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins5555458823943787584.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1518

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision ca4e28484eac3911f03159fd5602f3290fad1e71 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f ca4e28484eac3911f03159fd5602f3290fad1e71
Commit message: "A few small fixes to catch a few regressions - put String literals fi…"
 > git rev-list --no-walk ca4e28484eac3911f03159fd5602f3290fad1e71 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins7543009452845685142.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1517

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

Changes:

[coheigea] A few small fixes to catch a few regressions - put String literals

------------------------------------------
Started by GitHub push by lukecwik
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision ca4e28484eac3911f03159fd5602f3290fad1e71 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f ca4e28484eac3911f03159fd5602f3290fad1e71
Commit message: "A few small fixes to catch a few regressions - put String literals fi…"
 > git rev-list --no-walk fe7717da7bbf04b2f58a4c09a1b79225f85b33a7 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1388054051810542423.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1516

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

Changes:

[mairbek] Templatize host name in SpannerIO

------------------------------------------
Started by GitHub push by jkff
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision fe7717da7bbf04b2f58a4c09a1b79225f85b33a7 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f fe7717da7bbf04b2f58a4c09a1b79225f85b33a7
Commit message: "Merge pull request #5265: Templatize host name in SpannerIO"
 > git rev-list --no-walk 797908421efa94bb1cedf2a96a435f877c27e98b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins9201512649221847527.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1515

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 797908421efa94bb1cedf2a96a435f877c27e98b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 797908421efa94bb1cedf2a96a435f877c27e98b
Commit message: "Merge pull request #5203 from echauchot/BEAM-4138-MetricsHttpSink-committed-fix"
 > git rev-list --no-walk 797908421efa94bb1cedf2a96a435f877c27e98b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins5282135851343081208.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1514

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 797908421efa94bb1cedf2a96a435f877c27e98b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 797908421efa94bb1cedf2a96a435f877c27e98b
Commit message: "Merge pull request #5203 from echauchot/BEAM-4138-MetricsHttpSink-committed-fix"
 > git rev-list --no-walk 797908421efa94bb1cedf2a96a435f877c27e98b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8186499648580138273.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1513

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

Changes:

[echauchot] [BEAM-4138] Support runners that do not support committed metrics in

------------------------------------------
Started by GitHub push by jbonofre
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 797908421efa94bb1cedf2a96a435f877c27e98b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 797908421efa94bb1cedf2a96a435f877c27e98b
Commit message: "Merge pull request #5203 from echauchot/BEAM-4138-MetricsHttpSink-committed-fix"
 > git rev-list --no-walk e0567246354defdef3abc0b41feb8d846fa647b0 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1062572814761554771.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1512

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision e0567246354defdef3abc0b41feb8d846fa647b0 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f e0567246354defdef3abc0b41feb8d846fa647b0
Commit message: "Merge pull request #5234: Add KV and Window Coder Utilities to ModelCoders"
 > git rev-list --no-walk e0567246354defdef3abc0b41feb8d846fa647b0 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins4626257764703174276.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user mairbek@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1511

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

Changes:

[tgroh] Add KV and Window Coder Utilities to ModelCoders

[tgroh] Use ModelCoders in ProcessBundleDescriptors

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision e0567246354defdef3abc0b41feb8d846fa647b0 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f e0567246354defdef3abc0b41feb8d846fa647b0
Commit message: "Merge pull request #5234: Add KV and Window Coder Utilities to ModelCoders"
 > git rev-list --no-walk 04b8b44d96b457501df7b6f30280f267a4825a3b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1257674018655684362.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user mairbek@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1510

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

Changes:

[sidhom] Remove StateRequestHandler from JobBundleFactory

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 04b8b44d96b457501df7b6f30280f267a4825a3b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 04b8b44d96b457501df7b6f30280f267a4825a3b
Commit message: "Merge pull request #5263: Remove StateRequestHandler from JobBundleFactory"
 > git rev-list --no-walk 6ac67f75eceb54ebe9990bc77f93c09902c28e00 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1973148569305293894.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user mairbek@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1509

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

Changes:

[mairbek] Wait for input collection

[mairbek] Expose DatabaseAdminClient

[mairbek] Consistently use lower case table name and column names

[mairbek] Addressed comments

------------------------------------------
Started by GitHub push by jkff
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 6ac67f75eceb54ebe9990bc77f93c09902c28e00 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 6ac67f75eceb54ebe9990bc77f93c09902c28e00
Commit message: "Merge pull request #5259: SpannerIO fixes"
 > git rev-list --no-walk 48f9cce76cf87ffe7073c3ad9c34a9f2f6de4b76 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6040247814120990170.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user mairbek@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1508

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 48f9cce76cf87ffe7073c3ad9c34a9f2f6de4b76 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 48f9cce76cf87ffe7073c3ad9c34a9f2f6de4b76
Commit message: "Merge pull request #5152: Harness Manager Interfaces"
 > git rev-list --no-walk 48f9cce76cf87ffe7073c3ad9c34a9f2f6de4b76 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8204356684901283737.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1507

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

Changes:

[axelmagn] Create ArtifactSource Interface

[axelmagn] Create RemoteBundle interface

[axelmagn] Create JobInfo for job declaration by operators.

[axelmagn] Create BundleFactory chain.

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 48f9cce76cf87ffe7073c3ad9c34a9f2f6de4b76 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 48f9cce76cf87ffe7073c3ad9c34a9f2f6de4b76
Commit message: "Merge pull request #5152: Harness Manager Interfaces"
 > git rev-list --no-walk d19c3665a41978b6bdf3330dacc4ff4e8404fd79 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6324569358630667435.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1506

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

Changes:

[tgroh] Remove unused Test Utilities, Test

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam10 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision d19c3665a41978b6bdf3330dacc4ff4e8404fd79 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f d19c3665a41978b6bdf3330dacc4ff4e8404fd79
Commit message: "Merge pull request #5236"
 > git rev-list --no-walk 971f1f11d09af8545b17eb23da3d3fd4a80055a2 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins5454284561726038269.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1505

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

Changes:

[github] Fix DynamicDestinations documentation

------------------------------------------
Started by GitHub push by lukecwik
[EnvInject] - Loading node environment variables.
Building remotely on beam17 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 971f1f11d09af8545b17eb23da3d3fd4a80055a2 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 971f1f11d09af8545b17eb23da3d3fd4a80055a2
Commit message: "Fix DynamicDestinations documentation"
 > git rev-list --no-walk 69293a7c5a75187f38ead3ae9ef69b867ee62993 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6839563411572941403.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1504

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

Changes:

[github] Count compressed records with a long to avoid overflow

------------------------------------------
Started by GitHub push by lukecwik
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 69293a7c5a75187f38ead3ae9ef69b867ee62993 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 69293a7c5a75187f38ead3ae9ef69b867ee62993
Commit message: "Count compressed records with a long to avoid overflow"
 > git rev-list --no-walk 22615a1e6f8de72de24a77a50630ee0b31613c22 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6439667355959778562.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1503

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

Changes:

[alan] [BEAM-4218] Fix failing javadoc build

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 22615a1e6f8de72de24a77a50630ee0b31613c22 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 22615a1e6f8de72de24a77a50630ee0b31613c22
Commit message: "Merge pull request #5255: Fix failing javadoc build"
 > git rev-list --no-walk 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins3737713689862312226.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1502

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc
Commit message: "Merge pull request #5256: [BEAM-4224] Update perf.go: only trigger on processing bundles"
 > git rev-list --no-walk 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins9104837862657157993.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1501

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc
Commit message: "Merge pull request #5256: [BEAM-4224] Update perf.go: only trigger on processing bundles"
 > git rev-list --no-walk 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins9100031579441435845.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1500

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc
Commit message: "Merge pull request #5256: [BEAM-4224] Update perf.go: only trigger on processing bundles"
 > git rev-list --no-walk 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1379642106171810999.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1499

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

Changes:

[github] Update perf.go: only trigger on processing bundles

------------------------------------------
Started by GitHub push by jasonkuster
[EnvInject] - Loading node environment variables.
Building remotely on beam17 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 5e995f78ffcbde61d61bcfcd662ec41f2218dbbc
Commit message: "Merge pull request #5256: [BEAM-4224] Update perf.go: only trigger on processing bundles"
 > git rev-list --no-walk a08e6b098c9c43706eb26f3b716187d02583cffc # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins1659635526747409312.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1498

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

Changes:

[kirpichov] [BEAM-4144] Fixes SplittableParDoProcessFnTest

------------------------------------------
Started by GitHub push by jkff
[EnvInject] - Loading node environment variables.
Building remotely on beam12 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision a08e6b098c9c43706eb26f3b716187d02583cffc (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f a08e6b098c9c43706eb26f3b716187d02583cffc
Commit message: "Merge pull request #5250: [BEAM-4144] Fixes SplittableParDoProcessFnTest"
 > git rev-list --no-walk 643e3da528b7147c1e56023ac4868ad254c6cdaf # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins7920234033739728246.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1497

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

Changes:

[swegner] Findbugs cleanup; no functional changes

------------------------------------------
Started by GitHub push by tgroh
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 643e3da528b7147c1e56023ac4868ad254c6cdaf (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 643e3da528b7147c1e56023ac4868ad254c6cdaf
Commit message: "Merge pull request #5186: Findbugs cleanup; no functional changes"
 > git rev-list --no-walk a0036d5ab77be31ed090b3338faf2b32784399e0 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins2205417746886848989.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1496

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

Changes:

[github] [BEAM-3042] Refactor of TransformIOCounters (performance, inheritance).

------------------------------------------
Started by GitHub push by pabloem
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision a0036d5ab77be31ed090b3338faf2b32784399e0 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f a0036d5ab77be31ed090b3338faf2b32784399e0
Commit message: "[BEAM-3042] Refactor of TransformIOCounters (performance, inheritance). (#5075)"
 > git rev-list --no-walk 92fd475afca09da7da1224775342bd668b53d83a # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins2566173868859748733.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1495

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

Changes:

[Pablo] Add documentaton for quickstart tasks

------------------------------------------
Started by GitHub push by pabloem
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 92fd475afca09da7da1224775342bd668b53d83a (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 92fd475afca09da7da1224775342bd668b53d83a
Commit message: "Add documentaton for quickstart tasks"
 > git rev-list --no-walk d5b0316060c29581291a8e12058bb4ca2677f92b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins8566716041729701139.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1494

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

Changes:

[tgroh] Mark some ReduceFnRunner arguments Nullable

------------------------------------------
Started by GitHub push by tgroh
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision d5b0316060c29581291a8e12058bb4ca2677f92b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f d5b0316060c29581291a8e12058bb4ca2677f92b
Commit message: "Merge pull request #5237: Mark some ReduceFnRunner arguments Nullable"
 > git rev-list --no-walk 96fb76560de44abcdcb915da543df7d45f6f6b3b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins7102162756890609619.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1493

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 96fb76560de44abcdcb915da543df7d45f6f6b3b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 96fb76560de44abcdcb915da543df7d45f6f6b3b
Commit message: "[BEAM-4131] Include SDK into Python SDK harness container."
 > git rev-list --no-walk 96fb76560de44abcdcb915da543df7d45f6f6b3b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6091071962498451368.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1492

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 96fb76560de44abcdcb915da543df7d45f6f6b3b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 96fb76560de44abcdcb915da543df7d45f6f6b3b
Commit message: "[BEAM-4131] Include SDK into Python SDK harness container."
 > git rev-list --no-walk 96fb76560de44abcdcb915da543df7d45f6f6b3b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins6175827015196876227.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1491

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

------------------------------------------
Started by timer
[EnvInject] - Loading node environment variables.
Building remotely on beam23 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 96fb76560de44abcdcb915da543df7d45f6f6b3b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 96fb76560de44abcdcb915da543df7d45f6f6b3b
Commit message: "[BEAM-4131] Include SDK into Python SDK harness container."
 > git rev-list --no-walk 96fb76560de44abcdcb915da543df7d45f6f6b3b # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins7006540491596391202.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com

Build failed in Jenkins: beam_PostCommit_Python_ValidatesRunner_Dataflow #1490

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

Changes:

[thw] [BEAM-4131] Include SDK into Python SDK harness container.

[thw] cleanup

------------------------------------------
Started by GitHub push by lukecwik
[EnvInject] - Loading node environment variables.
Building remotely on beam17 (beam) in workspace <https://builds.apache.org/job/beam_PostCommit_Python_ValidatesRunner_Dataflow/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/*
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 96fb76560de44abcdcb915da543df7d45f6f6b3b (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 96fb76560de44abcdcb915da543df7d45f6f6b3b
Commit message: "[BEAM-4131] Include SDK into Python SDK harness container."
 > git rev-list --no-walk 9d75d06643f0d443ede4d172cca2c5d8b3c5ef65 # timeout=10
Cleaning workspace
 > git rev-parse --verify HEAD # timeout=10
Resetting working tree
 > git reset --hard # timeout=10
 > git clean -fdx # timeout=10
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1

[EnvInject] - Variables injected successfully.
[beam_PostCommit_Python_ValidatesRunner_Dataflow] $ /bin/bash -xe /tmp/jenkins710507666038311248.sh
+ cd src
+ bash sdks/python/run_validatesrunner.sh

# pip install --user installation location.
LOCAL_PATH=$HOME/.local/bin/

# INFRA does not install virtualenv
pip install virtualenv --user
Requirement already satisfied: virtualenv in /usr/lib/python2.7/dist-packages (15.0.1)

# Virtualenv for the rest of the script to run setup & e2e tests
${LOCAL_PATH}/virtualenv sdks/python
sdks/python/run_validatesrunner.sh: line 38: /home/jenkins/.local/bin//virtualenv: No such file or directory
Build step 'Execute shell' marked build as failure
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user kirpichov@google.com