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

Build failed in Jenkins: beam_PostCommit_Py_ValCont #6409

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

Changes:

[kcweaver] [BEAM-10154] Remove stray version number.

[github] Update programming-guide.md

[github] Updates CHANGES.md to include new I/Os for Beam 2.22.0. (#11879)

[github] [BEAM-10158] Use a shared unbounded thread pool within Beam Python.


------------------------------------------
[...truncated 1.99 MB...]
copying apache_beam/utils/profiler.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server_test.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.23.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.23.0.dev0/apache_beam/utils
Writing apache-beam-2.23.0.dev0/setup.cfg
Creating tar archive
removing 'apache-beam-2.23.0.dev0' (and everything under it)
SDK_LOCATION=$(find dist/apache-beam-*.tar.gz)
find dist/apache-beam-*.tar.gz

# Run ValidatesRunner tests on Google Cloud Dataflow service
echo ">>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST"
>>> RUNNING DATAFLOW RUNNER VALIDATESCONTAINER TEST
python setup.py nosetests \
  --attr ValidatesContainer \
  --nologcapture \
  --processes=1 \
  --process-timeout=900 \
  --with-xunitmp \
  --xunitmp-file=$XUNIT_FILE \
  --ignore-files '.*py3\d?\.py$' \
  --test-pipeline-options=" \
    --runner=TestDataflowRunner \
    --project=$PROJECT \
    --region=$REGION \
    --worker_harness_container_image=$CONTAINER:$TAG \
    --staging_location=$GCS_LOCATION/staging-validatesrunner-test \
    --temp_location=$GCS_LOCATION/temp-validatesrunner-test \
    --output=$GCS_LOCATION/output \
    --sdk_location=$SDK_LOCATION \
    --num_workers=1"
running nosetests
running egg_info
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python3.6/lib/python3.6/site-packages/setuptools/dist.py>:454: UserWarning: Normalizing '2.23.0.dev' to '2.23.0.dev0'
  warnings.warn(tmpl.format(**locals()))
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/gen_protos.py>:241: UserWarning: Installing grpcio-tools is recommended for development.
  warnings.warn('Installing grpcio-tools is recommended for development.')
INFO:gen_protos:Skipping proto regeneration: all files up to date
writing apache_beam.egg-info/PKG-INFO
writing dependency_links to apache_beam.egg-info/dependency_links.txt
writing entry points to apache_beam.egg-info/entry_points.txt
writing requirements to apache_beam.egg-info/requires.txt
writing top-level names to apache_beam.egg-info/top_level.txt
reading manifest file 'apache_beam.egg-info/SOURCES.txt'
reading manifest template 'MANIFEST.in'
warning: no files found matching 'README.md'
warning: no files found matching 'NOTICE'
warning: no files found matching 'LICENSE'
writing manifest file 'apache_beam.egg-info/SOURCES.txt'
WARNING:root:python-snappy is not installed; some tests will be skipped.
WARNING:root:Tensorflow is not installed, so skipping some tests.
<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/io/vcfio.py>:50: UserWarning: VCF IO will support Python 3 after migration to Nucleus, see: BEAM-5628.
  "VCF IO will support Python 3 after migration to Nucleus, "
WARNING:apache_beam.runners.interactive.interactive_environment:Dependencies required for Interactive Beam PCollection visualization are not available, please use: `pip install apache-beam[interactive]` to install necessary dependencies to enable all data visualization features.
WARNING:apache_beam.runners.interactive.interactive_environment:You cannot use Interactive Beam features when you are not in an interactive environment such as a Jupyter notebook or ipython terminal.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
test_wordcount_fnapi_it (apache_beam.examples.wordcount_it_test.WordCountIT) ... ok
test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest) ... FAIL

======================================================================
FAIL: test_metrics_fnapi_it (apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py",> line 61, in test_metrics_fnapi_it
    self.assertFalse(errors, str(errors))
AssertionError: "Unable to match metrics for matcher  namespace: 'apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn' name: 'total_values' step: 'metrics' attempted: <100> committed: <100>Unable to match metrics for matcher  namespace: 'apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn' name: 'distribution_values' step: 'metrics' attempted:  sum_value: <100> count_value: <4> min_value: <0> max_value: <100> committed:  sum_value: <100> count_value: <4> min_value: <0> max_value: <100>\nActual MetricResults:\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn, name=total_values), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn, name=distribution_values), labels={}), committed=DistributionResult(sum=0, count=2, min=0, max=0), attempted=DistributionResult(sum=0, count=2, min=0, max=0))\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalVcpuTime), labels={'original_name': 'Service-cpu_num_seconds'}), committed=193, attempted=193)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalMemoryUsage), labels={'original_name': 'Service-mem_mb_seconds'}), committed=741150, attempted=741150)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalPdUsage), labels={'original_name': 'Service-pd_gb_seconds'}), committed=48251, attempted=48251)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalSsdUsage), labels={'original_name': 'Service-pd_ssd_gb_seconds'}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalShuffleDataProcessed), labels={'original_name': 'Service-shuffle_service_actual_gb'}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=BillableShuffleDataProcessed), labels={'original_name': 'Service-shuffle_service_chargeable_gb'}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalStreamingDataProcessed), labels={'original_name': 'Service-streaming_service_gb'}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-06-01_18_01_59-1009516753940838870/phases/graph_runner/step-invocations/F20-invoke-11029322944291111903/map-tasks-completion/map-tasks', 'execution_step': 'F20'}), committed=1, attempted=1)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentVcpuCount), labels={'original_name': 'Service-cpu_num'}), committed=1, attempted=1)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentMemoryUsage), labels={'original_name': 'Service-mem_mb'}), committed=3840, attempted=3840)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentPdUsage), labels={'original_name': 'Service-pd_gb'}), committed=250, attempted=250)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentSsdUsage), labels={'original_name': 'Service-pd_ssd_gb'}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-ElementCount'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0-MeanByteCount'}), committed=42, attempted=42)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/Impulse-out0', 'original_name': 'Create/Impulse-out0-MeanByteCount'}), committed=14, attempted=14)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ShuffleBytesWritten), labels={'original_name': 's5-write-shuffle14-ByteCount'}), committed=108, attempted=108)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-MeanByteCount'}), committed=27, attempted=27)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0-ElementCount'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/Impulse-out0-ElementCount', 'output_user_name': 'Create/Impulse-out0'}), committed=1, attempted=1)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_WriteShuffle), labels={}), committed=4603, attempted=4603)\nMetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=200, attempted=200)\nMetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=401, attempted=401)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=601, attempted=601)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0-MeanByteCount'}), committed=19, attempted=19)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0-ElementCount'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/FlatMap(<lambda at core.py:2623>)-out0', 'original_name': 'Create/FlatMap(<lambda at core.py:2623>)-out0-MeanByteCount'}), committed=14, attempted=14)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/FlatMap(<lambda at core.py:2623>)-out0', 'original_name': 'Create/FlatMap(<lambda at core.py:2623>)-out0-ElementCount'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2623>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=227, attempted=227)\nMetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2623>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=403, attempted=403)\nMetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2623>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2623>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-06-01_18_01_59-1009516753940838870/phases/graph_runner/step-invocations/F19-invoke-11029322944291114019/map-tasks-completion/map-tasks', 'execution_step': 'F19'}), committed=1, attempted=None)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'metrics-out0', 'original_name': 'metrics-out0-MeanByteCount'}), committed=14, attempted=14)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'map_to_common_key-out0', 'original_name': 'map_to_common_key-out0-MeanByteCount'}), committed=18, attempted=18)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'map_to_common_key-out0-ElementCount', 'output_user_name': 'map_to_common_key-out0'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/Map(decode)-out0', 'original_name': 'Create/Map(decode)-out0-MeanByteCount'}), committed=14, attempted=14)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/Map(decode)-out0', 'original_name': 'Create/Map(decode)-out0-ElementCount'}), committed=2, attempted=2)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0-ElementCount'}), committed=2, attempted=2)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ShuffleBytesRead), labels={'original_name': 's5-read-shuffle16-ByteCount'}), committed=108, attempted=108)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ShuffleBytesWritten), labels={'original_name': 's11-write-shuffle5-ByteCount'}), committed=72, attempted=72)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0-MeanByteCount'}), committed=32, attempted=32)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0-ElementCount'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'metrics-out0', 'original_name': 'metrics-out0-ElementCount'}), committed=2, attempted=2)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'GroupByKey/Reify-out0', 'original_name': 'GroupByKey/Reify-out0-ElementCount'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0-MeanByteCount'}), committed=19, attempted=19)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0-ElementCount'}), committed=2, attempted=2)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0-MeanByteCount'}), committed=14, attempted=14)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0-ElementCount'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=1930, attempted=1930)\nMetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=4005, attempted=4005)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=1991, attempted=1991)\nMetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=2001, attempted=2001)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ReadShuffle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_WriteShuffle), labels={}), committed=5003, attempted=5003)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=6609, attempted=6609)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=406, attempted=406)\nMetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'GroupByKey/Reify-out0', 'original_name': 'GroupByKey/Reify-out0-MeanByteCount'}), committed=32, attempted=32)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0-MeanByteCount'}), committed=26, attempted=26)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-06-01_18_01_59-1009516753940838870/phases/graph_runner/step-invocations/F18-invoke-11029322944291112039/map-tasks-completion/map-tasks', 'execution_step': 'F18'}), committed=1, attempted=1)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'm_out-out0', 'original_name': 'm_out-out0-MeanByteCount'}), committed=15, attempted=15)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'GroupByKey/GroupByWindow-out0', 'original_name': 'GroupByKey/GroupByWindow-out0-ElementCount'}), committed=1, attempted=1)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'm_out-out0-ElementCount', 'output_user_name': 'm_out-out0'}), committed=5, attempted=5)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'GroupByKey/Read-out0', 'original_name': 'GroupByKey/Read-out0-ElementCount'}), committed=1, attempted=1)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'GroupByKey/GroupByWindow-out0', 'original_name': 'GroupByKey/GroupByWindow-out0-MeanByteCount'}), committed=25, attempted=25)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ShuffleBytesRead), labels={'original_name': 's11-read-shuffle7-ByteCount'}), committed=72, attempted=72)\nMetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=94, attempted=94)\nMetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ReadShuffle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'GroupByKey/Read-out0', 'original_name': 'GroupByKey/Read-out0-MeanByteCount'}), committed=23, attempted=23)" is not false : Unable to match metrics for matcher  namespace: 'apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn' name: 'total_values' step: 'metrics' attempted: <100> committed: <100>Unable to match metrics for matcher  namespace: 'apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn' name: 'distribution_values' step: 'metrics' attempted:  sum_value: <100> count_value: <4> min_value: <0> max_value: <100> committed:  sum_value: <100> count_value: <4> min_value: <0> max_value: <100>
Actual MetricResults:
MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn, name=total_values), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn, name=distribution_values), labels={}), committed=DistributionResult(sum=0, count=2, min=0, max=0), attempted=DistributionResult(sum=0, count=2, min=0, max=0))
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalVcpuTime), labels={'original_name': 'Service-cpu_num_seconds'}), committed=193, attempted=193)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalMemoryUsage), labels={'original_name': 'Service-mem_mb_seconds'}), committed=741150, attempted=741150)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalPdUsage), labels={'original_name': 'Service-pd_gb_seconds'}), committed=48251, attempted=48251)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalSsdUsage), labels={'original_name': 'Service-pd_ssd_gb_seconds'}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalShuffleDataProcessed), labels={'original_name': 'Service-shuffle_service_actual_gb'}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=BillableShuffleDataProcessed), labels={'original_name': 'Service-shuffle_service_chargeable_gb'}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalStreamingDataProcessed), labels={'original_name': 'Service-streaming_service_gb'}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-06-01_18_01_59-1009516753940838870/phases/graph_runner/step-invocations/F20-invoke-11029322944291111903/map-tasks-completion/map-tasks', 'execution_step': 'F20'}), committed=1, attempted=1)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentVcpuCount), labels={'original_name': 'Service-cpu_num'}), committed=1, attempted=1)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentMemoryUsage), labels={'original_name': 'Service-mem_mb'}), committed=3840, attempted=3840)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentPdUsage), labels={'original_name': 'Service-pd_gb'}), committed=250, attempted=250)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentSsdUsage), labels={'original_name': 'Service-pd_ssd_gb'}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-ElementCount'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0-MeanByteCount'}), committed=42, attempted=42)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/Impulse-out0', 'original_name': 'Create/Impulse-out0-MeanByteCount'}), committed=14, attempted=14)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ShuffleBytesWritten), labels={'original_name': 's5-write-shuffle14-ByteCount'}), committed=108, attempted=108)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-MeanByteCount'}), committed=27, attempted=27)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0-ElementCount'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/Impulse-out0-ElementCount', 'output_user_name': 'Create/Impulse-out0'}), committed=1, attempted=1)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_WriteShuffle), labels={}), committed=4603, attempted=4603)
MetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=200, attempted=200)
MetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=401, attempted=401)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=601, attempted=601)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0-MeanByteCount'}), committed=19, attempted=19)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0-ElementCount'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/FlatMap(<lambda at core.py:2623>)-out0', 'original_name': 'Create/FlatMap(<lambda at core.py:2623>)-out0-MeanByteCount'}), committed=14, attempted=14)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/FlatMap(<lambda at core.py:2623>)-out0', 'original_name': 'Create/FlatMap(<lambda at core.py:2623>)-out0-ElementCount'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2623>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=227, attempted=227)
MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2623>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=403, attempted=403)
MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2623>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2623>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-06-01_18_01_59-1009516753940838870/phases/graph_runner/step-invocations/F19-invoke-11029322944291114019/map-tasks-completion/map-tasks', 'execution_step': 'F19'}), committed=1, attempted=None)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'metrics-out0', 'original_name': 'metrics-out0-MeanByteCount'}), committed=14, attempted=14)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'map_to_common_key-out0', 'original_name': 'map_to_common_key-out0-MeanByteCount'}), committed=18, attempted=18)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'map_to_common_key-out0-ElementCount', 'output_user_name': 'map_to_common_key-out0'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/Map(decode)-out0', 'original_name': 'Create/Map(decode)-out0-MeanByteCount'}), committed=14, attempted=14)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/Map(decode)-out0', 'original_name': 'Create/Map(decode)-out0-ElementCount'}), committed=2, attempted=2)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0-ElementCount'}), committed=2, attempted=2)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ShuffleBytesRead), labels={'original_name': 's5-read-shuffle16-ByteCount'}), committed=108, attempted=108)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ShuffleBytesWritten), labels={'original_name': 's11-write-shuffle5-ByteCount'}), committed=72, attempted=72)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0-MeanByteCount'}), committed=32, attempted=32)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0-ElementCount'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'metrics-out0', 'original_name': 'metrics-out0-ElementCount'}), committed=2, attempted=2)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'GroupByKey/Reify-out0', 'original_name': 'GroupByKey/Reify-out0-ElementCount'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0-MeanByteCount'}), committed=19, attempted=19)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0-ElementCount'}), committed=2, attempted=2)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0-MeanByteCount'}), committed=14, attempted=14)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0-ElementCount'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=1930, attempted=1930)
MetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=4005, attempted=4005)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=1991, attempted=1991)
MetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=2001, attempted=2001)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ReadShuffle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_WriteShuffle), labels={}), committed=5003, attempted=5003)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=6609, attempted=6609)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=406, attempted=406)
MetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'GroupByKey/Reify-out0', 'original_name': 'GroupByKey/Reify-out0-MeanByteCount'}), committed=32, attempted=32)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0', 'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0-MeanByteCount'}), committed=26, attempted=26)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-06-01_18_01_59-1009516753940838870/phases/graph_runner/step-invocations/F18-invoke-11029322944291112039/map-tasks-completion/map-tasks', 'execution_step': 'F18'}), committed=1, attempted=1)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'm_out-out0', 'original_name': 'm_out-out0-MeanByteCount'}), committed=15, attempted=15)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'GroupByKey/GroupByWindow-out0', 'original_name': 'GroupByKey/GroupByWindow-out0-ElementCount'}), committed=1, attempted=1)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'm_out-out0-ElementCount', 'output_user_name': 'm_out-out0'}), committed=5, attempted=5)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'GroupByKey/Read-out0', 'original_name': 'GroupByKey/Read-out0-ElementCount'}), committed=1, attempted=1)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'GroupByKey/GroupByWindow-out0', 'original_name': 'GroupByKey/GroupByWindow-out0-MeanByteCount'}), committed=25, attempted=25)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ShuffleBytesRead), labels={'original_name': 's11-read-shuffle7-ByteCount'}), committed=72, attempted=72)
MetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=94, attempted=94)
MetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ReadShuffle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'output_user_name': 'GroupByKey/Read-out0', 'original_name': 'GroupByKey/Read-out0-MeanByteCount'}), committed=23, attempted=23)
-------------------- >> begin captured stdout << ---------------------
Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2020-06-01_18_01_59-1009516753940838870?project=apache-beam-testing

--------------------- >> end captured stdout << ----------------------

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

FAILED (failures=1)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.6_sdk:20200602-004703
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.6_sdk@sha256:68a37a245e63e5bf92036bb011e3dbb5bd558b02cff3cb025ee47bcd3e07510e
Deleted: sha256:4f14d4b83c991dbac0fbfae2deb8d9ce3bc6aa8a72361c5c2075559af4b5f78b
Deleted: sha256:ed73c4f4ed8473aa040472071e457cf273bad8307909bda199857ca956e2e74f
Deleted: sha256:ec940ba7e68abb168b837ec74f1d4cb180b8a2d176e84199f08305424833e769
Deleted: sha256:cb3c64fecae106328296426919eac7a41f7e406b2b7cdffdbe75022f1a97663c
Deleted: sha256:96684d908dea364bb60e6dbe538d68b8f49f68f5cf768f62918771b4d1bfb7a1
Deleted: sha256:b67e7c16cbf9ae8ce369daf4495e2ce58a613b26d5d491b16ceb94ca5e621b3c
Deleted: sha256:6088f85cc9379e945deae2a96b906389fb48bed468620faee1fc46b02039a734
Deleted: sha256:e6b3fe0237d89ee9da9aeb3075a5159f6c2410d22e7a0c34c450ab5350c14f4e
Deleted: sha256:1143f4a05eb5c4901d1262716a7c87b4a0417841154080377890b9bf7db4316d
Deleted: sha256:de16f88d3d147e05fbe80e1ca319aa79a54965430875e1a5e3b078828c33f50f
Deleted: sha256:6e23ca7561578fa9c8f29c2ca605a26c7344b7c090ff4de1ba67f64aa090339c
Deleted: sha256:4e3060656b5d8899f0cec39af4442fd5b213043684c64fbb4d9911323cf86dd5
Deleted: sha256:83973e2ee55f76d3c14872e365658a79cbc74d4449ed647717010f72b4662b50
Deleted: sha256:1cdad4ee038581cfaf73a1f92cb65b724df88fe73e32a3f01a1bca90c0819ca4
Deleted: sha256:e723a50f3a7f1a54987f4efe604753f871a364ed07ac759ae378b3cbb4754a4f
Deleted: sha256:fb01ecba15ac54fd57b1c09086faeca3c691ef205fbf94b39ffd7d4082d63550
Deleted: sha256:4addbc2b4bee013fc2649ecd4355ac2b3e9851393c4087073c6cfc5fc9e8f52e
Deleted: sha256:ae070a49b68f7e837ba879073766ecd191a2db323d6292ed1c384ae510ec0b80
Deleted: sha256:a4e468504c91bf941405e06ea6447ccc68f8ac3a33d4a9e992f7e0d99def2a51
Deleted: sha256:23198476a9213801f205ec573c7a34dd2891b7f753324dd7850eb6735194fa9a
Deleted: sha256:8edc5a4718ca524cd31ecf1e4bff49f29c7dda07065e2a984514d9c75ee40910
Deleted: sha256:e9dff73dc80adbcac935e221c32912d54a210c2de9725f30ecda669025cc1270
Deleted: sha256:5c60e28eeae7915e15fc3f8302e386e708033edf4abceeb6b7fd5dc8ab0f3127
Deleted: sha256:6af2d72e61bbe43fd56064f2e35065efd03d2a58e340516961ed022c0bf9a0ac
Deleted: sha256:e45732130ed537e3ec537653fe7a6938a950f477e73527ef7d1c80003a752360
Deleted: sha256:f3a682a2ee71f584083e61595848d9b06f869820d169af599c2d206c7f1f411a
Deleted: sha256:a1ba8d59448380b605ac6662b87e563d75988c5b9a37d78320ab0c32aefd4e98
Deleted: sha256:09999c73a93a002fac6afc57dfef2392825615965ef070e64ba590fd6b72e485
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.6_sdk@sha256:68a37a245e63e5bf92036bb011e3dbb5bd558b02cff3cb025ee47bcd3e07510e
  Associated tags:
 - 20200602-004703
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.6_sdk:20200602-004703
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.6_sdk:20200602-004703].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.6_sdk@sha256:68a37a245e63e5bf92036bb011e3dbb5bd558b02cff3cb025ee47bcd3e07510e].
Removed the container
Build step 'Execute shell' marked build as failure

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


Jenkins build is back to normal : beam_PostCommit_Py_ValCont #6410

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


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