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/11/15 23:50:26 UTC

Build failed in Jenkins: beam_PostCommit_Py_ValCont #9943

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

Changes:

[noreply] [Playground] Move Playground in GKE and Infrastructure change (#23928)

[noreply] Fix broken notebook (#24179)

[noreply] Add error reporting for BatchConverter match failure (#24022)

[noreply] Update automation to use Go 1.19 (#24175)

[noreply] Fix broken json for notebook (#24183)

[noreply] Using Teardown context instead of deprecated finalize (#24180)

[noreply] [Python]Support pipe operator as Union (PEP -604) (#24106)

[noreply] Add custom inference function support to the PyTorch model handler


------------------------------------------
[...truncated 1.94 MB...]
self = <apache_beam.runners.dataflow.test_dataflow_runner.TestDataflowRunner object at 0x7f48151549a0>
pipeline = <apache_beam.pipeline.Pipeline object at 0x7f4815176c80>
options = <apache_beam.options.pipeline_options.PipelineOptions object at 0x7f4815154550>

    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().run_pipeline(pipeline, options)
      if self.result.has_job:
        # TODO(markflyhigh)(https://github.com/apache/beam/issues/18254): Use
        # print since Nose dosen't show logs in some cases.
        print('Worker logs: %s' % self.build_console_url(options))
        _LOGGER.info('Console log: ')
        _LOGGER.info(self.build_console_url(options))
    
      try:
>       self.wait_until_in_state(PipelineState.RUNNING)

apache_beam/runners/dataflow/test_dataflow_runner.py:62: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.dataflow.test_dataflow_runner.TestDataflowRunner object at 0x7f48151549a0>
expected_state = 'RUNNING', timeout = 600

    def wait_until_in_state(self, expected_state, timeout=WAIT_IN_STATE_TIMEOUT):
      """Wait until Dataflow pipeline enters a certain state."""
      consoleUrl = (
          "Console URL: https://console.cloud.google.com/dataflow/"
          f"<regionId>/{self.result.job_id()}?project=<projectId>")
      if not self.result.has_job:
        _LOGGER.error(consoleUrl)
        raise IOError('Failed to get the Dataflow job id.')
    
      start_time = time.time()
      while time.time() - start_time <= timeout:
        job_state = self.result.state
        if self.result.is_in_terminal_state() or job_state == expected_state:
          return job_state
        time.sleep(5)
      _LOGGER.error(consoleUrl)
>     raise RuntimeError(
          'Timeout after %d seconds while waiting for job %s '
          'enters expected state %s. Current state is %s.' %
          (timeout, self.result.job_id(), expected_state, self.result.state))
E     RuntimeError: Timeout after 600 seconds while waiting for job 2022-11-15_15_32_05-6337918189257815308 enters expected state RUNNING. Current state is PENDING.

apache_beam/runners/dataflow/test_dataflow_runner.py:103: RuntimeError

During handling of the above exception, another exception occurred:

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

    @pytest.mark.it_validatescontainer
    def test_wordcount_it_with_use_sibling_sdk_workers(self):
>     self._run_wordcount_it(wordcount.run, experiment='use_sibling_sdk_workers')

apache_beam/examples/wordcount_it_test.py:113: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/wordcount_it_test.py:153: in _run_wordcount_it
    run_wordcount(
apache_beam/examples/wordcount.py:87: in run
    with beam.Pipeline(options=pipeline_options) as p:
apache_beam/pipeline.py:600: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:553: in run
    self._options).run(False)
apache_beam/pipeline.py:577: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/dataflow/test_dataflow_runner.py:73: in run_pipeline
    self.result.cancel()
apache_beam/runners/dataflow/dataflow_runner.py:1611: in cancel
    if not self._runner.dataflow_client.modify_job_state(
apache_beam/utils/retry.py:275: in wrapper
    return fun(*args, **kwargs)
apache_beam/runners/dataflow/internal/apiclient.py:952: in modify_job_state
    self._client.projects_locations_jobs.Update(request)
apache_beam/runners/dataflow/internal/clients/dataflow/dataflow_v1b3_client.py:857: in Update
    return self._RunMethod(
../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py:731: in _RunMethod
    return self.ProcessHttpResponse(method_config, http_response, request)
../../build/gradleenv/2050596098/lib/python3.10/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 0x7f4814ee7af0>
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': 'Tue, 1...pis.com/v1b3/projects/apache-beam-testing/locations/us-central1/jobs/2022-11-15_15_32_05-6337918189257815308?alt=json')
request = <DataflowProjectsLocationsJobsUpdateRequest
 job: <Job
 requestedState: RequestedStateValueValuesEnum(JOB_STATE_CANCEL...iles: []>
 jobId: '2022-11-15_15_32_05-6337918189257815308'
 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-11-15_15_32_05-6337918189257815308?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Tue, 15 Nov 2022 23:42:06 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': '283', '-content-encoding': 'gzip'}>, content <{
E             "error": {
E               "code": 400,
E               "message": "(fc39f6baa303e03a): Workflow modification failed. Causes: (8788ccbc4e74b938): Cannot perform operation 'cancel' on Job: 2022-11-15_15_32_05-6337918189257815308. Job has no backend assigned..",
E               "status": "FAILED_PRECONDITION"
E             }
E           }
E           >

../../build/gradleenv/2050596098/lib/python3.10/site-packages/apitools/base/py/base_api.py:603: HttpBadRequestError
=============================== warnings summary ===============================
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
../../build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

../../build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py:17
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/google/api_core/operations_v1/abstract_operations_client.py>:17: DeprecationWarning: The distutils package is deprecated and slated for removal in Python 3.12. Use setuptools or check PEP 632 for potential alternatives
    from distutils import util

../../build/gradleenv/2050596098/lib/python3.10/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/2050596098/lib/python3.10/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):

apache_beam/typehints/pandas_type_compatibility_test.py:67
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:67: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    }).set_index(pd.Int64Index(range(123, 223), name='an_index')),

apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:90: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(123, 223), name='an_index'),

apache_beam/typehints/pandas_type_compatibility_test.py:91
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:91: FutureWarning: pandas.Int64Index is deprecated and will be removed from pandas in a future version. Use pandas.Index with the appropriate dtype instead.
    pd.Int64Index(range(475, 575), name='another_index'),

apache_beam/examples/wordcount_it_test.py: 33 warnings
apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py: 2 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/build/gradleenv/2050596098/lib/python3.10/site-packages/httplib2/__init__.py>:147: DeprecationWarning: ssl.PROTOCOL_TLS is deprecated
    context = ssl.SSLContext(DEFAULT_TLS_VERSION)

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Py_ValCont/ws/src/sdks/python/pytest-beam_python3.10_sdk.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it_with_use_sibling_sdk_workers - apitools.base.py.exceptions.HttpBadRequestError: HttpError accessing <https://dataflow.googleapis.com/v1b3/projects/apache-beam-testing/locations/us-central1/jobs/2022-11-15_15_32_05-6337918189257815308?alt=json>: response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 'application/json; charset=UTF-8', 'date': 'Tue, 15 Nov 2022 23:42:06 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': '283', '-content-encoding': 'gzip'}>, content <{
  "error": {
    "code": 400,
    "message": "(fc39f6baa303e03a): Workflow modification failed. Causes: (8788ccbc4e74b938): Cannot perform operation 'cancel' on Job: 2022-11-15_15_32_05-6337918189257815308. Job has no backend assigned..",
    "status": "FAILED_PRECONDITION"
  }
}
>
======= 1 failed, 4 passed, 5 skipped, 42 warnings in 3097.30s (0:51:37) =======
cleanup_container
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.10_sdk:20221115-225535574867037
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_python3.10_sdk@sha256:4f363b3c76572135343822e4eb259e7cf2cd2fb973f8d244e4bba277b6c84ce4
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python310_sdk/beam_python_prebuilt_sdk:3957ea3f-3aee-428f-b2de-b03bd503ecc6
Untagged: us.gcr.io/apache-beam-testing/jenkins/prebuild_python310_sdk/beam_python_prebuilt_sdk@sha256:961da1e7cc64bbc6fb3f1dd13a118a654d9271a45a642a48ef2435861fc0830b
Deleted: sha256:48a0e108c27a97861fff1893db0d9ddd36207212c5e228eb1b918d9d88e32534
Deleted: sha256:d0c06d30c73e7d8f1c9685370e64f209e6a29947c8c149d3da7c2f3fd68d6bea
Deleted: sha256:64283a3cae43e45575393cb07484e58a44aa5c588775269ed1fb98f11a8ac0ff
Deleted: sha256:ab18f269474d740f711212b3d47abe4b59e6ac266030cb5d2f8faac45096f582
Deleted: sha256:a634303c6210e2b68cfd870c71f3c3175f210241be947edfe9b29d6f3038f916
Deleted: sha256:d05cc033e135e4a101b118082505ca721d0c317da38ee81a4cecd301811d5784
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.10_sdk@sha256:4f363b3c76572135343822e4eb259e7cf2cd2fb973f8d244e4bba277b6c84ce4
  Associated tags:
 - 20221115-225535574867037
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_python3.10_sdk:20221115-225535574867037
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.10_sdk:20221115-225535574867037].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_python3.10_sdk@sha256:4f363b3c76572135343822e4eb259e7cf2cd2fb973f8d244e4bba277b6c84ce4].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python310_sdk/beam_python_prebuilt_sdk@sha256:961da1e7cc64bbc6fb3f1dd13a118a654d9271a45a642a48ef2435861fc0830b
  Associated tags:
 - 3957ea3f-3aee-428f-b2de-b03bd503ecc6
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python310_sdk/beam_python_prebuilt_sdk:3957ea3f-3aee-428f-b2de-b03bd503ecc6].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python310_sdk/beam_python_prebuilt_sdk@sha256:961da1e7cc64bbc6fb3f1dd13a118a654d9271a45a642a48ef2435861fc0830b].
Digests:
- us.gcr.io/apache-beam-testing/jenkins/prebuild_python310_sdk/beam_python_prebuilt_sdk@sha256:4963bcc57debfdc087877146c9a31e49719e0a8a64164c03db4fbea56b99ae28
  Associated tags:
 - 7d29d12f-4a53-4cab-87ed-1619c3890199
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python310_sdk/beam_python_prebuilt_sdk:7d29d12f-4a53-4cab-87ed-1619c3890199].
Deleted [us.gcr.io/apache-beam-testing/jenkins/prebuild_python310_sdk/beam_python_prebuilt_sdk@sha256:4963bcc57debfdc087877146c9a31e49719e0a8a64164c03db4fbea56b99ae28].
Removed the container

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

FAILURE: Build completed with 2 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: 363

* 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.
==============================================================================

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: 363

* What went wrong:
Execution failed for task ':sdks:python:test-suites:dataflow:py310: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.
==============================================================================

* 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.5.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 9m 54s
62 actionable tasks: 51 executed, 4 from cache, 7 up-to-date

Publishing build scan...
https://gradle.com/s/4z6jg6bpmnowa

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 #9944

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


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