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 2022/05/06 11:24:11 UTC

Build failed in Jenkins: beam_PostCommit_XVR_PythonUsingJava_Dataflow #391

See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_PythonUsingJava_Dataflow/391/display/redirect>

Changes:


------------------------------------------
[...truncated 495.78 KB...]
============================= test session starts ==============================
platform linux -- Python 3.7.12, pytest-4.6.11, py-1.11.0, pluggy-0.13.1
rootdir: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_PythonUsingJava_Dataflow/ws/src/sdks/python,> inifile: pytest.ini
plugins: xdist-1.34.0, timeout-1.4.2, forked-1.4.0, requests-mock-1.9.3
timeout: 4500.0s
timeout method: signal
timeout func_only: False
gw0 I / gw1 I / gw2 I / gw3 I / gw4 I / gw5 I / gw6 I / gw7 I
[gw0] Python 3.7.12 (default, Jan 15 2022, 18:42:10)  -- [GCC 9.3.0]
[gw2] Python 3.7.12 (default, Jan 15 2022, 18:42:10)  -- [GCC 9.3.0]
[gw1] Python 3.7.12 (default, Jan 15 2022, 18:42:10)  -- [GCC 9.3.0]
[gw3] Python 3.7.12 (default, Jan 15 2022, 18:42:10)  -- [GCC 9.3.0]
[gw4] Python 3.7.12 (default, Jan 15 2022, 18:42:10)  -- [GCC 9.3.0]
[gw5] Python 3.7.12 (default, Jan 15 2022, 18:42:10)  -- [GCC 9.3.0]
[gw6] Python 3.7.12 (default, Jan 15 2022, 18:42:10)  -- [GCC 9.3.0]
[gw7] Python 3.7.12 (default, Jan 15 2022, 18:42:10)  -- [GCC 9.3.0]
gw0 [10] / gw1 [10] / gw2 [10] / gw3 [10] / gw4 [10] / gw5 [10] / gw6 [10] / gw7 [10]

scheduling tests via LoadScheduling

apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_combine_globally 
apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_multi_input_output_with_sideinput 
apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_cogroup_by_key 
apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_combine_per_key 
apache_beam/io/external/generate_sequence_test.py::XlangGenerateSequenceTest::test_generate_sequence_java_external_transform 
apache_beam/io/external/generate_sequence_test.py::XlangGenerateSequenceTest::test_generate_sequence_java_class_lookup_payload_builder 
apache_beam/io/external/generate_sequence_test.py::XlangGenerateSequenceTest::test_generate_sequence 
apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_group_by_key 
[gw1] PASSED apache_beam/io/external/generate_sequence_test.py::XlangGenerateSequenceTest::test_generate_sequence_java_external_transform 
[gw4] PASSED apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_combine_globally 
[gw6] PASSED apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_group_by_key 
[gw7] PASSED apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_multi_input_output_with_sideinput 
[gw3] PASSED apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_cogroup_by_key 
[gw0] PASSED apache_beam/io/external/generate_sequence_test.py::XlangGenerateSequenceTest::test_generate_sequence 
apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_partition 
[gw2] FAILED apache_beam/io/external/generate_sequence_test.py::XlangGenerateSequenceTest::test_generate_sequence_java_class_lookup_payload_builder 
apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_prefix 
[gw5] PASSED apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_combine_per_key 
[gw0] PASSED apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_partition 
[gw2] PASSED apache_beam/transforms/validate_runner_xlang_test.py::ValidateRunnerXlangTest::test_prefix 

=================================== FAILURES ===================================
_ XlangGenerateSequenceTest.test_generate_sequence_java_class_lookup_payload_builder _
[gw2] linux -- Python 3.7.12 <https://ci-beam.apache.org/job/beam_PostCommit_XVR_PythonUsingJava_Dataflow/ws/src/build/gradleenv/1922375555/bin/python3.7>

self = <apache_beam.io.external.generate_sequence_test.XlangGenerateSequenceTest testMethod=test_generate_sequence_java_class_lookup_payload_builder>

    @unittest.skipUnless(
        os.environ.get('EXPANSION_SERVICE_TYPE') != 'Python',
        'Java Class Lookup based expansion is not supported by the Python '
        'expansion service')
    def test_generate_sequence_java_class_lookup_payload_builder(self):
      port = os.environ.get('EXPANSION_PORT')
      address = 'localhost:%s' % port
    
      with TestPipeline() as p:
        payload_builder = JavaClassLookupPayloadBuilder(
            'org.apache.beam.sdk.io.GenerateSequence')
        payload_builder.with_constructor_method('from', 1)
        payload_builder.add_builder_method('to', 10)
    
        res = (
            p
            | ExternalTransform(None, payload_builder, expansion_service=address))
>       assert_that(res, equal_to(list(range(1, 10))))

apache_beam/io/external/generate_sequence_test.py:79: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/pipeline.py:596: in __exit__
    self.result = self.run()
apache_beam/testing/test_pipeline.py:114: in run
    False if self.not_use_test_runner_api else test_runner_api))
apache_beam/pipeline.py:573: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/dataflow/test_dataflow_runner.py:71: in run_pipeline
    self.result.cancel()
apache_beam/runners/dataflow/dataflow_runner.py:1687: in cancel
    self.job_id(), 'JOB_STATE_CANCELLED'):
apache_beam/utils/retry.py:253: in wrapper
    return fun(*args, **kwargs)
apache_beam/runners/dataflow/internal/apiclient.py:934: in modify_job_state
    self._client.projects_locations_jobs.Update(request)
apache_beam/runners/dataflow/internal/clients/dataflow/dataflow_v1b3_client.py:858: in Update
    config, request, global_params=global_params)
../../build/gradleenv/1922375555/lib/python3.7/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
../../build/gradleenv/1922375555/lib/python3.7/site-packages/apitools/base/py/base_api.py:737: in ProcessHttpResponse
    self.__ProcessHttpResponse(method_config, http_response, request))
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.dataflow.internal.clients.dataflow.dataflow_v1b3_client.DataflowV1b3.ProjectsLocationsJobsService object at 0x7fbe7b45db50>
method_config = <ApiMethodInfo
 relative_path: 'v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}'
 method_id: 'dataflow.pro...DataflowProjectsLocationsJobsUpdateRequest'
 response_type_name: 'Job'
 request_field: 'job'
 supports_download: False>
http_response = Response(info={'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Fri, 0...apis.com/v1b3/projects/apache-beam-testing/locations/us-central1/jobs/2022-05-06_04_03_47-396779360063093682?alt=json')
request = <DataflowProjectsLocationsJobsUpdateRequest
 job: <Job
 requestedState: RequestedStateValueValuesEnum(JOB_STATE_CANCEL...Files: []>
 jobId: '2022-05-06_04_03_47-396779360063093682'
 location: 'us-central1'
 projectId: 'apache-beam-testing'>

    def __ProcessHttpResponse(self, method_config, http_response, request):
        """Process the given http response."""
        if http_response.status_code not in (http_client.OK,
                                             http_client.CREATED,
                                             http_client.NO_CONTENT):
            raise exceptions.HttpError.FromResponse(
>               http_response, method_config=method_config, request=request)
E           apitools.base.py.exceptions.HttpBadRequestError: HttpError accessing <https://dataflow.googleapis.com/v1b3/projects/apache-beam-testing/locations/us-central1/jobs/2022-05-06_04_03_47-396779360063093682?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Fri, 06 May 2022 11:13:54 GMT', 'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 'transfer-encoding': 'chunked', 'status': '400', 'content-length': '314', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 400,
E               "message": "(d71effd21a5389e9): Workflow modification failed. Causes: (c11b3672c3a2b241): Operation cancel not allowed for job 2022-05-06_04_03_47-396779360063093682. Job is not yet ready for canceling. Please retry in a few minutes.",
E               "status": "FAILED_PRECONDITION"
E             }
E           }
E           >

../../build/gradleenv/1922375555/lib/python3.7/site-packages/apitools/base/py/base_api.py:604: HttpBadRequestError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.runners.portability.stager:stager.py:325 Copying Beam SDK "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_PythonUsingJava_Dataflow/ws/src/sdks/python/build/apache-beam.tar.gz"> to staging location.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:477 Pipeline has additional dependencies to be installed in SDK worker container, consider using the SDK container image pre-building workflow to avoid repetitive installations. Learn more on https://cloud.google.com/dataflow/docs/guides/using-custom-containers#prebuild
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.7 interpreter.
INFO     root:environments.py:380 Default Python SDK image for environment is apache/beam_python3.7_sdk:2.40.0.dev
INFO     root:environments.py:296 Using provided Python SDK container image: gcr.io/cloud-dataflow/v1beta3/python37-fnapi:beam-master-20220407
INFO     root:environments.py:304 Python SDK container image set to "gcr.io/cloud-dataflow/v1beta3/python37-fnapi:beam-master-20220407" for Docker environment
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function pack_combiners at 0x7fbe8be50cb0> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function sort_stages at 0x7fbe8be514d0> ====================
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:471 Defaulting to the temp_location as staging_location: gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:714 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/icedtea-sound-ebvtNFkfFXg4aaYFuDnwKpwDSjzsaZqlqv5iKxPTr-U.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:733 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/icedtea-sound-ebvtNFkfFXg4aaYFuDnwKpwDSjzsaZqlqv5iKxPTr-U.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:714 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/jaccess-ULFTCPsb6cLYZ0f1BG1FQfczmHNaZCx8plXuRDKpBqE.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:733 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/jaccess-ULFTCPsb6cLYZ0f1BG1FQfczmHNaZCx8plXuRDKpBqE.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:714 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/localedata-dUHqyGxaTVCjfTI8MckPYarZ3_mwf62udkxaHi1aKns.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:733 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/localedata-dUHqyGxaTVCjfTI8MckPYarZ3_mwf62udkxaHi1aKns.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:714 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/nashorn-XdUndQGroXOP9NCsfITpBERYcbbGXVHLjbvNWXCh-3A.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:733 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/nashorn-XdUndQGroXOP9NCsfITpBERYcbbGXVHLjbvNWXCh-3A.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:714 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/cldrdata-YqzuKX1QnLCOo0cwjKRdBhGrip_ltIJZg-APT60tUPA.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:733 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/cldrdata-YqzuKX1QnLCOo0cwjKRdBhGrip_ltIJZg-APT60tUPA.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:714 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/dnsns-dhEp186udEF6X6chZus-RJzWRmzlccxx1_btlXWayVI.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:733 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/dnsns-dhEp186udEF6X6chZus-RJzWRmzlccxx1_btlXWayVI.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:714 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/beam-sdks-java-testing-expansion-service-testExpansionService-2.40.0-SNAPSHOT-UWti_U5YCB4XNu2cr-0ODM7Po2khBI1Xqlws4Rt13Rk.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:733 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/beam-sdks-java-testing-expansion-service-testExpansionService-2.40.0-SNAPSHOT-UWti_U5YCB4XNu2cr-0ODM7Po2khBI1Xqlws4Rt13Rk.jar in 4 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:714 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/dataflow_python_sdk.tar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:733 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/dataflow_python_sdk.tar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:714 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/pipeline.pb...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:733 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0506110341-455835-zxz6xnth.1651835021.456270/pipeline.pb in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:893 Create job: <Job
                                                                           clientRequestId: '20220506110341457209-5768'
                                                                           createTime: '2022-05-06T11:03:49.555614Z'
                                                                           currentStateTime: '1970-01-01T00:00:00Z'
                                                                           id: '2022-05-06_04_03_47-396779360063093682'
                                                                           location: 'us-central1'
                                                                           name: 'beamapp-jenkins-0506110341-455835-zxz6xnth'
                                                                           projectId: 'apache-beam-testing'
                                                                           stageStates: []
                                                                           startTime: '2022-05-06T11:03:49.555614Z'
                                                                           steps: []
                                                                           tempFiles: []
                                                                           type: TypeValueValuesEnum(JOB_TYPE_BATCH, 1)>
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:895 Created job with id: [2022-05-06_04_03_47-396779360063093682]
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:896 Submitted job: 2022-05-06_04_03_47-396779360063093682
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:902 To access the Dataflow monitoring console, please navigate to https://console.cloud.google.com/dataflow/jobs/us-central1/2022-05-06_04_03_47-396779360063093682?project=apache-beam-testing
=============================== warnings summary ===============================
apache_beam/io/filesystems_test.py:54
apache_beam/io/filesystems_test.py:54
apache_beam/io/filesystems_test.py:54
apache_beam/io/filesystems_test.py:54
apache_beam/io/filesystems_test.py:54
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_PythonUsingJava_Dataflow/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
apache_beam/io/filesystems_test.py:62
apache_beam/io/filesystems_test.py:62
apache_beam/io/filesystems_test.py:62
apache_beam/io/filesystems_test.py:62
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_PythonUsingJava_Dataflow/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

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_XVR_PythonUsingJava_Dataflow/ws/src/sdks/python/pytest_xlangValidateRunner.xml> -
======== 1 failed, 9 passed, 1 skipped, 10 warnings in 1231.56 seconds =========

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerPythonUsingJava FAILED

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1315663.
Stopping expansion service pid: 1315664.

> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20220506105230
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:959111fa4d67449f7284f252d2443d9a7fe8b88801bbb971ab5ed43103527075
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20220506105230]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:959111fa4d67449f7284f252d2443d9a7fe8b88801bbb971ab5ed43103527075]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20220506105230] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:959111fa4d67449f7284f252d2443d9a7fe8b88801bbb971ab5ed43103527075])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:959111fa4d67449f7284f252d2443d9a7fe8b88801bbb971ab5ed43103527075
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:959111fa4d67449f7284f252d2443d9a7fe8b88801bbb971ab5ed43103527075
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:959111fa4d67449f7284f252d2443d9a7fe8b88801bbb971ab5ed43103527075].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20220506105230
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a30b1316b3d1f26e00597f2bc73efd15ddf13f32dec15bca90d79ecc4256026
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20220506105230]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a30b1316b3d1f26e00597f2bc73efd15ddf13f32dec15bca90d79ecc4256026]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20220506105230] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a30b1316b3d1f26e00597f2bc73efd15ddf13f32dec15bca90d79ecc4256026])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a30b1316b3d1f26e00597f2bc73efd15ddf13f32dec15bca90d79ecc4256026
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a30b1316b3d1f26e00597f2bc73efd15ddf13f32dec15bca90d79ecc4256026
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a30b1316b3d1f26e00597f2bc73efd15ddf13f32dec15bca90d79ecc4256026].

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerPythonUsingJava'.
> 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 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.4/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 31m 44s
139 actionable tasks: 97 executed, 36 from cache, 6 up-to-date

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

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_XVR_PythonUsingJava_Dataflow #392

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


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