You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@beam.apache.org by GitBox <gi...@apache.org> on 2022/08/05 12:09:53 UTC

[GitHub] [beam] yeandy opened a new issue, #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

yeandy opened a new issue, #22605:
URL: https://github.com/apache/beam/issues/22605

   ### What happened?
   
   Seeing this [error](https://ci-beam.apache.org/job/beam_PostCommit_Python38/2960/testReport/apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test/ExerciseMetricsPipelineTest/test_metrics_it/) in `test_metrics_it`. There were no changes at the time of first failure (run 2960).
   ```
   self = <apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest testMethod=test_metrics_it>
   
       @pytest.mark.it_postcommit
       def test_metrics_it(self):
         result = self.run_pipeline()
         errors = metric_result_matchers.verify_all(
             result.metrics().all_metrics(),
             dataflow_exercise_metrics_pipeline.metric_matchers())
   >     self.assertFalse(errors, str(errors))
   E     AssertionError: "Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-ElementCount').  attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'MeanByteCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-MeanByteCount').  attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'GroupByKey/GroupByWindow-out0').  (label_key: 'original_name' label_value: 'GroupByKey/GroupByWindow-out0-ElementCount').  attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'MeanByteCount' (label_key: 'output_user_name' label_value: 'GroupBy
 Key/GroupByWindow-out0').  (label_key: 'original_name' label_value: 'GroupByKey/GroupByWindow-out0-MeanByteCount').  attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-ElementCount').  attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'MeanByteCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-MeanByteCount').  attempted: a value greater than <0> committed: a value greater than <0>\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)\nMetricR
 esult(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=4, min=0, max=100), attempted=DistributionResult(sum=100, count=4, min=0, max=100))\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalVcpuTime), labels={'original_name': 'Service-cpu_num_seconds'}), committed=690, attempted=690)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalMemoryUsage), labels={'original_name': 'Service-mem_mb_seconds'}), committed=2830268, attempted=2830268)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalPdUsage), labels={'original_name': 'Service-pd_gb_seconds'}), committed=8637, attempted=8637)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalSsdUsage), labels={'original_name': 'Serv
 ice-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=None, attempted=None)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=BillableShuffleDataProcessed), labels={'original_name': 'Service-shuffle_service_chargeable_gb'}), committed=None, attempted=None)\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=TotalGpuTime), labels={'original_name': 'Service-gpu_num_seconds'}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentShuffleSlotCount), labels={'original_name': 'dax-shuffle-c
 urrent-shuffle-slots'}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentVcpuCount), labels={'original_name': 'Service-cpu_num'}), committed=2, attempted=2)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentMemoryUsage), labels={'original_name': 'Service-mem_mb'}), committed=8192, attempted=8192)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentPdUsage), labels={'original_name': 'Service-pd_gb'}), committed=25, attempted=25)\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=CurrentGpuCount), labels={'original_name': 'Service-gpu_num'}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow
 /v1b3, name=PeakShuffleSlotCount), labels={'original_name': 'dax-shuffle-peak-shuffle-slots'}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2022-08-03_02_53_39-1286231266624024730/phases/graph_runner/step-invocations/F16-invoke-13644712812717340681/map-tasks-completion/map-tasks', 'execution_step': 'F16'}), committed=1, attempted=1)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/Impulse-out0-ElementCount', 'outpu
 t_user_name': 'Create/Impulse-out0'}), committed=1, attempted=1)\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=46, attempted=46)\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={'original_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0-MeanByteCount', 'output_user_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0'}), committed=14, attempted=14)\nMetricResult(key=Me
 tricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0'}), committed=27, attempted=27)\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/FlatMap(<lambda at core.py:3481>)-out0-ElementCount', 'output_user_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCoun
 t), labels={'output_user_name': 'Create/Impulse-out0', 'original_name': 'Create/Impulse-out0-MeanByteCount'}), committed=13, attempted=13)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0'}), 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=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/FlatMap(<lambda at core.py:3481>), metric=MetricName(namespace=dataflow/v1b
 3, name=ExecutionTime_StartBundle), 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/FlatMap(<lambda at core.py:3481>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:3481>), 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, na
 me=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_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'execution_step': 'F15', 'original_name': 'dax_workflow_stage_progress_/workflows/wf-2022-08-03_02_53_39-1286231266624024730/phases/graph_runner/step-invocations/F15-invoke-13644712812717339153/map-tasks-completion/map-tasks'}), committed=1, attempted=1)\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_us
 er_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': 'map_to_common_key-out0', 'original_name': 'map_to_common_key-out0-ElementCount'}), committed=4, attempted=4)\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=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={'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=, 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=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=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=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=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0'}), committed=19, attempted=19)\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-ElementCoun
 t'}), committed=4, attempted=4)\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=945, attempted=945)\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/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=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(name
 space=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=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, 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_FinishBundle), 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=data
 flow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)\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/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_ProcessElement), labels={}), committed=3992, attempted=3992)\nMetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=1000, attempted=1000)\nMetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'execution_step': 'F14', 'original_name': 'dax_workflow_stage_progress_/workfl
 ows/wf-2022-08-03_02_53_39-1286231266624024730/phases/graph_runner/step-invocations/F14-invoke-13644712812717340437/map-tasks-completion/map-tasks'}), 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={'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=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/Read-out0-MeanByteCount'
 , 'output_user_name': 'GroupByKey/Read-out0'}), committed=16, attempted=16)\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_StartBundle), labels={}), committed=0, attempted=0)\nMetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)" is not false : Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-ElementCount').  attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'MeanByteCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').  (label_key: 'original_name' 
 label_value: 'GroupByKey/Reify-out0-MeanByteCount').  attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'GroupByKey/GroupByWindow-out0').  (label_key: 'original_name' label_value: 'GroupByKey/GroupByWindow-out0-ElementCount').  attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'MeanByteCount' (label_key: 'output_user_name' label_value: 'GroupByKey/GroupByWindow-out0').  (label_key: 'original_name' label_value: 'GroupByKey/GroupByWindow-out0-MeanByteCount').  attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-ElementCount').  attempted: a value greater than <0> committed: a value greater tha
 n <0>Unable to match metrics for matcher  name: 'MeanByteCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-MeanByteCount').  attempted: a value greater than <0> committed: a value greater than <0>
   E     Actual MetricResults:
   E     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)
   E     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=4, min=0, max=100), attempted=DistributionResult(sum=100, count=4, min=0, max=100))
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalVcpuTime), labels={'original_name': 'Service-cpu_num_seconds'}), committed=690, attempted=690)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalMemoryUsage), labels={'original_name': 'Service-mem_mb_seconds'}), committed=2830268, attempted=2830268)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalPdUsage), labels={'original_name': 'Service-pd_gb_seconds'}), committed=8637, attempted=8637)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalSsdUsage), labels={'original_name': 'Service-pd_ssd_gb_seconds'}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalShuffleDataProcessed), labels={'original_name': 'Service-shuffle_service_actual_gb'}), committed=None, attempted=None)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=BillableShuffleDataProcessed), labels={'original_name': 'Service-shuffle_service_chargeable_gb'}), committed=None, attempted=None)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalStreamingDataProcessed), labels={'original_name': 'Service-streaming_service_gb'}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=TotalGpuTime), labels={'original_name': 'Service-gpu_num_seconds'}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentShuffleSlotCount), labels={'original_name': 'dax-shuffle-current-shuffle-slots'}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentVcpuCount), labels={'original_name': 'Service-cpu_num'}), committed=2, attempted=2)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentMemoryUsage), labels={'original_name': 'Service-mem_mb'}), committed=8192, attempted=8192)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentPdUsage), labels={'original_name': 'Service-pd_gb'}), committed=25, attempted=25)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentSsdUsage), labels={'original_name': 'Service-pd_ssd_gb'}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=CurrentGpuCount), labels={'original_name': 'Service-gpu_num'}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=PeakShuffleSlotCount), labels={'original_name': 'dax-shuffle-peak-shuffle-slots'}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'original_name': 'dax_workflow_stage_progress_/workflows/wf-2022-08-03_02_53_39-1286231266624024730/phases/graph_runner/step-invocations/F16-invoke-13644712812717340681/map-tasks-completion/map-tasks', 'execution_step': 'F16'}), committed=1, attempted=1)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0'}), committed=4, attempted=4)
   E     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)
   E     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=46, attempted=46)
   E     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)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0-MeanByteCount', 'output_user_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0'}), committed=14, attempted=14)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0'}), committed=27, attempted=27)
   E     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)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0-ElementCount', 'output_user_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0'}), committed=4, attempted=4)
   E     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=13, attempted=13)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0'}), committed=4, attempted=4)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:3481>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:3481>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/FlatMap(<lambda at core.py:3481>), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/AddRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'execution_step': 'F15', 'original_name': 'dax_workflow_stage_progress_/workflows/wf-2022-08-03_02_53_39-1286231266624024730/phases/graph_runner/step-invocations/F15-invoke-13644712812717339153/map-tasks-completion/map-tasks'}), committed=1, attempted=1)
   E     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)
   E     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)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'map_to_common_key-out0', 'original_name': 'map_to_common_key-out0-ElementCount'}), committed=4, attempted=4)
   E     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=4, attempted=4)
   E     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)
   E     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)
   E     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=4, attempted=4)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'metrics-out0', 'original_name': 'metrics-out0-ElementCount'}), committed=4, attempted=4)
   E     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)
   E     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)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0'}), committed=19, attempted=19)
   E     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=4, attempted=4)
   E     MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=945, attempted=945)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/RemoveRandomKeys, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=map_to_common_key, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/Map(decode), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/FlatMap(restore_timestamps), metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=3992, attempted=3992)
   E     MetricResult(key=MetricKey(step=metrics, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=1000, attempted=1000)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionStepProgress), labels={'execution_step': 'F14', 'original_name': 'dax_workflow_stage_progress_/workflows/wf-2022-08-03_02_53_39-1286231266624024730/phases/graph_runner/step-invocations/F14-invoke-13644712812717340437/map-tasks-completion/map-tasks'}), committed=1, attempted=1)
   E     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)
   E     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)
   E     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)
   E     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=16, attempted=16)
   E     MetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_ProcessElement), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_StartBundle), labels={}), committed=0, attempted=0)
   E     MetricResult(key=MetricKey(step=m_out, metric=MetricName(namespace=dataflow/v1b3, name=ExecutionTime_FinishBundle), labels={}), committed=0, attempted=0)
   ```
   
   ### Issue Priority
   
   Priority: 2
   
   ### Issue Component
   
   Component: sdk-py-core


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] yeandy commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
yeandy commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1213435298

   Ran test on Dataflow at [PR681](https://ci-beam.apache.org/job/beam_PostCommit_Python39/681/changes) (commit 63d0f0d31ab633b1ecd8fec273ecf647585d3423) and passed, at [PR661](https://ci-beam.apache.org/job/beam_PostCommit_Python39/661/changes) (commit 033c30487434e44d85ff181bff4b5a84392e0b61) and passed, and at master at the time of writing (18ada2b043ad7319684cf8a12f2911e0a855cb43) and passed.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] lukecwik commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
lukecwik commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1355272913

   Note that beam_fn_api uses Dataflow runner v2 as of https://github.com/apache/beam/pull/24513, is there a difference in the job graphs being generated between the two now?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] ahmedabu98 commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
ahmedabu98 commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1347254270

   .take-issue


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] Abacn commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
Abacn commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1347154410

   Looks like it happens again since December: https://ci-beam.apache.org/view/PostCommit/job/beam_PostCommit_Python38/3485/testReport/


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] TheNeuralBit commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
TheNeuralBit commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1209581890

   I pulled out some data from the exception. Here is the assertion:
   ```
   Unable to match metrics for matcher  name: 'ElementCount'                          
     (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').                                                                                                                                                                 
     (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-ElementCount').  attempted: a value greater than <0> committed: a value greater than <0> 
   Unable to match metrics for matcher  name: 'MeanByteCount'                         
     (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').            
     (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-MeanByteCount').  attempted: a value greater than <0> committed: a value greater than <0> 
   Unable to match metrics for matcher  name: 'ElementCount'                          
     (label_key: 'output_user_name' label_value: 'GroupByKey/GroupByWindow-out0'). 
     (label_key: 'original_name' label_value: 'GroupByKey/GroupByWindow-out0-ElementCount').  attempted: a value greater than <0> committed: a value greater than <0> 
   Unable to match metrics for matcher  name: 'MeanByteCount'                         
     (label_key: 'output_user_name' label_value: 'GroupByKey/GroupByWindow-out0'). 
     (label_key: 'original_name' label_value: 'GroupByKey/GroupByWindow-out0-MeanByteCount').  attempted: a value greater than <0> committed: a value greater than <0> 
   Unable to match metrics for matcher  name: 'ElementCount'                          
     (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').            
     (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-ElementCount').  attempted: a value greater than <0> committed: a value greater than <0> 
   Unable to match metrics for matcher  name: 'MeanByteCount'                         
     (label_key: 'output_user_name' label_value: 'GroupByKey/Reify-out0').            
     (label_key: 'original_name' label_value: 'GroupByKey/Reify-out0-MeanByteCount').  attempted: a value greater than <0> committed: a value greater than <0> 
   ```
   
   And here are the actual metrics, with just the "ElementCount" and "MeanByteCount" items:
   ```
   Actual MetricResults:                                                           
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0'}), committed=4, attempted=4)
   E     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)
   E     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=46, attempted=46)
   E     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)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0-MeanByteCount', 'output_user_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0'}), committed=14, attempted=14)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/Map(reify_timestamps)-out0'}), committed=27, attempted=27)
   E     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)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0-ElementCount', 'output_user_name': 'Create/FlatMap(<lambda at core.py:3481>)-out0'}), committed=4, attempted=4)
   E     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=13, attempted=13)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0'}), committed=4, attempted=4)
   E     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)
   E     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)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'map_to_common_key-out0', 'original_name': 'map_to_common_key-out0-ElementCount'}), committed=4, attempted=4)
   E     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=4, attempted=4)
   E     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)
   E     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)
   E     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=4, attempted=4)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'output_user_name': 'metrics-out0', 'original_name': 'metrics-out0-ElementCount'}), committed=4, attempted=4)
   E     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)
   E     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)
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=MeanByteCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0-MeanByteCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Read-out0'}), committed=19, attempted=19)
   E     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=4, attempted=4)
   E     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)
   E     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)
   E     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)
   E     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=16, attempted=16)
   ```
   
   Looking at just the first item from the assertion (Reify ElementCount), we can see there is a corresponding metric result, but both original_name and output_user_name have a prefix, `Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/`:
   ```
   E     MetricResult(key=MetricKey(step=, metric=MetricName(namespace=dataflow/v1b3, name=ElementCount), labels={'original_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0-ElementCount', 'output_user_name': 'Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/GroupByKey/Reify-out0'}), committed=4, attempted=4)
   ```
   
   Is that what's causing the failure?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] kennknowles commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by "kennknowles (via GitHub)" <gi...@apache.org>.
kennknowles commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1428720840

   Is this still being actively worked on or would you unassign?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] yeandy commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
yeandy commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1206375324

   Will look to reproduce at an earlier commit to look for regressions.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] yeandy commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
yeandy commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1206375390

   .take-issue


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] yeandy commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
yeandy commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1209606647

   Yeah, it looks to be the case. Extra `Create/MaybeReshuffle/Reshuffle/ReshufflePerKey/` being added. Let me try to repro a few commits earlier than this 


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] ahmedabu98 commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by "ahmedabu98 (via GitHub)" <gi...@apache.org>.
ahmedabu98 commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1490659979

   I'm not actively working on this


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] kennknowles commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
kennknowles commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1341250232

   @yeandy are you actively working on this?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] yeandy commented on issue #22605: [Bug]: Beam Python failure for dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest.test_metrics_it

Posted by GitBox <gi...@apache.org>.
yeandy commented on issue #22605:
URL: https://github.com/apache/beam/issues/22605#issuecomment-1341282202

   No, unassigned myself.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org