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 2016/07/12 16:29:44 UTC

Build failed in Jenkins: beam_PostCommit_PythonVerify #72

See <https://builds.apache.org/job/beam_PostCommit_PythonVerify/72/changes>

Changes:

[robertwb] Pickle only used symbols from __main__ namespace.

------------------------------------------
[...truncated 1408 lines...]
hard linking apache_beam/transforms/trigger.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/trigger_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/util.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/window.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/window_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/write_ptransform_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/typehints/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/decorators.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/opcodes.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/trivial_inference.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/trivial_inference_test.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/typecheck.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/typed_pipeline_test.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/typehints.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/typehints_test.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/utils/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/counters.pxd -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/counters.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/dependency.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/dependency_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/names.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/options.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/path.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/path_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/pipeline_options_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/pipeline_options_validator.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/pipeline_options_validator_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/processes.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/processes_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/profiler.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/retry.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/retry_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam_sdk.egg-info/PKG-INFO -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/SOURCES.txt -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/dependency_links.txt -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/not-zip-safe -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/requires.txt -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/top_level.txt -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
copying setup.cfg -> apache-beam-sdk-0.3.0
Writing apache-beam-sdk-0.3.0/setup.cfg
Creating tar archive
removing 'apache-beam-sdk-0.3.0' (and everything under it)

# Run wordcount on the Google Cloud Dataflow service
python -m apache_beam.examples.wordcount \
--output $GCS_LOCATION/py-wordcount-cloud \
--staging_location $GCS_LOCATION/staging-wordcount \
--temp_location $GCS_LOCATION/temp-wordcount \
--runner BlockingDataflowPipelineRunner \
--job_name $JOBNAME \
--project $PROJECT \
--sdk_location dist/apache-beam-sdk-*.tar.gz \
--num_workers 1 >> job_output 2>&1 || true;

# Print full job output, validate correct, then remove it.
echo ">>> JOB OUTPUT FOLLOWS"
>>> JOB OUTPUT FOLLOWS
cat job_output
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(140578717938000, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(140528346898704, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(139876057866512, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(140310589935952, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(140410743091920, None)'

# Grep will exit with status 1 if success message was not found.
echo ">>> CHECKING JOB SUCCESS"
>>> CHECKING JOB SUCCESS
grep JOB_STATE_DONE job_output
Build step 'Execute shell' marked build as failure

Jenkins build is back to normal : beam_PostCommit_PythonVerify #75

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_PythonVerify/75/changes>


Build failed in Jenkins: beam_PostCommit_PythonVerify #74

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_PythonVerify/74/changes>

Changes:

[dhalperi] Remove more tests from nose tests exclusion list

------------------------------------------
[...truncated 1558 lines...]
hard linking apache_beam/examples/cookbook/coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/combiners_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/custom_ptransform.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/custom_ptransform_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/filters.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/filters_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/group_with_coder.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/group_with_coder_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/mergecontacts.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/mergecontacts_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/multiple_output_pardo.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/cookbook/multiple_output_pardo_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples/cookbook
hard linking apache_beam/examples/snippets/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/examples/snippets
hard linking apache_beam/examples/snippets/snippets.py -> apache-beam-sdk-0.3.0/apache_beam/examples/snippets
hard linking apache_beam/examples/snippets/snippets_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples/snippets
hard linking apache_beam/internal/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/apiclient.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/apiclient_test.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/auth.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/json_value.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/json_value_test.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/module_test.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/pickler.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/pickler_test.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/util.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/util_test.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/windmill_pb2.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/windmill_service_pb2.py -> apache-beam-sdk-0.3.0/apache_beam/internal
hard linking apache_beam/internal/clients/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients
hard linking apache_beam/internal/clients/bigquery/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients/bigquery
hard linking apache_beam/internal/clients/bigquery/bigquery_v2_client.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients/bigquery
hard linking apache_beam/internal/clients/bigquery/bigquery_v2_messages.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients/bigquery
hard linking apache_beam/internal/clients/dataflow/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients/dataflow
hard linking apache_beam/internal/clients/dataflow/dataflow_v1b3_client.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients/dataflow
hard linking apache_beam/internal/clients/dataflow/dataflow_v1b3_messages.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients/dataflow
hard linking apache_beam/internal/clients/storage/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients/storage
hard linking apache_beam/internal/clients/storage/storage_v1_client.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients/storage
hard linking apache_beam/internal/clients/storage/storage_v1_messages.py -> apache-beam-sdk-0.3.0/apache_beam/internal/clients/storage
hard linking apache_beam/io/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/avroio.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/avroio_test.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/bigquery.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/bigquery_test.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/filebasedsource.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/filebasedsource_test.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/fileio.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/fileio_test.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/gcsio.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/gcsio_test.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/iobase.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/pubsub.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/range_trackers.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/range_trackers_test.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/io/sources_test.py -> apache-beam-sdk-0.3.0/apache_beam/io
hard linking apache_beam/runners/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/runners
hard linking apache_beam/runners/common.pxd -> apache-beam-sdk-0.3.0/apache_beam/runners
hard linking apache_beam/runners/common.py -> apache-beam-sdk-0.3.0/apache_beam/runners
hard linking apache_beam/runners/dataflow_runner.py -> apache-beam-sdk-0.3.0/apache_beam/runners
hard linking apache_beam/runners/direct_runner.py -> apache-beam-sdk-0.3.0/apache_beam/runners
hard linking apache_beam/runners/runner.py -> apache-beam-sdk-0.3.0/apache_beam/runners
hard linking apache_beam/runners/runner_test.py -> apache-beam-sdk-0.3.0/apache_beam/runners
hard linking apache_beam/transforms/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/aggregator.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/aggregator_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/combiners.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/combiners_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/core.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/cy_combiners.pxd -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/cy_combiners.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/ptransform.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/ptransform_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/sideinputs.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/timeutil.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/timeutil_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/trigger.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/trigger_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/util.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/window.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/window_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/transforms/write_ptransform_test.py -> apache-beam-sdk-0.3.0/apache_beam/transforms
hard linking apache_beam/typehints/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/decorators.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/opcodes.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/trivial_inference.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/trivial_inference_test.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/typecheck.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/typed_pipeline_test.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/typehints.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/typehints/typehints_test.py -> apache-beam-sdk-0.3.0/apache_beam/typehints
hard linking apache_beam/utils/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/counters.pxd -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/counters.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/dependency.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/dependency_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/names.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/options.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/path.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/path_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/pipeline_options_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/pipeline_options_validator.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/pipeline_options_validator_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/processes.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/processes_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/profiler.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/retry.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam/utils/retry_test.py -> apache-beam-sdk-0.3.0/apache_beam/utils
hard linking apache_beam_sdk.egg-info/PKG-INFO -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/SOURCES.txt -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/dependency_links.txt -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/not-zip-safe -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/requires.txt -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
hard linking apache_beam_sdk.egg-info/top_level.txt -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
copying setup.cfg -> apache-beam-sdk-0.3.0
Writing apache-beam-sdk-0.3.0/setup.cfg
Creating tar archive
removing 'apache-beam-sdk-0.3.0' (and everything under it)

# Run wordcount on the Google Cloud Dataflow service
python -m apache_beam.examples.wordcount \
--output $GCS_LOCATION/py-wordcount-cloud \
--staging_location $GCS_LOCATION/staging-wordcount \
--temp_location $GCS_LOCATION/temp-wordcount \
--runner BlockingDataflowPipelineRunner \
--job_name $JOBNAME \
--project $PROJECT \
--sdk_location dist/apache-beam-sdk-*.tar.gz \
--num_workers 1 >> job_output 2>&1 || true;

# Print full job output, validate correct, then remove it.
echo ">>> JOB OUTPUT FOLLOWS"
>>> JOB OUTPUT FOLLOWS
cat job_output
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(139965429760336, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(139935430951184, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(139916943020880, None)'

# Grep will exit with status 1 if success message was not found.
echo ">>> CHECKING JOB SUCCESS"
>>> CHECKING JOB SUCCESS
grep JOB_STATE_DONE job_output
Build step 'Execute shell' marked build as failure

Build failed in Jenkins: beam_PostCommit_PythonVerify #73

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_PythonVerify/73/changes>

Changes:

[robertwb] Fix lint error.

------------------------------------------
[...truncated 1445 lines...]
hard linking apache_beam_sdk.egg-info/top_level.txt -> apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
copying setup.cfg -> apache-beam-sdk-0.3.0
Writing apache-beam-sdk-0.3.0/setup.cfg
Creating tar archive
removing 'apache-beam-sdk-0.3.0' (and everything under it)

# Run wordcount on the Google Cloud Dataflow service
python -m apache_beam.examples.wordcount \
--output $GCS_LOCATION/py-wordcount-cloud \
--staging_location $GCS_LOCATION/staging-wordcount \
--temp_location $GCS_LOCATION/temp-wordcount \
--runner BlockingDataflowPipelineRunner \
--job_name $JOBNAME \
--project $PROJECT \
--sdk_location dist/apache-beam-sdk-*.tar.gz \
--num_workers 1 >> job_output 2>&1 || true;

# Print full job output, validate correct, then remove it.
echo ">>> JOB OUTPUT FOLLOWS"
>>> JOB OUTPUT FOLLOWS
cat job_output
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(140578717938000, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(140528346898704, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(139876057866512, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(140310589935952, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(140410743091920, None)'
ERROR:root:Error while visiting write/WriteImpl/finalize_write
Traceback (most recent call last):
  File "/usr/lib/python2.7/runpy.py", line 162, in _run_module_as_main
    "__main__", fname, loader, pkg_name)
  File "/usr/lib/python2.7/runpy.py", line 72, in _run_code
    exec code in run_globals
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 102, in <module>
    run()
  File "<https://builds.apache.org/job/beam_PostCommit_PythonVerify/ws/sdks/python/apache_beam/examples/wordcount.py",> line 93, in run
    result = p.run()
  File "apache_beam/pipeline.py", line 161, in run
    return self.runner.run(self)
  File "apache_beam/runners/dataflow_runner.py", line 159, in run
    super(DataflowPipelineRunner, self).run(pipeline)
  File "apache_beam/runners/runner.py", line 99, in run
    pipeline.visit(RunVisitor(self))
  File "apache_beam/pipeline.py", line 184, in visit
    self._root_transform().visit(visitor, self, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 418, in visit
    part.visit(visitor, pipeline, visited)
  File "apache_beam/pipeline.py", line 421, in visit
    visitor.visit_transform(self)
  File "apache_beam/runners/runner.py", line 94, in visit_transform
    self.runner.run_transform(transform_node)
  File "apache_beam/runners/runner.py", line 169, in run_transform
    return m(transform_node)
  File "apache_beam/runners/dataflow_runner.py", line 367, in run_ParDo
    si_label = lookup_label(side_pval)
  File "apache_beam/runners/dataflow_runner.py", line 364, in <lambda>
    lookup_label = lambda side_pval: self._cache.get_pvalue(side_pval).step_name
  File "apache_beam/runners/runner.py", line 245, in get_pvalue
    value_with_refcount = self._cache[self.key(pvalue)]
KeyError: '(140051568476880, None)'

# Grep will exit with status 1 if success message was not found.
echo ">>> CHECKING JOB SUCCESS"
>>> CHECKING JOB SUCCESS
grep JOB_STATE_DONE job_output
Build step 'Execute shell' marked build as failure