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/10/16 21:42:01 UTC

Build failed in Jenkins: beam_PostCommit_Python39 #980

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

Changes:


------------------------------------------
[...truncated 44.22 MB...]
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:66: 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:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:89: 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:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/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(475, 575), name='another_index'),

apache_beam/dataframe/io_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_io_read_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_read_it_test.py: 7 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2484: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

apache_beam/dataframe/io_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_io_read_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_read_it_test.py: 7 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2486: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/dataframe/io_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_io_read_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_read_it_test.py: 7 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2510: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it
apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_it
apache_beam/examples/complete/game/leader_board_it_test.py::LeaderBoardIT::test_leader_board_it
apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_file_loads
apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_streaming_inserts
  <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/complete/game/game_stats_it_test.py: 2 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/examples/complete/game/leader_board_it_test.py: 2 warnings
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_test.py: 6 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1991: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    is_streaming_pipeline = p.options.view_as(StandardOptions).streaming

apache_beam/examples/complete/game/game_stats_it_test.py: 2 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/examples/complete/game/leader_board_it_test.py: 2 warnings
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_test.py: 6 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1997: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_test.py: 2 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1987: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self.table_reference.projectId = pcoll.pipeline.options.view_as(

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_test.py: 3 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 3 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1126: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self.project = self.project or p.options.view_as(GoogleCloudOptions).project

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_test.py: 3 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 3 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1133: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = p.options.view_as(GoogleCloudOptions).temp_location

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_test.py: 3 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 3 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1135: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).job_name or 'AUTOMATIC_JOB_NAME')

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/dataframe/io_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 1 warning
apache_beam/io/gcp/bigquery_read_it_test.py: 9 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2528: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    project_id = pcoll.pipeline.options.view_as(GoogleCloudOptions).project

apache_beam/dataframe/io_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 1 warning
apache_beam/io/gcp/bigquery_read_it_test.py: 9 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2549: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_aggregation
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_enrich
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/dataframe/io.py>:659: FutureWarning: WriteToFiles is experimental.
    return pcoll | fileio.WriteToFiles(

apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_aggregation
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_enrich
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/fileio.py>:590: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).temp_location or

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: Dropping of nuisance columns in DataFrame reductions (with 'numeric_only=None') is deprecated; in a future version this will raise TypeError.  Select only valid columns before calling the reduction.
    return airline_df[at_top_airports].mean()

apache_beam/io/gcp/bigquery_test.py::BigQueryStreamingInsertTransformIntegrationTests::test_multiple_destinations_transform
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_test.py>:1684: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    streaming = self.test_pipeline.options.view_as(StandardOptions).streaming

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>:171: BeamDeprecationWarning: BigQuerySource is deprecated since 2.25.0. Use ReadFromBigQuery instead.
    beam.io.BigQuerySource(query=self.query, use_standard_sql=True)))

apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_deidentification
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/ml/gcp/cloud_dlp_it_test.py>:74: FutureWarning: MaskDetectedDetails is experimental.
    | MaskDetectedDetails(

apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_inspection
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/ml/gcp/cloud_dlp_it_test.py>:85: FutureWarning: InspectForDetails is experimental.
    | InspectForDetails(

apache_beam/ml/inference/sklearn_inference_it_test.py::SklearnInference::test_sklearn_regression
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/examples/inference/sklearn_japanese_housing_regression.py>:128: FutureWarning: SklearnModelHandlerPandas is experimental. No backwards-compatibility guarantees.
    model_loader = SklearnModelHandlerPandas(

apache_beam/ml/inference/sklearn_inference_it_test.py::SklearnInference::test_sklearn_regression
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/dill/_dill.py>:472: FutureWarning: SklearnModelHandlerPandas is experimental. No backwards-compatibility guarantees.
    obj = StockUnpickler.load(self)

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>:646: 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_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_read_it_test.py>:761: FutureWarning: ReadAllFromBigQuery is experimental.
    | beam.io.ReadAllFromBigQuery())

apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2657: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2658: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    project = pcoll.pipeline.options.view_as(GoogleCloudOptions).project

apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2671: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    options=pcoll.pipeline.options,

-- 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> -
=========================== short test summary info ============================
FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_impersonation_it
FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it
FAILED apache_beam/io/fileio_test.py::MatchIntegrationTest::test_transform_on_gcs
FAILED apache_beam/io/gcp/pubsub_integration_test.py::PubSubIntegrationTest::test_streaming_data_only
FAILED apache_beam/io/gcp/pubsub_integration_test.py::PubSubIntegrationTest::test_streaming_with_attributes
ERROR apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_impersonation_it
ERROR apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it
= 5 failed, 81 passed, 15 skipped, 257 warnings, 2 errors in 12510.05s (3:28:30) =

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

FAILURE: Build failed with an exception.

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

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

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 3h 30m 35s
222 actionable tasks: 152 executed, 64 from cache, 6 up-to-date

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

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

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


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


Build failed in Jenkins: beam_PostCommit_Python39 #985

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

Changes:

[noreply] Adds a Java RunInference example (#23619)

[noreply] Fixes #23627: Speed up website checks (#23673)

[noreply] Suppress a FloatingPointLiteralPrecision error (#23667)

[noreply] Improved test coverage and fix the implementation of Inject and CoGBK


------------------------------------------
[...truncated 426.44 KB...]
> Task :sdks:java:extensions:sql:compileJava
> Task :runners:google-cloud-dataflow-java:compileJava
> Task :sdks:java:io:google-cloud-platform:expansion-service:shadowJar

> Task :runners:google-cloud-dataflow-java:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :runners:google-cloud-dataflow-java:classes
> Task :runners:google-cloud-dataflow-java:jar

> Task :sdks:java:extensions:sql:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :sdks:java:extensions:sql:classes
> Task :sdks:java:extensions:sql:jar
> Task :runners:google-cloud-dataflow-java:worker:compileJava

> Task :sdks:java:extensions:sql:zetasql:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :sdks:java:extensions:sql:zetasql:classes
> Task :sdks:java:extensions:sql:zetasql:jar

> Task :sdks:java:extensions:sql:expansion-service:compileJava
Note: <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/java/extensions/sql/expansion-service/src/main/java/org/apache/beam/sdk/extensions/sql/expansion/ExternalSqlTransformRegistrar.java> uses or overrides a deprecated API.
Note: Recompile with -Xlint:deprecation for details.

> Task :sdks:java:extensions:sql:expansion-service:classes
> Task :sdks:java:extensions:sql:expansion-service:jar
> Task :sdks:java:extensions:sql:expansion-service:shadowJar

> Task :runners:google-cloud-dataflow-java:worker:compileJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :runners:google-cloud-dataflow-java:worker:classes
> Task :runners:flink:1.15:job-server:shadowJar
> Task :runners:google-cloud-dataflow-java:worker:shadowJar
> Task :sdks:python:test-suites:dataflow:py39:postCommitIT

> Task :sdks:python:test-suites:portable:py39:portableWordCountSparkRunnerBatch
INFO:apache_beam.runners.worker.worker_pool_main:Listening for workers at localhost:46007
INFO:root:Default Python SDK image for environment is apache/beam_python3.9_sdk:2.43.0.dev
INFO:apache_beam.runners.portability.fn_api_runner.translations:==================== <function pack_combiners at 0x7fc0c3dfedc0> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:==================== <function lift_combiners at 0x7fc0c3dfee50> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:==================== <function sort_stages at 0x7fc0c3d805e0> ====================
INFO:apache_beam.utils.subprocess_server:Starting service with ['java' '-jar' '<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-job-server-2.43.0-SNAPSHOT.jar'> '--spark-master-url' 'local[4]' '--artifacts-dir' '/tmp/beam-tempnyn_2f1l/artifactszkruqox6' '--job-port' '45289' '--artifact-port' '0' '--expansion-port' '0']
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:07 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:07 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: ArtifactStagingService started on localhost:34317
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:08 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: Java ExpansionService started on localhost:41417
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:08 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: JobService started on localhost:45289
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:08 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: Job server now running, terminate with Ctrl+C
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:08 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Staging artifacts for job_d2c11e9b-3b7e-4b89-8897-5b32a0f98e97.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:08 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Resolving artifacts for job_d2c11e9b-3b7e-4b89-8897-5b32a0f98e97.ref_Environment_default_environment_1.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:08 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Getting 1 artifacts for job_d2c11e9b-3b7e-4b89-8897-5b32a0f98e97.null.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:08 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Artifacts fully staged for job_d2c11e9b-3b7e-4b89-8897-5b32a0f98e97.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:08 INFO org.apache.beam.runners.spark.SparkJobInvoker: Invoking job BeamApp-jenkins-1018003008-a86cdd5c_61b8ef48-f884-4297-a8e1-f053927bd350
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:09 INFO org.apache.beam.runners.jobsubmission.JobInvocation: Starting job invocation BeamApp-jenkins-1018003008-a86cdd5c_61b8ef48-f884-4297-a8e1-f053927bd350
INFO:apache_beam.runners.portability.portable_runner:Environment "LOOPBACK" has started a component necessary for the execution. Be sure to run the pipeline using
  with Pipeline() as p:
    p.apply(..)
This ensures that the pipeline finishes before this program exits.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to STOPPED
INFO:apache_beam.runners.portability.portable_runner:Job state changed to STARTING
INFO:apache_beam.runners.portability.portable_runner:Job state changed to RUNNING
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:09 INFO org.apache.beam.runners.spark.translation.SparkContextFactory: Creating a brand new Spark Context.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:09 WARN org.apache.hadoop.util.NativeCodeLoader: Unable to load native-hadoop library for your platform... using builtin-java classes where applicable
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:10 WARN org.apache.beam.runners.spark.translation.SparkContextFactory: Support for Spark 2 is deprecated, this runner will be removed in a few releases.
INFO:apache_beam.utils.subprocess_server:Spark 2 is reaching its EOL, consider migrating to Spark 3.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:10 INFO org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator: Instantiated aggregators accumulator:
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:10 INFO org.apache.beam.runners.spark.metrics.MetricsAccumulator: Instantiated metrics accumulator: MetricQueryResults()
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:10 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:10 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Running job BeamApp-jenkins-1018003008-a86cdd5c_61b8ef48-f884-4297-a8e1-f053927bd350 on Spark master local[4]
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:11 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:11 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:11 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:11 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.runners.worker.statecache:Creating state cache with size 0
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure control channel for localhost:40267.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
INFO:apache_beam.runners.worker.sdk_worker:Initializing SDKHarness with unbounded number of workers.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:11 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 1-1
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:11 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-2
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure state channel for localhost:40583.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for localhost:44305
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:11 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:11 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-3
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-4
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-5
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-6
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-7
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-8
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-9
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-10
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-11
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-12
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-13
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-14
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-15
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1018003008-a86cdd5c_61b8ef48-f884-4297-a8e1-f053927bd350: Pipeline translated successfully. Computing outputs
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-16
INFO:apache_beam.io.filebasedsink:Starting finalize_write threads with num_shards: 4 (skipped: 0), batches: 4, num_threads: 4
INFO:apache_beam.io.filebasedsink:Renamed 4 shards in 0.01 seconds.
INFO:apache_beam.utils.subprocess_server:22/10/18 00:30:12 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1018003008-a86cdd5c_61b8ef48-f884-4297-a8e1-f053927bd350 finished.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE
Exception in thread read_state:
Traceback (most recent call last):
  File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
Exception in thread run_worker_1-1:
Traceback (most recent call last):
  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 1006, in pull_responses
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 654, 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 426, 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 826, 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:44305 {grpc_message:"Socket closed", grpc_status:14, created_time:"2022-10-18T00:30:13.360304861+00:00"}"
>
Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
    for response in 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 426, in __next__
  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 254, in run
    return self._next()
    self.run()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 826, in _next
  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 426, in __next__
    self._target(*self._args, **self._kwargs)
    raise self
    return self._next()
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Connection reset by peer"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40583 {created_time:"2022-10-18T00:30:13.360266736+00:00", grpc_status:14, grpc_message:"Connection reset by peer"}"
>  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 671, 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 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Connection reset by peer"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40267 {grpc_message:"Connection reset by peer", grpc_status:14, created_time:"2022-10-18T00:30:13.3603065+00:00"}"
>
    target=lambda: self._read_inputs(elements_iterator),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 654, 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 426, 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 826, 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:44305 {grpc_message:"Socket closed", grpc_status:14, created_time:"2022-10-18T00:30:13.360304861+00:00"}"
>

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

> Task :sdks:python:test-suites:dataflow:py39:postCommitIT
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


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

FAILURE: Build failed with an exception.

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

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

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 3h 36m 2s
222 actionable tasks: 197 executed, 19 from cache, 6 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python39 #984

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

Changes:

[Moritz Mack] [Jenkins,Spark] Stop running Nexmark suite for deprecated Spark 2 runner

[noreply] [Playground] Examples CI (#23476)

[noreply] [Tour Of Beam] README update (#23318)

[noreply] Bump google.golang.org/api from 0.98.0 to 0.99.0 in /sdks (#23655)

[noreply] Fix  beam_PerformanceTests_PubsubIOIT_Python_Streaming (#23607)

[noreply] 2.42.0 Release Blog Post  (#23406)

[noreply] Docs for state in go (#22965)

[noreply] Fix typo in 2.42.0 blog.

[noreply] Adjust 2.42.0 publishing time.


------------------------------------------
[...truncated 43.61 MB...]
timestamp {
  seconds: 1666035536
  nanos: 331914663
}
message: "No more requests from control plane"
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py:264"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1666035536
  nanos: 332188606
}
message: "SDK Harness waiting for in-flight requests to complete"
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py:265"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1666035536
  nanos: 332303762
}
message: "Closing all cached grpc data channels."
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/data_plane.py:805"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1666035536
  nanos: 332376241
}
message: "Closing all cached gRPC state handlers."
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py:875"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1666035536
  nanos: 334089040
}
message: "Done consuming work."
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py:277"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1666035536
  nanos: 334250688
}
message: "Python sdk harness exiting."
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker_main.py:188"
thread: "MainThread"

INFO:apache_beam.runners.portability.local_job_service:Completed job in 27.498116731643677 seconds with state DONE.
INFO:root:Completed job in 27.498116731643677 seconds with state DONE.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE

> Task :sdks:python:test-suites:portable:py39:portableWordCountSparkRunnerBatch
INFO:apache_beam.runners.worker.worker_pool_main:Listening for workers at localhost:40489
INFO:root:Default Python SDK image for environment is apache/beam_python3.9_sdk:2.43.0.dev
INFO:apache_beam.runners.portability.fn_api_runner.translations:==================== <function pack_combiners at 0x7fae36135dc0> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:==================== <function lift_combiners at 0x7fae36135e50> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:==================== <function sort_stages at 0x7fae360b65e0> ====================
INFO:apache_beam.utils.subprocess_server:Starting service with ['java' '-jar' '<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-job-server-2.43.0-SNAPSHOT.jar'> '--spark-master-url' 'local[4]' '--artifacts-dir' '/tmp/beam-temp7by_dhok/artifacts8ovp99xt' '--job-port' '37147' '--artifact-port' '0' '--expansion-port' '0']
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:03 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
WARNING:root:Waiting for grpc channel to be ready at localhost:37147.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:05 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: ArtifactStagingService started on localhost:42241
WARNING:root:Waiting for grpc channel to be ready at localhost:37147.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:05 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: Java ExpansionService started on localhost:43389
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:05 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: JobService started on localhost:37147
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:05 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: Job server now running, terminate with Ctrl+C
WARNING:root:Waiting for grpc channel to be ready at localhost:37147.
WARNING:root:Waiting for grpc channel to be ready at localhost:37147.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:09 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Staging artifacts for job_42bdaebf-1e50-48cd-abfe-592e298130a1.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:09 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Resolving artifacts for job_42bdaebf-1e50-48cd-abfe-592e298130a1.ref_Environment_default_environment_1.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:09 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Getting 1 artifacts for job_42bdaebf-1e50-48cd-abfe-592e298130a1.null.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:09 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Artifacts fully staged for job_42bdaebf-1e50-48cd-abfe-592e298130a1.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:10 INFO org.apache.beam.runners.spark.SparkJobInvoker: Invoking job BeamApp-jenkins-1017193910-c96d138e_c14989fc-2018-46c4-86c1-30d78028cf30
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:10 INFO org.apache.beam.runners.jobsubmission.JobInvocation: Starting job invocation BeamApp-jenkins-1017193910-c96d138e_c14989fc-2018-46c4-86c1-30d78028cf30
INFO:apache_beam.runners.portability.portable_runner:Environment "LOOPBACK" has started a component necessary for the execution. Be sure to run the pipeline using
  with Pipeline() as p:
    p.apply(..)
This ensures that the pipeline finishes before this program exits.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to STOPPED
INFO:apache_beam.runners.portability.portable_runner:Job state changed to STARTING
INFO:apache_beam.runners.portability.portable_runner:Job state changed to RUNNING
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:11 INFO org.apache.beam.runners.spark.translation.SparkContextFactory: Creating a brand new Spark Context.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:13 WARN org.apache.hadoop.util.NativeCodeLoader: Unable to load native-hadoop library for your platform... using builtin-java classes where applicable
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:16 WARN org.apache.beam.runners.spark.translation.SparkContextFactory: Support for Spark 2 is deprecated, this runner will be removed in a few releases.
INFO:apache_beam.utils.subprocess_server:Spark 2 is reaching its EOL, consider migrating to Spark 3.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:16 INFO org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator: Instantiated aggregators accumulator:
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:16 INFO org.apache.beam.runners.spark.metrics.MetricsAccumulator: Instantiated metrics accumulator: MetricQueryResults()
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:16 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:16 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Running job BeamApp-jenkins-1017193910-c96d138e_c14989fc-2018-46c4-86c1-30d78028cf30 on Spark master local[4]
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:17 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:17 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:17 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:17 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.runners.worker.statecache:Creating state cache with size 0
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure control channel for localhost:41323.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
INFO:apache_beam.runners.worker.sdk_worker:Initializing SDKHarness with unbounded number of workers.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 1-1
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-2
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure state channel for localhost:35229.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for localhost:44843
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-3
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-4
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-5
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-8
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-7
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-6
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:18 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-9
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-10
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-11
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-12
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-13
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-14
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-15
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1017193910-c96d138e_c14989fc-2018-46c4-86c1-30d78028cf30: Pipeline translated successfully. Computing outputs
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-16
INFO:apache_beam.io.filebasedsink:Starting finalize_write threads with num_shards: 4 (skipped: 0), batches: 4, num_threads: 4
INFO:apache_beam.io.filebasedsink:Renamed 4 shards in 0.05 seconds.
INFO:apache_beam.utils.subprocess_server:22/10/17 19:39:19 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1017193910-c96d138e_c14989fc-2018-46c4-86c1-30d78028cf30 finished.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE
Exception in thread read_state:
Traceback (most recent call last):
  File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
Exception in thread run_worker_1-1:
Traceback (most recent call last):
  File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
    self.run()
    self.run()
  File "/usr/lib/python3.9/threading.py", line 910, in run
  File "/usr/lib/python3.9/threading.py", line 910, in run
    self._target(*self._args, **self._kwargs)
    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 254, in run
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 1006, in pull_responses
    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 426, in __next__
    for response in 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 426, 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 826, 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 826, in _next
    raise self
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 654, 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 426, 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 826, 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 ipv4:127.0.0.1:44843 {grpc_message:"Socket closed", grpc_status:14, created_time:"2022-10-17T19:39:20.269847514+00:00"}"
>
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Socket closed"
	debug_error_string = "UNKNOWN:Error received from peer ipv4:127.0.0.1:41323 {grpc_message:"Socket closed", grpc_status:14, created_time:"2022-10-17T19:39:20.269973395+00:00"}"
>
    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 ipv4:127.0.0.1:35229 {grpc_message:"Socket closed", grpc_status:14, created_time:"2022-10-17T19:39:20.269897296+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.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/data_plane.py",> line 671, in <lambda>
    target=lambda: self._read_inputs(elements_iterator),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 654, 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 426, 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 826, 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 ipv4:127.0.0.1:44843 {grpc_message:"Socket closed", grpc_status:14, created_time:"2022-10-17T19:39:20.269847514+00:00"}"
>

> Task :sdks:python:test-suites:portable:py39:postCommitPy39
> Task :sdks:python:test-suites:dataflow:py39:postCommitIT FAILED

FAILURE: Build failed with an exception.

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

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

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 4h 1m 17s
222 actionable tasks: 153 executed, 63 from cache, 6 up-to-date

Publishing build scan...
https://gradle.com/s/5mzzgrntx355m

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


Build failed in Jenkins: beam_PostCommit_Python39 #983

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

Changes:


------------------------------------------
[...truncated 44.41 MB...]

apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:66: 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:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:89: 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:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/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(475, 575), name='another_index'),

apache_beam/dataframe/io_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_io_read_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_read_it_test.py: 7 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2484: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

apache_beam/dataframe/io_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_io_read_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_read_it_test.py: 7 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2486: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/dataframe/io_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_io_read_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_read_it_test.py: 7 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2510: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it
apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_it
apache_beam/examples/complete/game/leader_board_it_test.py::LeaderBoardIT::test_leader_board_it
apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_file_loads
apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_streaming_inserts
  <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/complete/game/game_stats_it_test.py: 2 warnings
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/leader_board_it_test.py: 2 warnings
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 6 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 4 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1991: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    is_streaming_pipeline = p.options.view_as(StandardOptions).streaming

apache_beam/examples/complete/game/game_stats_it_test.py: 2 warnings
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/leader_board_it_test.py: 2 warnings
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 6 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 4 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1997: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

apache_beam/dataframe/io_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 1 warning
apache_beam/io/gcp/bigquery_read_it_test.py: 9 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2528: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    project_id = pcoll.pipeline.options.view_as(GoogleCloudOptions).project

apache_beam/dataframe/io_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 1 warning
apache_beam/io/gcp/bigquery_read_it_test.py: 9 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2549: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 3 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1133: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = p.options.view_as(GoogleCloudOptions).temp_location

apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 3 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1135: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).job_name or 'AUTOMATIC_JOB_NAME')

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_test.py: 2 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1987: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self.table_reference.projectId = pcoll.pipeline.options.view_as(

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 3 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1126: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self.project = self.project or p.options.view_as(GoogleCloudOptions).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: Dropping of nuisance columns in DataFrame reductions (with 'numeric_only=None') is deprecated; in a future version this will raise TypeError.  Select only valid columns before calling the reduction.
    return airline_df[at_top_airports].mean()

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/dataframe/io.py>:659: FutureWarning: WriteToFiles is experimental.
    return pcoll | fileio.WriteToFiles(

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/io/fileio.py>:590: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).temp_location or

apache_beam/io/gcp/bigquery_test.py::BigQueryStreamingInsertTransformIntegrationTests::test_multiple_destinations_transform
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_test.py>:1684: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    streaming = self.test_pipeline.options.view_as(StandardOptions).streaming

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>:171: BeamDeprecationWarning: BigQuerySource is deprecated since 2.25.0. Use ReadFromBigQuery instead.
    beam.io.BigQuerySource(query=self.query, use_standard_sql=True)))

apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_deidentification
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/ml/gcp/cloud_dlp_it_test.py>:74: FutureWarning: MaskDetectedDetails is experimental.
    | MaskDetectedDetails(

apache_beam/ml/inference/sklearn_inference_it_test.py::SklearnInference::test_sklearn_regression
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/examples/inference/sklearn_japanese_housing_regression.py>:128: FutureWarning: SklearnModelHandlerPandas is experimental. No backwards-compatibility guarantees.
    model_loader = SklearnModelHandlerPandas(

apache_beam/ml/inference/sklearn_inference_it_test.py::SklearnInference::test_sklearn_regression
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/dill/_dill.py>:472: FutureWarning: SklearnModelHandlerPandas is experimental. No backwards-compatibility guarantees.
    obj = StockUnpickler.load(self)

apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_inspection
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/ml/gcp/cloud_dlp_it_test.py>:85: FutureWarning: InspectForDetails is experimental.
    | InspectForDetails(

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>:646: 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_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_read_it_test.py>:761: FutureWarning: ReadAllFromBigQuery is experimental.
    | beam.io.ReadAllFromBigQuery())

apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2657: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2658: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    project = pcoll.pipeline.options.view_as(GoogleCloudOptions).project

apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2671: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    options=pcoll.pipeline.options,

-- 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> -
=========================== short test summary info ============================
FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_impersonation_it
FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it
FAILED apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_aggregation
FAILED apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_enrich
FAILED apache_beam/runners/dataflow/dataflow_exercise_metrics_pipeline_test.py::ExerciseMetricsPipelineTest::test_metrics_fnapi_it
ERROR apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_impersonation_it
ERROR apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it
ERROR apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_aggregation
ERROR apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_enrich
= 5 failed, 81 passed, 15 skipped, 253 warnings, 4 errors in 13583.91s (3:46:23) =

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

FAILURE: Build failed with an exception.

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

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

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 3h 49m 19s
222 actionable tasks: 152 executed, 64 from cache, 6 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python39 #982

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

Changes:


------------------------------------------
[...truncated 29.41 MB...]
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1665987974
  nanos: 639118432
}
message: "SDK Harness waiting for in-flight requests to complete"
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py:265"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1665987974
  nanos: 639213800
}
message: "Closing all cached grpc data channels."
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/data_plane.py:805"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1665987974
  nanos: 639291048
}
message: "Closing all cached gRPC state handlers."
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py:875"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1665987974
  nanos: 639532804
}
message: "Done consuming work."
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker.py:277"
thread: "MainThread"

INFO:root:severity: INFO
timestamp {
  seconds: 1665987974
  nanos: 639603137
}
message: "Python sdk harness exiting."
log_location: "/usr/local/lib/python3.9/site-packages/apache_beam/runners/worker/sdk_worker_main.py:188"
thread: "MainThread"

INFO:apache_beam.runners.portability.local_job_service:Completed job in 23.43202257156372 seconds with state DONE.
INFO:root:Completed job in 23.43202257156372 seconds with state DONE.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE

> Task :sdks:python:test-suites:portable:py39:portableWordCountSparkRunnerBatch
INFO:apache_beam.runners.worker.worker_pool_main:Listening for workers at localhost:36109
INFO:root:Default Python SDK image for environment is apache/beam_python3.9_sdk:2.43.0.dev
INFO:apache_beam.runners.portability.fn_api_runner.translations:==================== <function pack_combiners at 0x7f8e913b4b80> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:==================== <function lift_combiners at 0x7f8e913b4c10> ====================
INFO:apache_beam.runners.portability.fn_api_runner.translations:==================== <function sort_stages at 0x7f8e913b53a0> ====================
INFO:apache_beam.utils.subprocess_server:Starting service with ['java' '-jar' '<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-job-server-2.43.0-SNAPSHOT.jar'> '--spark-master-url' 'local[4]' '--artifacts-dir' '/tmp/beam-tempqmv265z7/artifactsilsrdqde' '--job-port' '38995' '--artifact-port' '0' '--expansion-port' '0']
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:28 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:29 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: ArtifactStagingService started on localhost:43293
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:29 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: Java ExpansionService started on localhost:40377
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:29 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: JobService started on localhost:38995
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:29 INFO org.apache.beam.runners.jobsubmission.JobServerDriver: Job server now running, terminate with Ctrl+C
WARNING:root:Waiting for grpc channel to be ready at localhost:38995.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:30 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Staging artifacts for job_16376bdf-7594-4b10-9d10-7aad942e0ce4.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:30 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Resolving artifacts for job_16376bdf-7594-4b10-9d10-7aad942e0ce4.ref_Environment_default_environment_1.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:30 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Getting 1 artifacts for job_16376bdf-7594-4b10-9d10-7aad942e0ce4.null.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:31 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Artifacts fully staged for job_16376bdf-7594-4b10-9d10-7aad942e0ce4.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:31 INFO org.apache.beam.runners.spark.SparkJobInvoker: Invoking job BeamApp-jenkins-1017062631-6708e9ea_110eb230-2f61-4fe6-90b5-a31f3bb84df7
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:31 INFO org.apache.beam.runners.jobsubmission.JobInvocation: Starting job invocation BeamApp-jenkins-1017062631-6708e9ea_110eb230-2f61-4fe6-90b5-a31f3bb84df7
INFO:apache_beam.runners.portability.portable_runner:Environment "LOOPBACK" has started a component necessary for the execution. Be sure to run the pipeline using
  with Pipeline() as p:
    p.apply(..)
This ensures that the pipeline finishes before this program exits.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to STOPPED
INFO:apache_beam.runners.portability.portable_runner:Job state changed to STARTING
INFO:apache_beam.runners.portability.portable_runner:Job state changed to RUNNING
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:32 INFO org.apache.beam.runners.spark.translation.SparkContextFactory: Creating a brand new Spark Context.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:33 WARN org.apache.hadoop.util.NativeCodeLoader: Unable to load native-hadoop library for your platform... using builtin-java classes where applicable
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:34 WARN org.apache.beam.runners.spark.translation.SparkContextFactory: Support for Spark 2 is deprecated, this runner will be removed in a few releases.
INFO:apache_beam.utils.subprocess_server:Spark 2 is reaching its EOL, consider migrating to Spark 3.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:34 INFO org.apache.beam.runners.spark.aggregators.AggregatorsAccumulator: Instantiated aggregators accumulator:
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:35 INFO org.apache.beam.runners.spark.metrics.MetricsAccumulator: Instantiated metrics accumulator: MetricQueryResults()
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:35 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:35 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Running job BeamApp-jenkins-1017062631-6708e9ea_110eb230-2f61-4fe6-90b5-a31f3bb84df7 on Spark master local[4]
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.runners.worker.statecache:Creating state cache with size 0
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure control channel for localhost:43205.
INFO:apache_beam.runners.worker.sdk_worker:Control channel established.
INFO:apache_beam.runners.worker.sdk_worker:Initializing SDKHarness with unbounded number of workers.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 1-1
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-2
INFO:apache_beam.runners.worker.sdk_worker:Creating insecure state channel for localhost:44985.
INFO:apache_beam.runners.worker.sdk_worker:State channel established.
INFO:apache_beam.runners.worker.data_plane:Creating client data channel for localhost:35997
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-3
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-4
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:36 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-5
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-7
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-9
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-6
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-8
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-10
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-11
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-12
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-13
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-14
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-15
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1017062631-6708e9ea_110eb230-2f61-4fe6-90b5-a31f3bb84df7: Pipeline translated successfully. Computing outputs
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 1-16
INFO:apache_beam.io.filebasedsink:Starting finalize_write threads with num_shards: 4 (skipped: 0), batches: 4, num_threads: 4
INFO:apache_beam.io.filebasedsink:Renamed 4 shards in 0.01 seconds.
INFO:apache_beam.utils.subprocess_server:22/10/17 06:26:37 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1017062631-6708e9ea_110eb230-2f61-4fe6-90b5-a31f3bb84df7 finished.
INFO:apache_beam.runners.portability.portable_runner:Job state changed to DONE
Exception in thread read_state:
Traceback (most recent call last):
Exception in thread run_worker_1-1:
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()
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 654, 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 426, 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 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Connection reset by peer"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35997 {grpc_message:"Connection reset by peer", grpc_status:14, created_time:"2022-10-17T06:26:38.164182807+00:00"}"
>
  File "/usr/lib/python3.9/threading.py", line 910, in run
    self.run()
Exception in thread read_grpc_client_inputs:
  File "/usr/lib/python3.9/threading.py", line 910, in run
    self._target(*self._args, **self._kwargs)
Traceback (most recent call last):
  File "/usr/lib/python3.9/threading.py", line 973, in _bootstrap_inner
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/sdk_worker.py",> line 1006, in pull_responses
    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 254, 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 426, in __next__
    for response in responses:
    self.run()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "/usr/lib/python3.9/threading.py", line 910, in run
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/grpc/_channel.py",> line 826, in _next
    return self._next()
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 671, 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 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Connection reset by peer"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43205 {grpc_message:"Connection reset by peer", grpc_status:14, created_time:"2022-10-17T06:26:38.164188536+00:00"}"
>
    raise self
    target=lambda: self._read_inputs(elements_iterator),
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Connection reset by peer"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44985 {created_time:"2022-10-17T06:26:38.164202293+00:00", grpc_status:14, grpc_message:"Connection reset by peer"}"
>
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 654, 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 426, 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 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.UNAVAILABLE
	details = "Connection reset by peer"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35997 {grpc_message:"Connection reset by peer", grpc_status:14, created_time:"2022-10-17T06:26:38.164182807+00:00"}"
>

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

> Task :sdks:python:test-suites:dataflow:py39:postCommitIT
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


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

FAILURE: Build failed with an exception.

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

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

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 3h 51m 50s
222 actionable tasks: 152 executed, 64 from cache, 6 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_Python39 #981

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

Changes:

[noreply] Blog post for Hop web in Google Cloud (#23652)


------------------------------------------
[...truncated 44.28 MB...]
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
apache_beam/typehints/pandas_type_compatibility_test.py:66
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:66: 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:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
apache_beam/typehints/pandas_type_compatibility_test.py:89
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/typehints/pandas_type_compatibility_test.py>:89: 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:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
apache_beam/typehints/pandas_type_compatibility_test.py:90
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/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(475, 575), name='another_index'),

apache_beam/dataframe/io_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_read_it_test.py: 7 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 3 warnings
apache_beam/io/gcp/bigquery_io_read_it_test.py: 2 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2484: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

apache_beam/dataframe/io_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_read_it_test.py: 7 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 3 warnings
apache_beam/io/gcp/bigquery_io_read_it_test.py: 2 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2486: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/dataframe/io_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_read_it_test.py: 7 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 3 warnings
apache_beam/io/gcp/bigquery_io_read_it_test.py: 2 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2510: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

apache_beam/examples/complete/game/game_stats_it_test.py::GameStatsIT::test_game_stats_it
apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_it
apache_beam/examples/complete/game/leader_board_it_test.py::LeaderBoardIT::test_leader_board_it
apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_file_loads
apache_beam/io/gcp/bigquery_test.py::PubSubBigQueryIT::test_streaming_inserts
  <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/complete/game/game_stats_it_test.py: 2 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/examples/complete/game/leader_board_it_test.py: 2 warnings
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 6 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 4 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1991: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    is_streaming_pipeline = p.options.view_as(StandardOptions).streaming

apache_beam/examples/complete/game/game_stats_it_test.py: 2 warnings
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/examples/complete/game/leader_board_it_test.py: 2 warnings
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 6 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 4 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1997: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

apache_beam/dataframe/io_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 1 warning
apache_beam/io/gcp/bigquery_read_it_test.py: 9 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2528: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    project_id = pcoll.pipeline.options.view_as(GoogleCloudOptions).project

apache_beam/dataframe/io_it_test.py: 2 warnings
apache_beam/io/gcp/bigquery_json_it_test.py: 1 warning
apache_beam/io/gcp/bigquery_read_it_test.py: 9 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2549: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    pipeline_options=pcoll.pipeline.options,

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_test.py: 2 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1987: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self.table_reference.projectId = pcoll.pipeline.options.view_as(

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 3 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1126: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    self.project = self.project or p.options.view_as(GoogleCloudOptions).project

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 3 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1133: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = p.options.view_as(GoogleCloudOptions).temp_location

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py: 1 warning
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 1 warning
apache_beam/io/gcp/big_query_query_to_table_it_test.py: 4 warnings
apache_beam/io/gcp/bigquery_file_loads_test.py: 3 warnings
apache_beam/io/gcp/bigquery_test.py: 3 warnings
apache_beam/io/gcp/bigquery_write_it_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1135: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).job_name or 'AUTOMATIC_JOB_NAME')

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: Dropping of nuisance columns in DataFrame reductions (with 'numeric_only=None') is deprecated; in a future version this will raise TypeError.  Select only valid columns before calling the reduction.
    return airline_df[at_top_airports].mean()

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_aggregation
apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_enrich
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/dataframe/io.py>:659: FutureWarning: WriteToFiles is experimental.
    return pcoll | fileio.WriteToFiles(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_aggregation
apache_beam/examples/dataframe/taxiride_it_test.py::TaxirideIT::test_enrich
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/fileio.py>:590: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).temp_location or

apache_beam/io/gcp/bigquery_test.py::BigQueryStreamingInsertTransformIntegrationTests::test_multiple_destinations_transform
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_test.py>:1684: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    streaming = self.test_pipeline.options.view_as(StandardOptions).streaming

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>:171: BeamDeprecationWarning: BigQuerySource is deprecated since 2.25.0. Use ReadFromBigQuery instead.
    beam.io.BigQuerySource(query=self.query, use_standard_sql=True)))

apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_deidentification
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/ml/gcp/cloud_dlp_it_test.py>:74: FutureWarning: MaskDetectedDetails is experimental.
    | MaskDetectedDetails(

apache_beam/ml/gcp/cloud_dlp_it_test.py::CloudDLPIT::test_inspection
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/ml/gcp/cloud_dlp_it_test.py>:85: FutureWarning: InspectForDetails is experimental.
    | InspectForDetails(

apache_beam/ml/inference/sklearn_inference_it_test.py::SklearnInference::test_sklearn_regression
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/examples/inference/sklearn_japanese_housing_regression.py>:128: FutureWarning: SklearnModelHandlerPandas is experimental. No backwards-compatibility guarantees.
    model_loader = SklearnModelHandlerPandas(

apache_beam/ml/inference/sklearn_inference_it_test.py::SklearnInference::test_sklearn_regression
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/build/gradleenv/-1734967050/lib/python3.9/site-packages/dill/_dill.py>:472: FutureWarning: SklearnModelHandlerPandas is experimental. No backwards-compatibility guarantees.
    obj = StockUnpickler.load(self)

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>:646: 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_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery_read_it_test.py>:761: FutureWarning: ReadAllFromBigQuery is experimental.
    | beam.io.ReadAllFromBigQuery())

apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2657: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    job_name = pcoll.pipeline.options.view_as(GoogleCloudOptions).job_name

apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2658: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    project = pcoll.pipeline.options.view_as(GoogleCloudOptions).project

apache_beam/io/gcp/bigquery_read_it_test.py::ReadAllBQTests::test_read_queries
  <https://ci-beam.apache.org/job/beam_PostCommit_Python39/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2671: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    options=pcoll.pipeline.options,

-- 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> -
=========================== short test summary info ============================
FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_impersonation_it
FAILED apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it
FAILED apache_beam/io/fileio_test.py::MatchIntegrationTest::test_transform_on_gcs
FAILED apache_beam/io/gcp/pubsub_integration_test.py::PubSubIntegrationTest::test_streaming_data_only
FAILED apache_beam/io/gcp/pubsub_integration_test.py::PubSubIntegrationTest::test_streaming_with_attributes
ERROR apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_impersonation_it
ERROR apache_beam/examples/wordcount_it_test.py::WordCountIT::test_wordcount_it
= 5 failed, 81 passed, 15 skipped, 257 warnings, 2 errors in 13547.15s (3:45:47) =

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

FAILURE: Build failed with an exception.

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

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

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 3h 47m 33s
222 actionable tasks: 152 executed, 64 from cache, 6 up-to-date

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

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