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/08/14 18:27:43 UTC

Build failed in Jenkins: beam_PostCommit_XVR_Dataflow #1072

See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Dataflow/1072/display/redirect>

Changes:


------------------------------------------
[...truncated 674.29 KB...]
[gw4] linux -- Python 3.6.8 <https://ci-beam.apache.org/job/beam_PostCommit_XVR_Dataflow/ws/src/build/gradleenv/1922375555/bin/python3.6>

self = <apache_beam.transforms.validate_runner_xlang_test.ValidateRunnerXlangTest testMethod=test_cogroup_by_key>
test_pipeline = None

    @pytest.mark.xlang_transforms
    def test_cogroup_by_key(self, test_pipeline=None):
      CrossLanguageTestPipelines().run_cogroup_by_key(
>         test_pipeline or self.create_pipeline())

apache_beam/transforms/validate_runner_xlang_test.py:269: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/transforms/validate_runner_xlang_test.py:164: in run_cogroup_by_key
    assert_that(res, equal_to(['0:1,2,4', '1:3,5,6']))
apache_beam/pipeline.py:586: 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:565: 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
 createTime: '2021-08-14T18:17:37.070550Z'
 currentState: CurrentStateValueValuesEnum(JOB...021-08-14T18:17:37.070550Z'
 steps: []
 tempFiles: []
 type: TypeValueValuesEnum(JOB_TYPE_BATCH, 1)> at 0x7ff2425d39e8>
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. Causes: Job appears to be stuck. Several workers have failed to start up in a row, and no worker has successfully started up for this job. Last error reported: Unable to pull container image due to error: image pull request failed with error: Error response from daemon: manifest for us.gcr.io/apache-beam-testing/java-postcommit-it/java:20210814180111 not found: manifest unknown: Failed to fetch "20210814180111" from request "/v2/apache-beam-testing/java-postcommit-it/java/manifests/20210814180111".. This is likely due to an invalid SDK container image URL. Please verify any provided SDK container image is valid and that Dataflow workers have permissions to pull image..

apache_beam/runners/dataflow/dataflow_runner.py:1635: DataflowRuntimeException
------------------------------ Captured log call -------------------------------
INFO     apache_beam.runners.portability.stager:stager.py:300 Copying Beam SDK "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Dataflow/ws/src/sdks/python/build/apache-beam.tar.gz"> to staging location.
WARNING  root:environments.py:374 Make sure that locally built Python SDK docker image has Python 3.6 interpreter.
INFO     root:environments.py:380 Default Python SDK image for environment is apache/beam_python3.6_sdk:2.33.0.dev
INFO     root:environments.py:296 Using provided Python SDK container image: gcr.io/cloud-dataflow/v1beta3/python36-fnapi:beam-master-20210809
INFO     root:environments.py:304 Python SDK container image set to "gcr.io/cloud-dataflow/v1beta3/python36-fnapi:beam-master-20210809" for Docker environment
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:650 ==================== <function pack_combiners at 0x7ff2447baae8> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:650 ==================== <function sort_stages at 0x7ff2447b22f0> ====================
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:452 Defaulting to the temp_location as staging_location: gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/icedtea-sound-Bdoi2wYa757-fzq5vconCy4SSQ22ZaOq7yuC98fKPs8.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:650 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/icedtea-sound-Bdoi2wYa757-fzq5vconCy4SSQ22ZaOq7yuC98fKPs8.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/jaccess-CMbK-IOdQPLKHEqCuDnE-yBk-VpbtVT-hgjbHRUGO78.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:650 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/jaccess-CMbK-IOdQPLKHEqCuDnE-yBk-VpbtVT-hgjbHRUGO78.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/localedata-ae5Z0L6ak4922fztWeWy7ajiWXdG3ubNrwerJRFoFj0.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:650 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/localedata-ae5Z0L6ak4922fztWeWy7ajiWXdG3ubNrwerJRFoFj0.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/nashorn-XHtz_UehGpYcLTOrATrTnMNVUgEVa_ttoWkPxnVfqTo.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:650 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/nashorn-XHtz_UehGpYcLTOrATrTnMNVUgEVa_ttoWkPxnVfqTo.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/cldrdata-k07I6K9W3X5KTQbcDIEsqM0LXyM18f0eR6IaJw-P_xk.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:650 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/cldrdata-k07I6K9W3X5KTQbcDIEsqM0LXyM18f0eR6IaJw-P_xk.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/dnsns-RGhCDg3GVOQVC2r6ka2N0hmI4eqQH6VobuoAnQ74MnE.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:650 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/dnsns-RGhCDg3GVOQVC2r6ka2N0hmI4eqQH6VobuoAnQ74MnE.jar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/beam-sdks-java-testing-expansion-service-testExpansionService-2.33.0-SNAPSHOT-Qh-QSpCLAcatcpH7t_5-FhPyRZREHK49Ot5iWF2HwIQ.jar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:650 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/beam-sdks-java-testing-expansion-service-testExpansionService-2.33.0-SNAPSHOT-Qh-QSpCLAcatcpH7t_5-FhPyRZREHK49Ot5iWF2HwIQ.jar in 5 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/dataflow_python_sdk.tar...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:650 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/dataflow_python_sdk.tar in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:631 Starting GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/pipeline.pb...
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:650 Completed GCS upload to gs://dataflow-staging-us-central1-77b801c0838aee13391c0d1885860494/beamapp-jenkins-0814181728-915485.1628965048.916347/pipeline.pb in 0 seconds.
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:797 Create job: <Job
                                                                           createTime: '2021-08-14T18:17:37.070550Z'
                                                                           currentStateTime: '1970-01-01T00:00:00Z'
                                                                           id: '2021-08-14_11_17_36-9483226992428941484'
                                                                           location: 'us-central1'
                                                                           name: 'beamapp-jenkins-0814181728-915485'
                                                                           projectId: 'apache-beam-testing'
                                                                           stageStates: []
                                                                           startTime: '2021-08-14T18:17:37.070550Z'
                                                                           steps: []
                                                                           tempFiles: []
                                                                           type: TypeValueValuesEnum(JOB_TYPE_BATCH, 1)>
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:799 Created job with id: [2021-08-14_11_17_36-9483226992428941484]
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:800 Submitted job: 2021-08-14_11_17_36-9483226992428941484
INFO     apache_beam.runners.dataflow.internal.apiclient:apiclient.py:806 To access the Dataflow monitoring console, please navigate to https://console.cloud.google.com/dataflow/jobs/us-central1/2021-08-14_11_17_36-9483226992428941484?project=apache-beam-testing
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-08-14_11_17_36-9483226992428941484 is in state JOB_STATE_RUNNING
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:39.757Z: JOB_MESSAGE_DETAILED: Autoscaling is enabled for job 2021-08-14_11_17_36-9483226992428941484. The number of workers will be between 1 and 1000.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:39.850Z: JOB_MESSAGE_DETAILED: Autoscaling was automatically enabled for job 2021-08-14_11_17_36-9483226992428941484.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:42.034Z: JOB_MESSAGE_BASIC: Worker configuration: e2-standard-2 in us-central1-a.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:42.778Z: JOB_MESSAGE_DETAILED: Expanding SplittableParDo operations into optimizable parts.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:42.814Z: JOB_MESSAGE_DETAILED: Expanding CollectionToSingleton operations into optimizable parts.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:42.888Z: JOB_MESSAGE_DETAILED: Expanding CoGroupByKey operations into optimizable parts.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:42.924Z: JOB_MESSAGE_DEBUG: Combiner lifting skipped for step assert_that/Group/_CoGBKImpl/GroupByKey: GroupByKey not followed by a combiner.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:42.957Z: JOB_MESSAGE_DEBUG: Combiner lifting skipped for step ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK: GroupByKey not followed by a combiner.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:42.998Z: JOB_MESSAGE_DETAILED: Expanding GroupByKey operations into optimizable parts.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.036Z: JOB_MESSAGE_DEBUG: Annotating graph with Autotuner information.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.090Z: JOB_MESSAGE_DETAILED: Fusing adjacent ParDo, Read, Write, and Flatten operations
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.128Z: JOB_MESSAGE_DEBUG: Inserted coder converter after flatten ref_AppliedPTransform_assert_that-Group-_CoGBKImpl-Flatten_26
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.163Z: JOB_MESSAGE_DETAILED: Unzipping flatten ref_AppliedPTransform_assert_that-Group-_CoGBKImpl-Flatten_26 for input ref_AppliedPTransform_assert_that-Group-_CoGBKImpl-Tag-0-_24.None
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.195Z: JOB_MESSAGE_DETAILED: Fusing unzipped copy of assert_that/Group/_CoGBKImpl/Flatten/OutputIdentity, through flatten assert_that/Group/_CoGBKImpl/Flatten, into producer assert_that/Group/_CoGBKImpl/Tag[0]
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.218Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Group/_CoGBKImpl/MapTuple(collect_values) into assert_that/Group/_CoGBKImpl/GroupByKey/Read
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.239Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Group/RestoreTags into assert_that/Group/_CoGBKImpl/MapTuple(collect_values)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.273Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Unkey into assert_that/Group/RestoreTags
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.304Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Match into assert_that/Unkey
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.345Z: JOB_MESSAGE_DETAILED: Unzipping flatten ref_AppliedPTransform_assert_that-Group-_CoGBKImpl-Flatten_26-u16 for input ref_AppliedPTransform_assert_that-Group-_CoGBKImpl-Flatten_26.None-c14
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.374Z: JOB_MESSAGE_DETAILED: Fusing unzipped copy of assert_that/Group/_CoGBKImpl/GroupByKey/Write, through flatten assert_that/Group/_CoGBKImpl/Flatten/Unzipped-1, into producer assert_that/Group/_CoGBKImpl/Flatten/OutputIdentity
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.407Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Group/_CoGBKImpl/Flatten/OutputIdentity into assert_that/Group/_CoGBKImpl/Tag[1]
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.430Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Group/_CoGBKImpl/GroupByKey/Write into assert_that/Group/_CoGBKImpl/Flatten/OutputIdentity
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.464Z: JOB_MESSAGE_DETAILED: Unzipping flatten external_1ExternalTransform-beam-transforms-xlang-test-cgbk--CoGroupByKey-Flatten for input external_1ExternalTransform-beam-transforms-xlang-test-cgbk--CoGroupByKey-MakeUnionTable0-ParMultiDo-Construct.output
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.499Z: JOB_MESSAGE_DETAILED: Fusing unzipped copy of ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Write, through flatten ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/Flatten, into producer ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/MakeUnionTable0/ParMultiDo(ConstructUnionTable)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.535Z: JOB_MESSAGE_DETAILED: Fusing consumer ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/ConstructCoGbkResultFn/ParMultiDo(ConstructCoGbkResult) into ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Read
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.568Z: JOB_MESSAGE_DETAILED: Fusing consumer ExternalTransform(beam:transforms:xlang:test:cgbk)/ParDo(Anonymous)/ParMultiDo(Anonymous) into ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/ConstructCoGbkResultFn/ParMultiDo(ConstructCoGbkResult)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.601Z: JOB_MESSAGE_DETAILED: Fusing consumer Map(<lambda at validate_runner_xlang_test.py:163>) into ExternalTransform(beam:transforms:xlang:test:cgbk)/ParDo(Anonymous)/ParMultiDo(Anonymous)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.629Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/WindowInto(WindowIntoFn) into Map(<lambda at validate_runner_xlang_test.py:163>)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.660Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/ToVoidKey into assert_that/WindowInto(WindowIntoFn)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.688Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Group/_CoGBKImpl/Tag[1] into assert_that/ToVoidKey
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.721Z: JOB_MESSAGE_DETAILED: Fusing consumer ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Write into ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/MakeUnionTable1/ParMultiDo(ConstructUnionTable)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.743Z: JOB_MESSAGE_DETAILED: Fusing consumer create_col2/FlatMap(<lambda at core.py:2968>) into create_col2/Impulse
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.774Z: JOB_MESSAGE_DETAILED: Fusing consumer create_col2/Map(decode) into create_col2/FlatMap(<lambda at core.py:2968>)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.798Z: JOB_MESSAGE_DETAILED: Fusing consumer ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/MakeUnionTable0/ParMultiDo(ConstructUnionTable) into create_col2/Map(decode)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.821Z: JOB_MESSAGE_DETAILED: Fusing consumer create_col1/FlatMap(<lambda at core.py:2968>) into create_col1/Impulse
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.847Z: JOB_MESSAGE_DETAILED: Fusing consumer create_col1/Map(decode) into create_col1/FlatMap(<lambda at core.py:2968>)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.883Z: JOB_MESSAGE_DETAILED: Fusing consumer ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/MakeUnionTable1/ParMultiDo(ConstructUnionTable) into create_col1/Map(decode)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.906Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Create/FlatMap(<lambda at core.py:2968>) into assert_that/Create/Impulse
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.930Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Create/Map(decode) into assert_that/Create/FlatMap(<lambda at core.py:2968>)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:43.969Z: JOB_MESSAGE_DETAILED: Fusing consumer assert_that/Group/_CoGBKImpl/Tag[0] into assert_that/Create/Map(decode)
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.012Z: JOB_MESSAGE_DEBUG: Workflow config is missing a default resource spec.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.051Z: JOB_MESSAGE_DEBUG: Adding StepResource setup and teardown to workflow graph.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.107Z: JOB_MESSAGE_DEBUG: Adding workflow start and stop steps.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.140Z: JOB_MESSAGE_DEBUG: Assigning stage ids.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.296Z: JOB_MESSAGE_DEBUG: Executing wait step start28
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.372Z: JOB_MESSAGE_BASIC: Executing operation ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Create
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.396Z: JOB_MESSAGE_BASIC: Executing operation assert_that/Group/_CoGBKImpl/GroupByKey/Create
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.422Z: JOB_MESSAGE_DEBUG: Starting worker pool setup.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.459Z: JOB_MESSAGE_BASIC: Starting 1 workers in us-central1-a...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.503Z: JOB_MESSAGE_BASIC: Finished operation ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Create
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.519Z: JOB_MESSAGE_BASIC: Finished operation assert_that/Group/_CoGBKImpl/GroupByKey/Create
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.570Z: JOB_MESSAGE_DEBUG: Value "ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Session" materialized.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.602Z: JOB_MESSAGE_DEBUG: Value "assert_that/Group/_CoGBKImpl/GroupByKey/Session" materialized.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.631Z: JOB_MESSAGE_BASIC: Executing operation create_col1/Impulse+create_col1/FlatMap(<lambda at core.py:2968>)+create_col1/Map(decode)+ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/MakeUnionTable1/ParMultiDo(ConstructUnionTable)+ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Write
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.659Z: JOB_MESSAGE_BASIC: Executing operation create_col2/Impulse+create_col2/FlatMap(<lambda at core.py:2968>)+create_col2/Map(decode)+ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/MakeUnionTable0/ParMultiDo(ConstructUnionTable)+ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Write
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:17:44.694Z: JOB_MESSAGE_BASIC: Executing operation assert_that/Create/Impulse+assert_that/Create/FlatMap(<lambda at core.py:2968>)+assert_that/Create/Map(decode)+assert_that/Group/_CoGBKImpl/Tag[0]+assert_that/Group/_CoGBKImpl/Flatten/OutputIdentity+assert_that/Group/_CoGBKImpl/GroupByKey/Write
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:18:20.073Z: JOB_MESSAGE_BASIC: Your project already contains 100 Dataflow-created metric descriptors, so new user metrics of the form custom.googleapis.com/* will not be created. However, all user metrics are also available in the metric dataflow.googleapis.com/job/user_counter. If you rely on the custom metrics, you can delete old / unused metric descriptors. See https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.list and https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.delete
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:18:24.170Z: JOB_MESSAGE_DETAILED: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running stage(s).
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:19:14.558Z: JOB_MESSAGE_WARNING: A worker was unable to start up.  Error: Unable to pull container image due to error: image pull request failed with error: Error response from daemon: manifest for us.gcr.io/apache-beam-testing/java-postcommit-it/java:20210814180111 not found: manifest unknown: Failed to fetch "20210814180111" from request "/v2/apache-beam-testing/java-postcommit-it/java/manifests/20210814180111".. This is likely due to an invalid SDK container image URL. Please verify any provided SDK container image is valid and that Dataflow workers have permissions to pull image.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:19:43.854Z: JOB_MESSAGE_DETAILED: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running stage(s).
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:20:29.048Z: JOB_MESSAGE_WARNING: A worker was unable to start up.  Error: Unable to pull container image due to error: image pull request failed with error: Error response from daemon: manifest for us.gcr.io/apache-beam-testing/java-postcommit-it/java:20210814180111 not found: manifest unknown: Failed to fetch "20210814180111" from request "/v2/apache-beam-testing/java-postcommit-it/java/manifests/20210814180111".. This is likely due to an invalid SDK container image URL. Please verify any provided SDK container image is valid and that Dataflow workers have permissions to pull image.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:20:58.569Z: JOB_MESSAGE_DETAILED: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running stage(s).
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:21:42.094Z: JOB_MESSAGE_WARNING: A worker was unable to start up.  Error: Unable to pull container image due to error: image pull request failed with error: Error response from daemon: manifest for us.gcr.io/apache-beam-testing/java-postcommit-it/java:20210814180111 not found: manifest unknown: Failed to fetch "20210814180111" from request "/v2/apache-beam-testing/java-postcommit-it/java/manifests/20210814180111".. This is likely due to an invalid SDK container image URL. Please verify any provided SDK container image is valid and that Dataflow workers have permissions to pull image.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:22:06.749Z: JOB_MESSAGE_DETAILED: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running stage(s).
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:22:48.832Z: JOB_MESSAGE_WARNING: A worker was unable to start up.  Error: Unable to pull container image due to error: image pull request failed with error: Error response from daemon: manifest for us.gcr.io/apache-beam-testing/java-postcommit-it/java:20210814180111 not found: manifest unknown: Failed to fetch "20210814180111" from request "/v2/apache-beam-testing/java-postcommit-it/java/manifests/20210814180111".. This is likely due to an invalid SDK container image URL. Please verify any provided SDK container image is valid and that Dataflow workers have permissions to pull image.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:23:14.971Z: JOB_MESSAGE_DETAILED: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running stage(s).
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:24:05.042Z: JOB_MESSAGE_WARNING: A worker was unable to start up.  Error: Unable to pull container image due to error: image pull request failed with error: Error response from daemon: manifest for us.gcr.io/apache-beam-testing/java-postcommit-it/java:20210814180111 not found: manifest unknown: Failed to fetch "20210814180111" from request "/v2/apache-beam-testing/java-postcommit-it/java/manifests/20210814180111".. This is likely due to an invalid SDK container image URL. Please verify any provided SDK container image is valid and that Dataflow workers have permissions to pull image.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:24:05.072Z: JOB_MESSAGE_ERROR: Workflow failed. Causes: Job appears to be stuck. Several workers have failed to start up in a row, and no worker has successfully started up for this job. Last error reported: Unable to pull container image due to error: image pull request failed with error: Error response from daemon: manifest for us.gcr.io/apache-beam-testing/java-postcommit-it/java:20210814180111 not found: manifest unknown: Failed to fetch "20210814180111" from request "/v2/apache-beam-testing/java-postcommit-it/java/manifests/20210814180111".. This is likely due to an invalid SDK container image URL. Please verify any provided SDK container image is valid and that Dataflow workers have permissions to pull image..
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:24:05.133Z: JOB_MESSAGE_BASIC: Finished operation create_col1/Impulse+create_col1/FlatMap(<lambda at core.py:2968>)+create_col1/Map(decode)+ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/MakeUnionTable1/ParMultiDo(ConstructUnionTable)+ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Write
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:24:05.133Z: JOB_MESSAGE_BASIC: Finished operation create_col2/Impulse+create_col2/FlatMap(<lambda at core.py:2968>)+create_col2/Map(decode)+ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/MakeUnionTable0/ParMultiDo(ConstructUnionTable)+ExternalTransform(beam:transforms:xlang:test:cgbk)/CoGroupByKey/GBK/Write
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:24:05.133Z: JOB_MESSAGE_BASIC: Finished operation assert_that/Create/Impulse+assert_that/Create/FlatMap(<lambda at core.py:2968>)+assert_that/Create/Map(decode)+assert_that/Group/_CoGBKImpl/Tag[0]+assert_that/Group/_CoGBKImpl/Flatten/OutputIdentity+assert_that/Group/_CoGBKImpl/GroupByKey/Write
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:24:05.211Z: JOB_MESSAGE_DETAILED: Cleaning up.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:24:05.308Z: JOB_MESSAGE_DEBUG: Starting worker pool teardown.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:24:05.337Z: JOB_MESSAGE_BASIC: Stopping worker pool...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:26:53.637Z: JOB_MESSAGE_BASIC: Worker pool stopped.
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:236 2021-08-14T18:26:53.668Z: JOB_MESSAGE_DEBUG: Tearing down pending resources...
INFO     apache_beam.runners.dataflow.dataflow_runner:dataflow_runner.py:191 Job 2021-08-14_11_17_36-9483226992428941484 is in state JOB_STATE_FAILED
=============================== warnings summary ===============================
apache_beam/io/filesystems_test.py:54
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_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
  <https://ci-beam.apache.org/job/beam_PostCommit_XVR_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_Dataflow/ws/src/sdks/python/pytest_xlangValidateRunner.xml> -
=============== 7 failed, 1 passed, 2 warnings in 646.56 seconds ===============

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

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 9671.
Stopping expansion service pid: 9674.

> Task :runners:google-cloud-dataflow-java:cleanUpDockerImages FAILED
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20210814180111
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8a09af1103ebc943fea17b8b2ab18757d6928a6140458bfb7176321d3051fa9f
ERROR: (gcloud.container.images.untag) Image could not be found: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20210814180111]

FAILURE: Build completed with 2 failures.

1: Task 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.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_Dataflow/ws/src/runners/google-cloud-dataflow-java/build.gradle'> line: 279

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:cleanUpDockerImages'.
> Process 'command 'gcloud'' 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 27m 7s
113 actionable tasks: 84 executed, 25 from cache, 4 up-to-date

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

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_Dataflow #1073

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


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