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/11 23:53:37 UTC

Build failed in Jenkins: beam_PostCommit_PythonVerify #66

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

Changes:

[robertwb] Internal cleanup.

------------------------------------------
[...truncated 1245 lines...]
echo ">>> RUNNING DIRECT RUNNER py-wordcount"
>>> RUNNING DIRECT RUNNER py-wordcount
python -m apache_beam.examples.wordcount --output /tmp/py-wordcount-direct
INFO:root:Missing pipeline option (runner). Executing pipeline using the default runner: DirectPipelineRunner.
INFO:oauth2client.client:Attempting refresh to obtain initial access_token
INFO:root:Starting finalize_write threads with num_shards: 1, num_threads: 1
INFO:root:Renamed 1 shards in 0.00 seconds.
INFO:root:Final: Debug counters: {'element_counts': Counter({('group/reify_windows', None): 28001, ('pair_with_one', None): 28001, ('split', None): 28001, 'read': 5525, ('group/group_by_window', None): 4784, ('format', None): 4784, ('count', None): 4784, 'group/group_by_key': 4784, ('write/WriteImpl/finalize_write', None): 1, ('write/WriteImpl/write_bundles', None): 1, ('write/WriteImpl/initialize_write', None): 1, 'write/WriteImpl/DoOnce': 1})}
INFO:root:number of empty lines: 1663
INFO:root:average word lengths: [4.204242705617657]
# TODO: check that output file is generated for Direct Runner.

# Run wordcount on the service.

# Where to store wordcount output.
GCS_LOCATION=gs://temp-storage-for-end-to-end-tests

# Job name needs to be unique
JOBNAME=py-wordcount-`date +%s`
date +%s

PROJECT=apache-beam-testing

# Create a tarball
python setup.py sdist
running sdist
running egg_info
writing requirements to apache_beam_sdk.egg-info/requires.txt
writing apache_beam_sdk.egg-info/PKG-INFO
writing top-level names to apache_beam_sdk.egg-info/top_level.txt
writing dependency_links to apache_beam_sdk.egg-info/dependency_links.txt
reading manifest file 'apache_beam_sdk.egg-info/SOURCES.txt'
writing manifest file 'apache_beam_sdk.egg-info/SOURCES.txt'
warning: sdist: standard file not found: should have one of README, README.rst, README.txt

running check
warning: check: missing meta-data: if 'author' supplied, 'author_email' must be supplied too

creating apache-beam-sdk-0.3.0
creating apache-beam-sdk-0.3.0/apache_beam
creating apache-beam-sdk-0.3.0/apache_beam/coders
creating apache-beam-sdk-0.3.0/apache_beam/examples
creating apache-beam-sdk-0.3.0/apache_beam/internal
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/bigquery
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/dataflow
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/storage
creating apache-beam-sdk-0.3.0/apache_beam/io
creating apache-beam-sdk-0.3.0/apache_beam/runners
creating apache-beam-sdk-0.3.0/apache_beam/transforms
creating apache-beam-sdk-0.3.0/apache_beam/typehints
creating apache-beam-sdk-0.3.0/apache_beam/utils
creating apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
making hard links in apache-beam-sdk-0.3.0...
hard linking setup.cfg -> apache-beam-sdk-0.3.0
hard linking setup.py -> apache-beam-sdk-0.3.0
hard linking apache_beam/__init__.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/dataflow_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/error.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pipeline.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pipeline_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pvalue.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pvalue_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/version.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/coders/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coder_impl.pxd -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coder_impl.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders_test_common.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/fast_coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/observable.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/observable_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/slow_coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/slow_stream.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pxd -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pyx -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/examples/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcap.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
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)'

# 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

Build failed in Jenkins: beam_PostCommit_PythonVerify #72

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

Build failed in Jenkins: beam_PostCommit_PythonVerify #71

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

Changes:

[chamikara] Adds more code snippets.

------------------------------------------
[...truncated 1371 lines...]
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: '(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)'

# 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 #70

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

------------------------------------------
[...truncated 1319 lines...]
hard linking apache_beam/coders/slow_stream.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pxd -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pyx -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/examples/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcap.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
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: '(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)'

# 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 #69

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

------------------------------------------
[...truncated 1282 lines...]

creating apache-beam-sdk-0.3.0
creating apache-beam-sdk-0.3.0/apache_beam
creating apache-beam-sdk-0.3.0/apache_beam/coders
creating apache-beam-sdk-0.3.0/apache_beam/examples
creating apache-beam-sdk-0.3.0/apache_beam/internal
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/bigquery
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/dataflow
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/storage
creating apache-beam-sdk-0.3.0/apache_beam/io
creating apache-beam-sdk-0.3.0/apache_beam/runners
creating apache-beam-sdk-0.3.0/apache_beam/transforms
creating apache-beam-sdk-0.3.0/apache_beam/typehints
creating apache-beam-sdk-0.3.0/apache_beam/utils
creating apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
making hard links in apache-beam-sdk-0.3.0...
hard linking setup.cfg -> apache-beam-sdk-0.3.0
hard linking setup.py -> apache-beam-sdk-0.3.0
hard linking apache_beam/__init__.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/dataflow_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/error.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pipeline.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pipeline_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pvalue.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pvalue_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/version.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/coders/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coder_impl.pxd -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coder_impl.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders_test_common.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/fast_coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/observable.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/observable_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/slow_coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/slow_stream.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pxd -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pyx -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/examples/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcap.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
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)'

# 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 #68

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

------------------------------------------
[...truncated 1282 lines...]

creating apache-beam-sdk-0.3.0
creating apache-beam-sdk-0.3.0/apache_beam
creating apache-beam-sdk-0.3.0/apache_beam/coders
creating apache-beam-sdk-0.3.0/apache_beam/examples
creating apache-beam-sdk-0.3.0/apache_beam/internal
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/bigquery
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/dataflow
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/storage
creating apache-beam-sdk-0.3.0/apache_beam/io
creating apache-beam-sdk-0.3.0/apache_beam/runners
creating apache-beam-sdk-0.3.0/apache_beam/transforms
creating apache-beam-sdk-0.3.0/apache_beam/typehints
creating apache-beam-sdk-0.3.0/apache_beam/utils
creating apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
making hard links in apache-beam-sdk-0.3.0...
hard linking setup.cfg -> apache-beam-sdk-0.3.0
hard linking setup.py -> apache-beam-sdk-0.3.0
hard linking apache_beam/__init__.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/dataflow_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/error.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pipeline.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pipeline_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pvalue.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pvalue_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/version.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/coders/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coder_impl.pxd -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coder_impl.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders_test_common.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/fast_coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/observable.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/observable_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/slow_coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/slow_stream.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pxd -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pyx -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/examples/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcap.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
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: '(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)'

# 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

Re: Build failed in Jenkins: beam_PostCommit_PythonVerify #67

Posted by Dan Halperin <dh...@google.com>.
Filed JIRA: https://issues.apache.org/jira/browse/BEAM-441

On Mon, Jul 11, 2016 at 5:54 PM, Apache Jenkins Server <
jenkins@builds.apache.org> wrote:

> See <https://builds.apache.org/job/beam_PostCommit_PythonVerify/67/changes
> >
>
> Changes:
>
> [dhalperi] Fix warnings that came with newly released Pylint (1.6.1)
> version.
>
> ------------------------------------------
> [...truncated 1247 lines...]
> echo ">>> RUNNING DIRECT RUNNER py-wordcount"
> >>> RUNNING DIRECT RUNNER py-wordcount
> python -m apache_beam.examples.wordcount --output /tmp/py-wordcount-direct
> INFO:root:Missing pipeline option (runner). Executing pipeline using the
> default runner: DirectPipelineRunner.
> INFO:oauth2client.client:Attempting refresh to obtain initial access_token
> INFO:root:Starting finalize_write threads with num_shards: 1, num_threads:
> 1
> INFO:root:Renamed 1 shards in 0.02 seconds.
> INFO:root:Final: Debug counters: {'element_counts':
> Counter({('group/reify_windows', None): 28001, ('pair_with_one', None):
> 28001, ('split', None): 28001, 'read': 5525, ('group/group_by_window',
> None): 4784, ('format', None): 4784, ('count', None): 4784,
> 'group/group_by_key': 4784, ('write/WriteImpl/finalize_write', None): 1,
> ('write/WriteImpl/write_bundles', None): 1,
> ('write/WriteImpl/initialize_write', None): 1, 'write/WriteImpl/DoOnce':
> 1})}
> INFO:root:number of empty lines: 1663
> INFO:root:average word lengths: [4.204242705617657]
> # TODO: check that output file is generated for Direct Runner.
>
> # Run wordcount on the service.
>
> # Where to store wordcount output.
> GCS_LOCATION=gs://temp-storage-for-end-to-end-tests
>
> # Job name needs to be unique
> JOBNAME=py-wordcount-`date +%s`
> date +%s
>
> PROJECT=apache-beam-testing
>
> # Create a tarball
> python setup.py sdist
> running sdist
> running egg_info
> writing requirements to apache_beam_sdk.egg-info/requires.txt
> writing apache_beam_sdk.egg-info/PKG-INFO
> writing top-level names to apache_beam_sdk.egg-info/top_level.txt
> writing dependency_links to apache_beam_sdk.egg-info/dependency_links.txt
> reading manifest file 'apache_beam_sdk.egg-info/SOURCES.txt'
> writing manifest file 'apache_beam_sdk.egg-info/SOURCES.txt'
> warning: sdist: standard file not found: should have one of README,
> README.rst, README.txt
>
> running check
> warning: check: missing meta-data: if 'author' supplied, 'author_email'
> must be supplied too
>
> creating apache-beam-sdk-0.3.0
> creating apache-beam-sdk-0.3.0/apache_beam
> creating apache-beam-sdk-0.3.0/apache_beam/coders
> creating apache-beam-sdk-0.3.0/apache_beam/examples
> creating apache-beam-sdk-0.3.0/apache_beam/internal
> creating apache-beam-sdk-0.3.0/apache_beam/internal/clients
> creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/bigquery
> creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/dataflow
> creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/storage
> creating apache-beam-sdk-0.3.0/apache_beam/io
> creating apache-beam-sdk-0.3.0/apache_beam/runners
> creating apache-beam-sdk-0.3.0/apache_beam/transforms
> creating apache-beam-sdk-0.3.0/apache_beam/typehints
> creating apache-beam-sdk-0.3.0/apache_beam/utils
> creating apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
> making hard links in apache-beam-sdk-0.3.0...
> hard linking setup.cfg -> apache-beam-sdk-0.3.0
> hard linking setup.py -> apache-beam-sdk-0.3.0
> hard linking apache_beam/__init__.py -> apache-beam-sdk-0.3.0/apache_beam
> hard linking apache_beam/dataflow_test.py ->
> apache-beam-sdk-0.3.0/apache_beam
> hard linking apache_beam/error.py -> apache-beam-sdk-0.3.0/apache_beam
> hard linking apache_beam/pipeline.py -> apache-beam-sdk-0.3.0/apache_beam
> hard linking apache_beam/pipeline_test.py ->
> apache-beam-sdk-0.3.0/apache_beam
> hard linking apache_beam/pvalue.py -> apache-beam-sdk-0.3.0/apache_beam
> hard linking apache_beam/pvalue_test.py ->
> apache-beam-sdk-0.3.0/apache_beam
> hard linking apache_beam/version.py -> apache-beam-sdk-0.3.0/apache_beam
> hard linking apache_beam/coders/__init__.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/coder_impl.pxd ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/coder_impl.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/coders.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/coders_test.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/coders_test_common.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/fast_coders_test.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/observable.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/observable_test.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/slow_coders_test.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/slow_stream.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/stream.pxd ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/stream.pyx ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/stream_test.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/typecoders.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/coders/typecoders_test.py ->
> apache-beam-sdk-0.3.0/apache_beam/coders
> hard linking apache_beam/examples/__init__.py ->
> apache-beam-sdk-0.3.0/apache_beam/examples
> hard linking apache_beam/examples/streaming_wordcap.py ->
> apache-beam-sdk-0.3.0/apache_beam/examples
> hard linking apache_beam/examples/streaming_wordcount.py ->
> apache-beam-sdk-0.3.0/apache_beam/examples
> hard linking apache_beam/examples/wordcount.py ->
> apache-beam-sdk-0.3.0/apache_beam/examples
> hard linking apache_beam/examples/wordcount_debugging.py ->
> apache-beam-sdk-0.3.0/apache_beam/examples
> hard linking apache_beam/examples/wordcount_debugging_test.py ->
> apache-beam-sdk-0.3.0/apache_beam/examples
> hard linking apache_beam/examples/wordcount_minimal.py ->
> apache-beam-sdk-0.3.0/apache_beam/examples
> hard linking apache_beam/examples/wordcount_minimal_test.py ->
> apache-beam-sdk-0.3.0/apache_beam/examples
> hard linking apache_beam/examples/wordcount_test.py ->
> apache-beam-sdk-0.3.0/apache_beam/examples
> 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: '(140578717938000, 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 #67

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

Changes:

[dhalperi] Fix warnings that came with newly released Pylint (1.6.1) version.

------------------------------------------
[...truncated 1247 lines...]
echo ">>> RUNNING DIRECT RUNNER py-wordcount"
>>> RUNNING DIRECT RUNNER py-wordcount
python -m apache_beam.examples.wordcount --output /tmp/py-wordcount-direct
INFO:root:Missing pipeline option (runner). Executing pipeline using the default runner: DirectPipelineRunner.
INFO:oauth2client.client:Attempting refresh to obtain initial access_token
INFO:root:Starting finalize_write threads with num_shards: 1, num_threads: 1
INFO:root:Renamed 1 shards in 0.02 seconds.
INFO:root:Final: Debug counters: {'element_counts': Counter({('group/reify_windows', None): 28001, ('pair_with_one', None): 28001, ('split', None): 28001, 'read': 5525, ('group/group_by_window', None): 4784, ('format', None): 4784, ('count', None): 4784, 'group/group_by_key': 4784, ('write/WriteImpl/finalize_write', None): 1, ('write/WriteImpl/write_bundles', None): 1, ('write/WriteImpl/initialize_write', None): 1, 'write/WriteImpl/DoOnce': 1})}
INFO:root:number of empty lines: 1663
INFO:root:average word lengths: [4.204242705617657]
# TODO: check that output file is generated for Direct Runner.

# Run wordcount on the service.

# Where to store wordcount output.
GCS_LOCATION=gs://temp-storage-for-end-to-end-tests

# Job name needs to be unique
JOBNAME=py-wordcount-`date +%s`
date +%s

PROJECT=apache-beam-testing

# Create a tarball
python setup.py sdist
running sdist
running egg_info
writing requirements to apache_beam_sdk.egg-info/requires.txt
writing apache_beam_sdk.egg-info/PKG-INFO
writing top-level names to apache_beam_sdk.egg-info/top_level.txt
writing dependency_links to apache_beam_sdk.egg-info/dependency_links.txt
reading manifest file 'apache_beam_sdk.egg-info/SOURCES.txt'
writing manifest file 'apache_beam_sdk.egg-info/SOURCES.txt'
warning: sdist: standard file not found: should have one of README, README.rst, README.txt

running check
warning: check: missing meta-data: if 'author' supplied, 'author_email' must be supplied too

creating apache-beam-sdk-0.3.0
creating apache-beam-sdk-0.3.0/apache_beam
creating apache-beam-sdk-0.3.0/apache_beam/coders
creating apache-beam-sdk-0.3.0/apache_beam/examples
creating apache-beam-sdk-0.3.0/apache_beam/internal
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/bigquery
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/dataflow
creating apache-beam-sdk-0.3.0/apache_beam/internal/clients/storage
creating apache-beam-sdk-0.3.0/apache_beam/io
creating apache-beam-sdk-0.3.0/apache_beam/runners
creating apache-beam-sdk-0.3.0/apache_beam/transforms
creating apache-beam-sdk-0.3.0/apache_beam/typehints
creating apache-beam-sdk-0.3.0/apache_beam/utils
creating apache-beam-sdk-0.3.0/apache_beam_sdk.egg-info
making hard links in apache-beam-sdk-0.3.0...
hard linking setup.cfg -> apache-beam-sdk-0.3.0
hard linking setup.py -> apache-beam-sdk-0.3.0
hard linking apache_beam/__init__.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/dataflow_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/error.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pipeline.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pipeline_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pvalue.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/pvalue_test.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/version.py -> apache-beam-sdk-0.3.0/apache_beam
hard linking apache_beam/coders/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coder_impl.pxd -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coder_impl.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/coders_test_common.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/fast_coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/observable.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/observable_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/slow_coders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/slow_stream.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pxd -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream.pyx -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/stream_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/coders/typecoders_test.py -> apache-beam-sdk-0.3.0/apache_beam/coders
hard linking apache_beam/examples/__init__.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcap.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/streaming_wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_debugging_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_minimal_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
hard linking apache_beam/examples/wordcount_test.py -> apache-beam-sdk-0.3.0/apache_beam/examples
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: '(140578717938000, 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