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 2024/01/03 07:53:21 UTC

Build failed in Jenkins: beam_PostCommit_Python39 #2730

See <https://ci-beam.apache.org/job/beam_PostCommit_Python39/2730/display/redirect>

Changes:


------------------------------------------
[...truncated 12.10 MB...]
Traceback (most recent call last):
Exception in thread read_state:
Traceback (most recent call last):
  File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
  File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.9/threading.py", line 910, in run
    self.run()
  File "/usr/lib/python3.9/threading.py", line 910, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 265, in run
ERROR:apache_beam.runners.worker.data_plane:Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 669, in _read_inputs
    for elements in elements_iterator:
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 540, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 966, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Socket closed"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45751 {grpc_message:"Socket closed", grpc_status:14, created_time:"2024-01-03T06:43:23.359153989+00:00"}"
>
Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 1049, in pull_responses
    self.run()
  File "/usr/lib/python3.9/threading.py", line 910, in run
    for work_request in self._control_stub.Control(get_responses()):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 540, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 966, in _next
    self._target(*self._args, **self._kwargs)
    for response in responses:
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 686, in <lambda>
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 540, in __next__
    target=lambda: self._read_inputs(elements_iterator),
    raise self
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 669, in _read_inputs
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Socket closed"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44501 {grpc_message:"Socket closed", grpc_status:14, created_time:"2024-01-03T06:43:23.359158782+00:00"}"
>
    return self._next()
    for elements in elements_iterator:
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 966, in _next
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 540, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 966, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Socket closed"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46339 {created_time:"2024-01-03T06:43:23.359146203+00:00", grpc_status:14, grpc_message:"Socket closed"}"
>    raise self

grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Socket closed"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45751 {grpc_message:"Socket closed", grpc_status:14, created_time:"2024-01-03T06:43:23.359153989+00:00"}"
>

> Task :sdks:python:test-suites:portable:py39:postCommitPy39

> Task :sdks:python:test-suites:dataflow:py39:postCommitIT

[gw5] PASSED apache_beam/ml/inference/sklearn_inference_it_test.py::SklearnInference::test_sklearn_mnist_classification_large_model 
apache_beam/ml/inference/sklearn_inference_it_test.py::SklearnInference::test_sklearn_regression 
[gw0] PASSED apache_beam/io/gcp/bigquery_io_read_it_test.py::BigqueryIOReadIT::test_bigquery_read_custom_1M_python 
apache_beam/io/gcp/gcsio_integration_test.py::GcsIOIntegrationTest::test_batch_copy_and_delete 
[gw0] PASSED apache_beam/io/gcp/gcsio_integration_test.py::GcsIOIntegrationTest::test_batch_copy_and_delete 
apache_beam/io/gcp/gcsio_integration_test.py::GcsIOIntegrationTest::test_copy 
[gw0] PASSED apache_beam/io/gcp/gcsio_integration_test.py::GcsIOIntegrationTest::test_copy 
apache_beam/examples/streaming_wordcount_debugging_it_test.py::StreamingWordcountDebuggingIT::test_streaming_wordcount_debugging_it 
[gw0] SKIPPED apache_beam/examples/streaming_wordcount_debugging_it_test.py::StreamingWordcountDebuggingIT::test_streaming_wordcount_debugging_it 
apache_beam/examples/streaming_wordcount_it_test.py::StreamingWordCountIT::test_streaming_wordcount_it 
[gw4] PASSED apache_beam/io/gcp/bigquery_json_it_test.py::BigQueryJsonIT::test_streaming_inserts 
apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_impersonation_it 
[gw3] PASSED apache_beam/dataframe/io_it_test.py::ReadUsingReadGbqTests::test_ReadGbq_with_computation 
apache_beam/io/gcp/pubsub_integration_test.py::PubSubIntegrationTest::test_streaming_data_only 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadTests::test_table_schema_retrieve_with_direct_read 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source 
[gw2] PASSED apache_beam/io/gcp/bigquery_write_it_test.py::BigQueryWriteIntegrationTests::test_big_query_write_without_schema 
apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_deidentification 
[gw6] PASSED apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_file_loads 
apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_streaming_inserts 
[gw5] PASSED apache_beam/ml/inference/sklearn_inference_it_test.py::SklearnInference::test_sklearn_regression 
apache_beam/io/gcp/healthcare/dicomio_integration_test.py::DICOMIoIntegrationTest::test_dicom_search_instances 
[gw7] PASSED apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_aggregation 
apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_enrich 
[gw2] PASSED apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_deidentification 
apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_inspection 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_column_selection 
[gw4] PASSED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_impersonation_it 
apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it 
[gw5] PASSED apache_beam/io/gcp/healthcare/dicomio_integration_test.py::DICOMIoIntegrationTest::test_dicom_search_instances 
apache_beam/io/gcp/healthcare/dicomio_integration_test.py::DICOMIoIntegrationTest::test_dicom_store_instance_from_gcs 
[gw2] PASSED apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_inspection 
apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_user_score_it 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_column_selection 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_column_selection_and_row_restriction 
[gw4] PASSED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it 
apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_it 
[gw3] PASSED apache_beam/io/gcp/pubsub_integration_test.py::PubSubIntegrationTest::test_streaming_data_only 
apache_beam/io/gcp/pubsub_integration_test.py::PubSubIntegrationTest::test_streaming_with_attributes 
[gw0] PASSED apache_beam/examples/streaming_wordcount_it_test.py::StreamingWordCountIT::test_streaming_wordcount_it 
apache_beam/examples/complete/autocomplete_test.py::AutocompleteTest::test_autocomplete_it 
[gw5] PASSED apache_beam/io/gcp/healthcare/dicomio_integration_test.py::DICOMIoIntegrationTest::test_dicom_store_instance_from_gcs 
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_column_selection_and_row_restriction 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_column_selection_and_row_restriction_rows 
[gw0] PASSED apache_beam/examples/complete/autocomplete_test.py::AutocompleteTest::test_autocomplete_it 
apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it 
[gw5] PASSED apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it 
apache_beam/io/fileio_test.py::MatchIntegrationTest::test_transform_on_gcs 
[gw6] PASSED apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_streaming_inserts 
apache_beam/io/gcp/bigquery_test.py::BigQueryFileLoadsIntegrationTests::test_avro_file_load 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_column_selection_and_row_restriction_rows 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_native_datetime 
[gw2] PASSED apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_user_score_it 
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays 
[gw3] PASSED apache_beam/io/gcp/pubsub_integration_test.py::PubSubIntegrationTest::test_streaming_with_attributes 
apache_beam/examples/complete/game/leader_board_it_test.py::LeaderBoardIT::test_leader_board_it 
[gw4] PASSED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_it 
apache_beam/examples/inference/tfx_bsl/tfx_bsl_inference_it_test.py::TFXRunInferenceTests::test_tfx_run_inference_mobilenetv2 
[gw4] SKIPPED apache_beam/examples/inference/tfx_bsl/tfx_bsl_inference_it_test.py::TFXRunInferenceTests::test_tfx_run_inference_mobilenetv2 
apache_beam/io/gcp/datastore/v1new/datastore_write_it_test.py::DatastoreWriteIT::test_datastore_write_limit 
[gw5] PASSED apache_beam/io/fileio_test.py::MatchIntegrationTest::test_transform_on_gcs 
apache_beam/ml/gcp/visionml_test_it.py::VisionMlTestIT::test_text_detection_with_language_hint 
[gw7] PASSED apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_enrich 
apache_beam/examples/fastavro_it_test.py::FastavroIT::test_avro_it 
[gw6] PASSED apache_beam/io/gcp/bigquery_test.py::BigQueryFileLoadsIntegrationTests::test_avro_file_load 
apache_beam/examples/complete/juliaset/juliaset/juliaset_test_it.py::JuliaSetTestIT::test_run_example_with_setup_file 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_native_datetime 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_query <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/-1734967050/bin/python3.9>: No module named build
warning: sdist: standard file not found: should have one of README, README.rst, README.txt, README.md

warning: check: missing required meta-data: url

warning: check: missing meta-data: either (author and author_email) or (maintainer and maintainer_email) should be supplied


[gw2] PASSED apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays 
apache_beam/io/parquetio_it_test.py::TestParquetIT::test_parquetio_it 
[gw5] PASSED apache_beam/ml/gcp/visionml_test_it.py::VisionMlTestIT::test_text_detection_with_language_hint 
apache_beam/ml/inference/onnx_inference_it_test.py::OnnxInference::test_onnx_run_inference_roberta_sentiment_classification 
[gw5] SKIPPED apache_beam/ml/inference/onnx_inference_it_test.py::OnnxInference::test_onnx_run_inference_roberta_sentiment_classification 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_query 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_query_and_filters 
[gw6] PASSED apache_beam/examples/complete/juliaset/juliaset/juliaset_test_it.py::JuliaSetTestIT::test_run_example_with_setup_file 
apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py::ExerciseMetricsPipelineTest::test_metrics_it 
[gw6] SKIPPED apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py::ExerciseMetricsPipelineTest::test_metrics_it 
[gw2] PASSED apache_beam/io/parquetio_it_test.py::TestParquetIT::test_parquetio_it 
apache_beam/transforms/external_it_test.py::ExternalTransformIT::test_job_python_from_python_it 
[gw0] PASSED apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it 
apache_beam/ml/gcp/videointelligenceml_test_it.py::VideoIntelligenceMlTestIT::test_label_detection_with_video_context 
[gw0] SKIPPED apache_beam/ml/gcp/videointelligenceml_test_it.py::VideoIntelligenceMlTestIT::test_label_detection_with_video_context 
apache_beam/ml/inference/base_test.py::RunInferenceBaseTest::test_run_inference_with_side_inputin_streaming 
[gw0] SKIPPED apache_beam/ml/inference/base_test.py::RunInferenceBaseTest::test_run_inference_with_side_inputin_streaming 
[gw7] PASSED apache_beam/examples/fastavro_it_test.py::FastavroIT::test_avro_it 
apache_beam/examples/cookbook/datastore_wordcount_it_test.py::DatastoreWordCountIT::test_datastore_wordcount_it 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_query_and_filters 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_row_restriction 
[gw3] PASSED apache_beam/examples/complete/game/leader_board_it_test.py::LeaderBoardIT::test_leader_board_it 
apache_beam/ml/gcp/naturallanguageml_test_it.py::NaturalLanguageMlTestIT::test_analyzing_syntax 
[gw3] SKIPPED apache_beam/ml/gcp/naturallanguageml_test_it.py::NaturalLanguageMlTestIT::test_analyzing_syntax 
apache_beam/transforms/periodicsequence_it_test.py::PeriodicSequenceIT::test_periodicsequence_outputs_valid_watermarks_it 
[gw3] SKIPPED apache_beam/transforms/periodicsequence_it_test.py::PeriodicSequenceIT::test_periodicsequence_outputs_valid_watermarks_it 
[gw2] PASSED apache_beam/transforms/external_it_test.py::ExternalTransformIT::test_job_python_from_python_it 
[gw7] PASSED apache_beam/examples/cookbook/datastore_wordcount_it_test.py::DatastoreWordCountIT::test_datastore_wordcount_it 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_row_restriction 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_very_selective_filters 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadUsingStorageApiTests::test_iobase_source_with_very_selective_filters 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadNewTypesTests::test_iobase_source 
[gw4] PASSED apache_beam/io/gcp/datastore/v1new/datastore_write_it_test.py::DatastoreWriteIT::test_datastore_write_limit 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadNewTypesTests::test_iobase_source 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadNewTypesTests::test_native_source 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadNewTypesTests::test_native_source 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries 
apache_beam/io/gcp/bigquery_read_it_test.py::ReadInteractiveRunnerTests::test_read_in_interactive_runner 
[gw1] PASSED apache_beam/io/gcp/bigquery_read_it_test.py::ReadInteractiveRunnerTests::test_read_in_interactive_runner 

=============================== warnings summary ===============================
apache_beam/io/gcp/bigquery.py:2603
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2603: DeprecationWarning: invalid escape sequence \#
    """Read data from BigQuery.

apache_beam/io/gcp/bigquery_read_it_test.py::ReadTests::test_native_source
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_read_it_test.py>:170: BeamDeprecationWarning: BigQuerySource is deprecated since 2.25.0. Use ReadFromBigQuery instead.
    beam.io.BigQuerySource(query=self.query, use_standard_sql=True)))

apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_file_loads
apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_streaming_inserts
apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_it
apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it
apache_beam/examples/complete/game/leader_board_it_test.py::LeaderBoardIT::test_leader_board_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/tests/utils.py>:63: PendingDeprecationWarning: Client.dataset is deprecated and will be removed in a future version. Use a string like 'my_project.my_dataset' or a cloud.google.bigquery.DatasetReference object, instead.
    dataset_ref = client.dataset(unique_dataset_name, project=project)

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/tests/utils.py>:100: PendingDeprecationWarning: Client.dataset is deprecated and will be removed in a future version. Use a string like 'my_project.my_dataset' or a cloud.google.bigquery.DatasetReference object, instead.
    table_ref = client.dataset(dataset_id).table(table_id)

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/examples/dataframe/flight_delays.py>:47: FutureWarning: The default value of numeric_only in DataFrame.mean is deprecated. In a future version, it will default to False. In addition, specifying 'numeric_only=None' is deprecated. Select only valid columns or specify the value of numeric_only to silence this warning.
    return airline_df[at_top_airports].mean()

apache_beam/io/gcp/bigquery_read_it_test.py::ReadNewTypesTests::test_native_source
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_read_it_test.py>:706: BeamDeprecationWarning: BigQuerySource is deprecated since 2.25.0. Use ReadFromBigQuery instead.
    beam.io.BigQuerySource(query=self.query, use_standard_sql=True)))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/pytest_postCommitIT-df-py39.xml> -
=========== 83 passed, 49 skipped, 10 warnings in 5680.43s (1:34:40) ===========

FAILURE: Build failed with an exception.

* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/test-suites/direct/common.gradle'> line: 52

* What went wrong:
Execution failed for task ':sdks:python:test-suites:direct:py39:postCommitIT'.
> 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 9.0.

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

For more on this, please refer to https://docs.gradle.org/8.4/userguide/command_line_interface.html#sec:command_line_warnings in the Gradle documentation.

BUILD FAILED in 1h 41m 54s
222 actionable tasks: 156 executed, 62 from cache, 4 up-to-date

Publishing build scan...
https://ge.apache.org/s/psrn5jxhbimto

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_Python39 #2731

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


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