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/07/10 07:26:02 UTC

Build failed in Jenkins: beam_PostCommit_Py_ValCont #6563

See <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/6563/display/redirect?page=changes>

Changes:

[Maximilian Michels] [BEAM-9996] Unshadow test_metrics test for flink_runner_test

[noreply] Merge pull request #12107 from Interactive Environment Inspector for

[Steve Niemitz] Deduplicate uploads by destinations before uploading

[noreply] [BEAM-10438] Sync ZetaSQL function allowlist with full list from ZetaSQL


------------------------------------------
[...truncated 2.68 MB...]
copying apache_beam/utils/profiler.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/proto_utils.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/retry.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/retry_test.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/subprocess_server_test.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/thread_pool_executor_test.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/timestamp_test.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/urns.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.pxd -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value.py -> apache-beam-2.24.0.dev0/apache_beam/utils
copying apache_beam/utils/windowed_value_test.py -> apache-beam-2.24.0.dev0/apache_beam/utils
Writing apache-beam-2.24.0.dev0/setup.cfg
Creating tar archive
removing 'apache-beam-2.24.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://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/container/venv/python3.7/lib/python3.7/site-packages/setuptools/dist.py>:458: UserWarning: Normalizing '2.24.0.dev' to '2.24.0.dev0'
  warnings.warn(tmpl.format(**locals()))
<https://ci-beam.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://ci-beam.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.7 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.7 interpreter.
WARNING:root:Make sure that locally built Python SDK docker image has Python 3.7 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://ci-beam.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: '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=100, attempted=100)\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn, name=distribution_values), labels={}), committed=DistributionResult(sum=100, count=2, min=0, max=100), attempted=DistributionResult(sum=100, count=2, min=0, max=100))\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalVcpuTime), labels={'original_name': 'Service-cpu_num_seconds'}), committed=185, attempted=185)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalMemoryUsage), labels={'original_name': 'Service-mem_mb_seconds'}), committed=713471, attempted=713471)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalPdUsage), labels={'original_name': 'Service-pd_gb_seconds'}), committed=46449, attempted=46449)\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={'execution_step': 'F20', 'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-07-10_00_21_14-4521784545710075667/phases/graph_runner/step-invocations/F20-invoke-8318367438191879781/map-tasks-completion/map-tasks'}), 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=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=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/Impulse-out0', 'original_name': 'Create/Impulse-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/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=ElementCount), labels={'output_user_name': 'Create/Impulse-out0', 'original_name': 'Create/Impulse-out0-ElementCount'}), committed=1, attempted=1)\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=MeanByteCount), labels={'original_name': 'Create/FlatMap(<lambda at core.py:2628>)-out0-MeanByteCount', 'output_user_name': 'Create/FlatMap(<lambda at core.py:2628>)-out0'}), committed=14, attempted=14)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0'}), committed=19, attempted=19)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0'}), committed=4, attempted=4)\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/FlatMap(<lambda at core.py:2628>)-out0', 'original_name': 'Create/FlatMap(<lambda at core.py:2628>)-out0-ElementCount'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), 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/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/Impulse, 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_ProcessElement), labels={}), committed=202, attempted=202)\nMetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2628>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=204, attempted=204)\nMetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2628>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_WriteShuffle), 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_StartBundle), labels={}), committed=202, attempted=202)\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/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), 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/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\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=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=187, attempted=187)\nMetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2628>), 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/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=401, attempted=401)\nMetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2628>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), 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/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=204, attempted=204)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'execution_step': 'F19', 'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-07-10_00_21_14-4521784545710075667/phases/graph_runner/step-invocations/F19-invoke-8318367438191881465/map-tasks-completion/map-tasks'}), committed=1, attempted=1)\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=, 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=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=MeanByteCount), labels={'original_name': 'map_to_common_key-out0-MeanByteCount', 'output_user_name': 'map_to_common_key-out0'}), committed=18, attempted=18)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'GroupByKey/Reify-out0-ElementCount', 'output_user_name': 'GroupByKey/Reify-out0'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0'}), committed=4, attempted=4)\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': '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=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0'}), committed=32, attempted=32)\nMetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=8415, attempted=8415)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_WriteShuffle), labels={}), committed=4203, attempted=4203)\nMetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=2001, attempted=2001)\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=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ReadShuffle), 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=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=1953, attempted=1953)\nMetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), 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_StartBundle), labels={}), committed=0, attempted=0)\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=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\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=GroupByKey, 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_ProcessElement), labels={}), committed=200, attempted=200)\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_FinishBundle), labels={}), committed=2001, attempted=2001)\nMetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), 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/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=1847, attempted=1847)\nMetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), 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=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/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=, 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=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0'}), committed=19, attempted=19)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0'}), committed=14, attempted=14)\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=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=MeanByteCount), labels={'original_name': 'metrics-out0-MeanByteCount', 'output_user_name': 'metrics-out0'}), committed=14, attempted=14)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/Map(decode)-out0-MeanByteCount', 'output_user_name': 'Create/Map(decode)-out0'}), committed=14, attempted=14)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0'}), committed=2, attempted=2)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-07-10_00_21_14-4521784545710075667/phases/graph_runner/step-invocations/F18-invoke-8318367438191879053/map-tasks-completion/map-tasks', 'execution_step': 'F18'}), committed=1, attempted=1)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'm_out-out0-MeanByteCount', 'output_user_name': 'm_out-out0'}), committed=15, attempted=15)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'GroupByKey/GroupByWindow-out0-MeanByteCount', 'output_user_name': 'GroupByKey/GroupByWindow-out0'}), committed=25, attempted=25)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'm_out-out0', 'original_name': 'm_out-out0-ElementCount'}), committed=5, attempted=5)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'GroupByKey/Read-out0-ElementCount', 'output_user_name': 'GroupByKey/Read-out0'}), committed=1, attempted=1)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'GroupByKey/GroupByWindow-out0-ElementCount', 'output_user_name': 'GroupByKey/GroupByWindow-out0'}), committed=1, attempted=1)\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_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=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_ProcessElement), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=200, attempted=200)\nMetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), 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=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ReadShuffle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=182, attempted=182)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'GroupByKey/Read-out0-MeanByteCount', 'output_user_name': 'GroupByKey/Read-out0'}), committed=23, attempted=23)" is not false : 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=100, attempted=100)
MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn, name=distribution_values), labels={}), committed=DistributionResult(sum=100, count=2, min=0, max=100), attempted=DistributionResult(sum=100, count=2, min=0, max=100))
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalVcpuTime), labels={'original_name': 'Service-cpu_num_seconds'}), committed=185, attempted=185)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalMemoryUsage), labels={'original_name': 'Service-mem_mb_seconds'}), committed=713471, attempted=713471)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalPdUsage), labels={'original_name': 'Service-pd_gb_seconds'}), committed=46449, attempted=46449)
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={'execution_step': 'F20', 'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-07-10_00_21_14-4521784545710075667/phases/graph_runner/step-invocations/F20-invoke-8318367438191879781/map-tasks-completion/map-tasks'}), 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=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=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/Impulse-out0', 'original_name': 'Create/Impulse-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/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=ElementCount), labels={'output_user_name': 'Create/Impulse-out0', 'original_name': 'Create/Impulse-out0-ElementCount'}), committed=1, attempted=1)
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=MeanByteCount), labels={'original_name': 'Create/FlatMap(<lambda at core.py:2628>)-out0-MeanByteCount', 'output_user_name': 'Create/FlatMap(<lambda at core.py:2628>)-out0'}), committed=14, attempted=14)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0'}), committed=19, attempted=19)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/AddRandomKeys-out0'}), committed=4, attempted=4)
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/FlatMap(<lambda at core.py:2628>)-out0', 'original_name': 'Create/FlatMap(<lambda at core.py:2628>)-out0-ElementCount'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), 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/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/Impulse, 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_ProcessElement), labels={}), committed=202, attempted=202)
MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2628>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s03, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=204, attempted=204)
MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2628>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_WriteShuffle), 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_StartBundle), labels={}), committed=202, attempted=202)
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/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), 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/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
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=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=187, attempted=187)
MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2628>), 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/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=401, attempted=401)
MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:2628>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), 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/Impulse, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=204, attempted=204)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'execution_step': 'F19', 'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-07-10_00_21_14-4521784545710075667/phases/graph_runner/step-invocations/F19-invoke-8318367438191881465/map-tasks-completion/map-tasks'}), committed=1, attempted=1)
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=, 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=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=MeanByteCount), labels={'original_name': 'map_to_common_key-out0-MeanByteCount', 'output_user_name': 'map_to_common_key-out0'}), committed=18, attempted=18)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'GroupByKey/Reify-out0-ElementCount', 'output_user_name': 'GroupByKey/Reify-out0'}), committed=4, attempted=4)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0'}), committed=4, attempted=4)
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': '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=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/GroupByWindow-out0'}), committed=32, attempted=32)
MetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=8415, attempted=8415)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_WriteShuffle), labels={}), committed=4203, attempted=4203)
MetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=2001, attempted=2001)
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=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ReadShuffle), 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=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=1953, attempted=1953)
MetricResult(key=MetricKey(step=s05, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), 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_StartBundle), labels={}), committed=0, attempted=0)
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=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
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=GroupByKey, 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_ProcessElement), labels={}), committed=200, attempted=200)
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_FinishBundle), labels={}), committed=2001, attempted=2001)
MetricResult(key=MetricKey(step=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessTimers), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), 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/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=1847, attempted=1847)
MetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), 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=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/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=, 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=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0'}), committed=19, attempted=19)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys-out0'}), committed=14, attempted=14)
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=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=MeanByteCount), labels={'original_name': 'metrics-out0-MeanByteCount', 'output_user_name': 'metrics-out0'}), committed=14, attempted=14)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/Map(decode)-out0-MeanByteCount', 'output_user_name': 'Create/Map(decode)-out0'}), committed=14, attempted=14)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps)-out0'}), committed=2, attempted=2)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2020-07-10_00_21_14-4521784545710075667/phases/graph_runner/step-invocations/F18-invoke-8318367438191879053/map-tasks-completion/map-tasks', 'execution_step': 'F18'}), committed=1, attempted=1)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'm_out-out0-MeanByteCount', 'output_user_name': 'm_out-out0'}), committed=15, attempted=15)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'GroupByKey/GroupByWindow-out0-MeanByteCount', 'output_user_name': 'GroupByKey/GroupByWindow-out0'}), committed=25, attempted=25)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'm_out-out0', 'original_name': 'm_out-out0-ElementCount'}), committed=5, attempted=5)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'GroupByKey/Read-out0-ElementCount', 'output_user_name': 'GroupByKey/Read-out0'}), committed=1, attempted=1)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'GroupByKey/GroupByWindow-out0-ElementCount', 'output_user_name': 'GroupByKey/GroupByWindow-out0'}), committed=1, attempted=1)
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_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=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_ProcessElement), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=s07, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=200, attempted=200)
MetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), 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=GroupByKey, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ReadShuffle), labels={}), committed=0, attempted=0)
MetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=182, attempted=182)
MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'GroupByKey/Read-out0-MeanByteCount', 'output_user_name': 'GroupByKey/Read-out0'}), committed=23, attempted=23)
-------------------- >> begin captured stdout << ---------------------
Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2020-07-10_00_21_14-4521784545710075667?project=apache-beam-testing

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

----------------------------------------------------------------------
XML: nosetests-beam_python3.7_sdk.xml
----------------------------------------------------------------------
XML: <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 2 tests in 617.798s

FAILED (failures=1)
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20200710-070709
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:de85d81e72c36f29cc35589a6a45b44756c2b5360fb0962979c9b086f5ec32e7
Deleted: sha256:d4bd2dc03796e54bc62692c0e6070b1da30283093fff74c91bfc948a57a76dfc
Deleted: sha256:240d97d8864250469cae79e1e18ccbebb4e41696695fe34e250113cc991cddf1
Deleted: sha256:2328717f020f26b9f8ef7b3eef90c48938c7fddd960c195f85b6257f2ccb8b39
Deleted: sha256:250fed251db5e4c7bf1ad6a1937049ffc13bf5664c7add862b9e11924111b1cf
Deleted: sha256:ba9040c603f4175707a58456b68a07a693cafb7fb4a0219304e53b4d1215b168
Deleted: sha256:f3be23996ec672d2b61e812ad69bbb0046c5aa66595977d8ff5c11f1c42699f0
Deleted: sha256:c152f28ff9bb239e778dfc8ea0f2da67c973f51de83c570911e25386c6b6a38b
Deleted: sha256:6f7e60177d20121fa2cca781038a7f5dc066e18436afbbb4320b365893aae4f9
Deleted: sha256:02cdd8e8c3e738ed08e198cf6602c4fd547c8bb20d087b32e42fc6eba41a5e70
Deleted: sha256:a47ec930f6d2fd294e4a113f49e8d43b8f985b5259a8912e8a591a0ae3adc162
Deleted: sha256:98451b3f153d83ae06e2f40a4689745b6273c1e98cf263b26b7280dc236bf34e
Deleted: sha256:11d710abde097bd8713d43c6cb57496fd39d7a9fddad820f87104bbc0395d01d
Deleted: sha256:b76632728ab032692a664941dec5e8c2c6c471d6d230844c1aa8e9fc7a4fa58d
Deleted: sha256:fe6df34c0b31974c13c4381ff9c35cd5b1859c74e7909520e7597ec17ecc48f6
Deleted: sha256:25dfd99332aeb7688cd6815554c45c3e677d82ec11cd1a285237db79ee691a53
Deleted: sha256:48da1ed781d75e790d8610ed523c0cecec482f85687e0a8e9d35b96917cb45f9
Deleted: sha256:cab3e79de4bd0b13bef0bd1be175524524334d4abf87a3c8130edb978992b251
Deleted: sha256:ffec1a89b0ae6f60ae17ea70b8d2bf8cd308b9a625218a1f4760332f003331c6
Deleted: sha256:90fca629279231bd3042dece076eed79e962265be7b919a776bedb20faca70ac
Deleted: sha256:ce75478aa75d03104a9de7d0927f26400f181807a214b8f6181c4f5290cf5546
Deleted: sha256:90e3389052993619d4dd6775f51dd9e5363da4a0fed2248f30a62a74e5e0d644
Deleted: sha256:949402af29bd77915102fac6b35cbcbff06df39c36bfd0fdac954820fd3705ef
Deleted: sha256:b8cd091ba150bb1f76456a37ada935735bade29eccc5e15ecf932ea940003649
Deleted: sha256:d7a79d945c46e799bf2fa1c10603bb86f84a61c89140c42a71c14aea56a08535
Deleted: sha256:059639a2d7e3079e9a3e19b3cd4051eb1593d38ff02a27042d3f033dcd375839
Deleted: sha256:ec1ad1064d674dc1257ca69dc5f55d8e2ea324dd1d726959e80c7b8c6dba2e59
Deleted: sha256:e5c717230f7042e7080b1465d2bc87a30476678f355f63dc9357cc91a140610c
Deleted: sha256:d368ba2996053cfac1fe2921a26b49fce99eaa838ee07e2345c36f372ce642ab
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:de85d81e72c36f29cc35589a6a45b44756c2b5360fb0962979c9b086f5ec32e7
  Associated tags:
 - 20200710-070709
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20200710-070709
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk:20200710-070709].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.7_sdk@sha256:de85d81e72c36f29cc35589a6a45b44756c2b5360fb0962979c9b086f5ec32e7].
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 #6564

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


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