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 2021/09/13 18:24:26 UTC

Build failed in Jenkins: beam_PostCommit_Py_ValCont #8243

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

Changes:

[rohde.samuel] [BEAM-12842] Add timestamp to test work item to deflake

[suztomo] [BEAM-12873] HL7v2IO: to leave schematizedData null, not empty


------------------------------------------
[...truncated 147.77 KB...]
          prebuild_sdk_container_engine='cloud_build')

apache_beam/examples/wordcount_it_test.py:64: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/wordcount_it_test.py:108: in _run_wordcount_it
    run_wordcount(
apache_beam/examples/wordcount.py:89: in run
    output | 'Write' >> WriteToText(known_args.output)
apache_beam/pipeline.py:587: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:539: in run
    return Pipeline.from_runner_api(
apache_beam/pipeline.py:566: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/dataflow/test_dataflow_runner.py:65: in run_pipeline
    self.result.wait_until_finish(duration=wait_duration)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <DataflowPipelineResult <Job
 clientRequestId: '20210913182131150071-7102'
 createTime: '2021-09-13T18:21:32.680208Z'
...021-09-13T18:21:32.680208Z'
 steps: []
 tempFiles: []
 type: TypeValueValuesEnum(JOB_TYPE_BATCH, 1)> at 0x7f05755b7640>
duration = None

    def wait_until_finish(self, duration=None):
      if not self.is_in_terminal_state():
        if not self.has_job:
          raise IOError('Failed to get the Dataflow job id.')
    
        thread = threading.Thread(
            target=DataflowRunner.poll_for_job_completion,
            args=(self._runner, self, duration))
    
        # Mark the thread as a daemon thread so a keyboard interrupt on the main
        # thread will terminate everything. This is also the reason we will not
        # use thread.join() to wait for the polling thread.
        thread.daemon = True
        thread.start()
        while thread.is_alive():
          time.sleep(5.0)
    
        # TODO: Merge the termination code in poll_for_job_completion and
        # is_in_terminal_state.
        terminated = self.is_in_terminal_state()
        assert duration or terminated, (
            'Job did not reach to a terminal state after waiting indefinitely.')
    
        if terminated and self.state != PipelineState.DONE:
          # TODO(BEAM-1290): Consider converting this to an error log based on
          # theresolution of the issue.
>         raise DataflowRuntimeException(
              'Dataflow pipeline failed. State: %s, Error:\n%s' %
              (self.state, getattr(self._runner, 'last_error_msg', None)),
              self)
E         apache_beam.runners.dataflow.dataflow_runner.DataflowRuntimeException: Dataflow pipeline failed. State: FAILED, Error:
E         Workflow failed.

apache_beam/runners/dataflow/dataflow_runner.py:1632: DataflowRuntimeException
____ WordCountIT.test_wordcount_it_with_prebuilt_sdk_container_local_docker ____
[gw0] linux -- Python 3.8.5 <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/-1734967051/bin/python3.8>

self = <apache_beam.examples.wordcount_it_test.WordCountIT testMethod=test_wordcount_it_with_prebuilt_sdk_container_local_docker>

    @pytest.mark.it_validatescontainer
    def test_wordcount_it_with_prebuilt_sdk_container_local_docker(self):
>     self._run_wordcount_it(
          wordcount.run,
          experiment='beam_fn_api',
          prebuild_sdk_container_engine='local_docker')

apache_beam/examples/wordcount_it_test.py:57: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/wordcount_it_test.py:108: in _run_wordcount_it
    run_wordcount(
apache_beam/examples/wordcount.py:89: in run
    output | 'Write' >> WriteToText(known_args.output)
apache_beam/pipeline.py:587: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:539: in run
    return Pipeline.from_runner_api(
apache_beam/pipeline.py:566: in run
    return self.runner.run_pipeline(self, self._options)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.dataflow.test_dataflow_runner.TestDataflowRunner object at 0x7f0575554940>
pipeline = <apache_beam.pipeline.Pipeline object at 0x7f057593bbe0>
options = <apache_beam.options.pipeline_options.PipelineOptions object at 0x7f0575978580>

    def run_pipeline(self, pipeline, options):
      """Execute test pipeline and verify test matcher"""
      test_options = options.view_as(TestOptions)
      on_success_matcher = test_options.on_success_matcher
      wait_duration = test_options.wait_until_finish_duration
      is_streaming = options.view_as(StandardOptions).streaming
    
      # [BEAM-1889] Do not send this to remote workers also, there is no need to
      # send this option to remote executors.
      test_options.on_success_matcher = None
    
      self.result = super(TestDataflowRunner,
                          self).run_pipeline(pipeline, options)
      if self.result.has_job:
        # TODO(markflyhigh)(BEAM-1890): Use print since Nose dosen't show logs
        # in some cases.
        print('Worker logs: %s' % self.build_console_url(options))
    
      try:
        self.wait_until_in_state(PipelineState.RUNNING)
    
        if is_streaming and not wait_duration:
          _LOGGER.warning('Waiting indefinitely for streaming job.')
        self.result.wait_until_finish(duration=wait_duration)
    
        if on_success_matcher:
          from hamcrest import assert_that as hc_assert_that
>         hc_assert_that(self.result, pickler.loads(on_success_matcher))
E         AssertionError: 
E         Expected: (Test pipeline expected terminated in state: DONE and Expected checksum is 33535a832b7db6d78389759577d4ff495980b9c0)
E              but: Test pipeline expected terminated in state: DONE Test pipeline job terminated in state: FAILED

apache_beam/runners/dataflow/test_dataflow_runner.py:69: AssertionError
______________ ExerciseMetricsPipelineTest.test_metrics_fnapi_it _______________
[gw0] linux -- Python 3.8.5 <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/-1734967051/bin/python3.8>

self = <apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline_test.ExerciseMetricsPipelineTest testMethod=test_metrics_fnapi_it>

    @pytest.mark.it_postcommit
    @pytest.mark.it_validatescontainer
    def test_metrics_fnapi_it(self):
      result = self.run_pipeline(experiment='beam_fn_api')
      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  namespace: 'apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn' name: 'total_values' step: 'metrics' attempted: <100> committed: <100>Unable to match metrics for matcher  name: 'ExecutionTime_StartBundle' step: 'metrics' attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'ExecutionTime_ProcessElement' step: 'metrics' attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'ExecutionTime_FinishBundle' step: 'metrics' attempted: a value greater than <0> committed: a value greater than <0>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>Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'metrics-out0').  (label_key: 'original_name' label_value: 'metrics-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: 'metrics-out0').  (label_key: 'original_name' label_value: 'metrics-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>Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Read-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Read-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/Read-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Read-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: 'map_to_common_key-out0').  (label_key: 'original_name' label_value: 'map_to_common_key-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: 'map_to_common_key-out0').  (label_key: 'original_name' label_value: 'map_to_common_key-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/Read-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Read-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/Read-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Read-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:\n" is not false : Unable to match metrics for matcher  namespace: 'apache_beam.runners.dataflow.dataflow_exercise_metrics_pipeline.UserMetricsDoFn' name: 'total_values' step: 'metrics' attempted: <100> committed: <100>Unable to match metrics for matcher  name: 'ExecutionTime_StartBundle' step: 'metrics' attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'ExecutionTime_ProcessElement' step: 'metrics' attempted: a value greater than <0> committed: a value greater than <0>Unable to match metrics for matcher  name: 'ExecutionTime_FinishBundle' step: 'metrics' attempted: a value greater than <0> committed: a value greater than <0>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>Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'metrics-out0').  (label_key: 'original_name' label_value: 'metrics-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: 'metrics-out0').  (label_key: 'original_name' label_value: 'metrics-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>Unable to match metrics for matcher  name: 'ElementCount' (label_key: 'output_user_name' label_value: 'GroupByKey/Read-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Read-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/Read-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Read-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: 'map_to_common_key-out0').  (label_key: 'original_name' label_value: 'map_to_common_key-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: 'map_to_common_key-out0').  (label_key: 'original_name' label_value: 'map_to_common_key-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/Read-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Read-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/Read-out0').  (label_key: 'original_name' label_value: 'GroupByKey/Read-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>
E     Actual MetricResults:

apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py:60: AssertionError
=============================== warnings summary ===============================
apache_beam/io/filesystems_test.py:54
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/io/filesystems_test.py>:54: DeprecationWarning: invalid escape sequence \c
    self.assertIsNone(FileSystems.get_scheme('c:\\abc\cdf'))  # pylint: disable=anomalous-backslash-in-string

apache_beam/io/filesystems_test.py:62
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/io/filesystems_test.py>:62: DeprecationWarning: invalid escape sequence \d
    self.assertTrue(isinstance(FileSystems.get_filesystem('c:\\abc\def'),  # pylint: disable=anomalous-backslash-in-string

<https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/-1734967051/lib/python3.8/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/pytest-beam_python3.8_sdk.xml> -
==================== 4 failed, 3 warnings in 551.55 seconds ====================
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20210913-181233714496878
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:76918bef6dd4a69e889b9e805a0da11b35b4a38b85a0f255a576355f98bb7224
docker images --format '{{.Repository}}:{{.Tag}}' | grep $PREBUILD_SDK_CONTAINER_REGISTRY_PATH
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:49f1325a-effc-4de6-bfa4-8e756f3cbb67
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:47d57d74ca77e43e38c46df84e3b12ffed6b564fa8e18e23ea884e1eefb74e0a
Deleted: sha256:43ca3c8473f6f21fe6ca1fba8f435b7b1e845a73f773667e57730c9d7b4587b1
Deleted: sha256:a7629d16ef8920970aa9586de881d60eb2db126b3372b3fce187d6ece717c7d3
Deleted: sha256:9d7a0e6bad789ecf37def8cffff3fe8ec3117567d5d94ce01f14442faa197b45
Deleted: sha256:e28ed087d5aaef6a680e50cc43ffc6cffd2d779016951a4f0d8cfb21ec5bc517
Deleted: sha256:44da2ba5e98dc62a96d769f1fdb789b6663f4bd3941e5ee49e63eb0bcefb72ec
Deleted: sha256:c3d283891d647e7c20163619edf9f22c188733f4c7032e4bf40293d652a74ce2
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:76918bef6dd4a69e889b9e805a0da11b35b4a38b85a0f255a576355f98bb7224
  Associated tags:
 - 20210913-181233714496878
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20210913-181233714496878
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk:20210913-181233714496878].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.8_sdk@sha256:76918bef6dd4a69e889b9e805a0da11b35b4a38b85a0f255a576355f98bb7224].
gcloud container images list-tags $PREBUILD_SDK_CONTAINER_REGISTRY_PATH/beam_python_prebuilt_sdk  --format="get(digest)"
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:47d57d74ca77e43e38c46df84e3b12ffed6b564fa8e18e23ea884e1eefb74e0a
  Associated tags:
 - 49f1325a-effc-4de6-bfa4-8e756f3cbb67
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:49f1325a-effc-4de6-bfa4-8e756f3cbb67].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:47d57d74ca77e43e38c46df84e3b12ffed6b564fa8e18e23ea884e1eefb74e0a].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:66a8357a93cb06625d940d9d73a7aa9825426c97a07eb42c5bcf1da8ef6c7fcc
  Associated tags:
 - 44c5bfa6-97f1-49c4-aafd-a622946b910e
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk:44c5bfa6-97f1-49c4-aafd-a622946b910e].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python38_sdk/beam_python_prebuilt_sdk@sha256:66a8357a93cb06625d940d9d73a7aa9825426c97a07eb42c5bcf1da8ef6c7fcc].
Removed the container

> Task :sdks:python:test-suites:dataflow:py38:validatesContainer FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 276

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py37:validatesContainer'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 276

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py36:validatesContainer'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

3: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/test-suites/dataflow/common.gradle'> line: 276

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py38:validatesContainer'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.8.3/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 23m 56s
44 actionable tasks: 40 executed, 4 up-to-date

Publishing build scan...
https://gradle.com/s/gqfemqv75v5b4

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' 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 #8244

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


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