You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2022/11/02 07:29:29 UTC

Build failed in Jenkins: beam_PostCommit_Python_Examples_Spark #1033

See <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/1033/display/redirect>

Changes:


------------------------------------------
[...truncated 393.63 KB...]
apache_beam/examples/dataframe/wordcount_test.py:57: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/dataframe/wordcount.py:52: in run
    with beam.Pipeline(options=PipelineOptions(pipeline_args)) as p:
apache_beam/pipeline.py:597: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:574: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/portability/spark_runner.py:47: in run_pipeline
    return super().run_pipeline(pipeline, options)
apache_beam/runners/portability/portable_runner.py:439: in run_pipeline
    job_service_handle = self.create_job_service(options)
apache_beam/runners/portability/portable_runner.py:318: in create_job_service
    return self.create_job_service_handle(server.start(), options)
apache_beam/runners/portability/job_server.py:81: in start
    self._endpoint = self._job_server.start()
apache_beam/runners/portability/job_server.py:106: in start
    cmd, endpoint = self.subprocess_cmd_and_endpoint()
apache_beam/runners/portability/job_server.py:150: in subprocess_cmd_and_endpoint
    jar_path = self.local_jar(self.path_to_jar())
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.spark_runner.SparkJarJobServer object at 0x7f5fc36b4eb0>

    def path_to_jar(self):
      if self._jar:
        if not os.path.exists(self._jar):
          url = urllib.parse.urlparse(self._jar)
          if not url.scheme:
>           raise ValueError(
                'Unable to parse jar URL "%s". If using a full URL, make sure '
                'the scheme is specified. If using a local file path, make sure '
                'the file exists; you may have to first build the job server '
                'using `./gradlew runners:spark:3:job-server:shadowJar`.' %
                self._jar)
E           ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.

apache_beam/runners/portability/spark_runner.py:87: ValueError
------------------------------ Captured log call -------------------------------
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[set_column_DataFrame_140049277114912], ComputedExpression[set_index_DataFrame_140049277113472], ComputedExpression[pre_combine_sum_DataFrame_140049277117120]]:140049249778176]> for Stage[inputs={PlaceholderExpression[placeholder_DataFrame_140048710338736]}, partitioning=Arbitrary, ops=[ComputedExpression[set_column_DataFrame_140049277114912], ComputedExpression[set_index_DataFrame_140049277113472], ComputedExpression[pre_combine_sum_DataFrame_140049277117120]], outputs={ComputedExpression[pre_combine_sum_DataFrame_140049277117120], PlaceholderExpression[placeholder_DataFrame_140048710338736]}]
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[post_combine_sum_DataFrame_140049277121296]]:140049249766320]> for Stage[inputs={ComputedExpression[pre_combine_sum_DataFrame_140049277117120]}, partitioning=Index, ops=[ComputedExpression[post_combine_sum_DataFrame_140049277121296]], outputs={ComputedExpression[post_combine_sum_DataFrame_140049277121296]}]
INFO     apache_beam.io.fileio:fileio.py:595 Added temporary directory gs://temp-storage-for-end-to-end-tests/temp-it/.tempbea83265-5963-481f-9c7d-7dad44d9f477
INFO     apache_beam.runners.worker.worker_pool_main:worker_pool_main.py:93 Listening for workers at localhost:46381
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.10_sdk:2.44.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function pack_combiners at 0x7f5ffe7e1870> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function lift_combiners at 0x7f5ffe7e1900> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function sort_stages at 0x7f5ffe7e2050> ====================
=============================== warnings summary ===============================
../../build/gradleenv/-1720702907/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

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

../../build/gradleenv/-1720702907/lib/python3.10/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

apache_beam/typehints/pandas_type_compatibility_test.py:66
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/examples/wordcount_debugging_test.py: 3 warnings
apache_beam/examples/wordcount_minimal_test.py: 3 warnings
apache_beam/examples/wordcount_test.py: 3 warnings
apache_beam/examples/complete/autocomplete_it_test.py: 3 warnings
apache_beam/examples/complete/distribopt_test.py: 3 warnings
apache_beam/examples/complete/tfidf_it_test.py: 10 warnings
apache_beam/examples/complete/top_wikipedia_sessions_it_test.py: 3 warnings
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 2 warnings
apache_beam/examples/complete/game/user_score_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_side_input_it_test.py: 1 warning
apache_beam/examples/cookbook/coders_it_test.py: 3 warnings
apache_beam/examples/cookbook/custom_ptransform_it_test.py: 3 warnings
apache_beam/examples/cookbook/group_with_coder_test.py: 6 warnings
apache_beam/examples/cookbook/mergecontacts_test.py: 9 warnings
apache_beam/examples/cookbook/multiple_output_pardo_test.py: 3 warnings
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/examples/dataframe/wordcount_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/httplib2/__init__.py>:147: DeprecationWarning: ssl.PROTOCOL_TLS is deprecated
    context = ssl.SSLContext(DEFAULT_TLS_VERSION)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1140: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2511: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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
    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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/wordcount_debugging_test.py::WordCountDebuggingTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/wordcount_minimal_test.py::WordCountMinimalTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/wordcount_test.py::WordCountTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/autocomplete_it_test.py::AutocompleteIT::test_autocomplete_output_files_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/distribopt_test.py::DistribOptimizationTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/estimate_pi_it_test.py::EstimatePiIT::test_estimate_pi_output_file - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/tfidf_it_test.py::TfIdfIT::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/top_wikipedia_sessions_it_test.py::ComputeTopSessionsIT::test_top_wikipedia_sessions_output_files_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/coders_it_test.py::CodersIT::test_coders_output_files_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check - AssertionError: 'Unable to deterministically encode' not found in 'Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.'
FAILED apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
ERROR apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.BigQueryTornadoesIT.monthly_tornadoes_1667374154866
ERROR apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.FiltersTestIT.cold_days_1667374157468
= 21 failed, 1 passed, 6 skipped, 6696 deselected, 107 warnings, 2 errors in 33.15s =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 3m 2s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1091

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/1091/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_Python_Examples_Spark #1090

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

Changes:


------------------------------------------
[...truncated 4.60 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36841 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-16T13:30:46.401958029+00:00"}"
>
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:46 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:46 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1116133044-c9c3179d_76560681-a6cd-4a04-9a68-0321c12cc4c4: Pipeline translated successfully. Computing outputs
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:46 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:46 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:46 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:46 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 0
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:182 Creating insecure control channel for localhost:42031.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:190 Control channel established.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:235 Initializing SDKHarness with unbounded number of workers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:46 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 144-1
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:46 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 144-2
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:856 Creating insecure state channel for localhost:40259.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:863 State channel established.
INFO     apache_beam.runners.worker.data_plane:data_plane.py:772 Creating client data channel for localhost:39493
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:46 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:620 Finished listing 1 files in 0.03644275665283203 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:316 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:361 Renamed 1 shards in 0.40 seconds.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:47 INFO org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory: Closing environment urn: "beam:env:external:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:32931"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39493 {created_time:"2022-11-16T13:30:47.024937354+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:47 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:47 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1116133044-c9c3179d_76560681-a6cd-4a04-9a68-0321c12cc4c4 finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 13:30:47 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@19702620{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6715 deselected, 40 warnings in 233.34s (0:03:53) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 25s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

Publishing build scan...
https://gradle.com/s/2algq4bmfpsr2

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_Python_Examples_Spark #1089

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

Changes:


------------------------------------------
[...truncated 4.69 MB...]
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40315 {created_time:"2022-11-16T07:31:36.992286506+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"

INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 07:31:36 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 07:31:37 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1116073134-80c93e98_4c7ddfaa-7a4d-4c18-a5db-61740c224f29 finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 07:31:37 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@4e9e3749{HTTP/1.1, (http/1.1)}{127.0.0.1:4040}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34003 {created_time:"2022-11-16T07:32:40.663531919+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40943 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-16T07:32:51.796537774+00:00"}"
>

  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 654, in _read_inputs
    for elements in elements_iterator:
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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(

    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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)

	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44951 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-16T07:33:00.049282641+00:00"}"
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6715 deselected, 40 warnings in 266.85s (0:04:26) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 17s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1088

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

Changes:

[Kenneth Knowles] Fix arguments to checkState in BatchViewOverrides

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

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

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

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

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

[noreply] Updated README of Interactive Beam

[noreply] Minor update

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

[noreply] Strip FGAC database role from changestreams metadata requests (#24177)


------------------------------------------
[...truncated 4.62 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 01:32:06 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 01:32:06 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1116013204-b3a373e8_a2e22cd7-f5c7-421b-b528-9b8d9faf4bca finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/16 01:32:06 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@49e605ce{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
    experiments = p.options.view_as(DebugOptions).experiments or []

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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

	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38107 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-16T01:32:45.243273726+00:00"}"
>

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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')

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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

	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37193 {created_time:"2022-11-16T01:32:49.702435945+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 671, in <lambda>
    target=lambda: self._read_inputs(elements_iterator),
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  /home/jenkins/jenkins-slavgrpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41351 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-16T01:33:12.123343259+00:00"}"
>

e/workspace/beam_PostCommit_Python_Examples_Spark/src/sdks/python/apache_beam/io/gcp/bigquery.py:1988: 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(

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38859 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-16T01:33:13.966001239+00:00"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36347 {created_time:"2022-11-16T01:33:18.785813377+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6715 deselected, 40 warnings in 244.80s (0:04:04) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 47s
78 actionable tasks: 51 executed, 25 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1087

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

Changes:

[noreply] Editorial review of the ML notebooks. (#24125)

[noreply] Configure flutter_code_editor options with Hugo shortcode (#23926)

[noreply] Eliminate CalciteUtil.CharType logical type (#24013)

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

[noreply] Fix broken notebook (#24179)


------------------------------------------
[...truncated 4.82 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 19:31:11 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 19:31:11 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 0
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:182 Creating insecure control channel for localhost:46195.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:190 Control channel established.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:235 Initializing SDKHarness with unbounded number of workers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 19:31:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 146-1
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 19:31:12 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 146-2
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:856 Creating insecure state channel for localhost:40065.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:863 State channel established.
INFO     apache_beam.runners.worker.data_plane:data_plane.py:772 Creating client data channel for localhost:43201
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 19:31:12 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:620 Finished listing 1 files in 0.04653024673461914 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:316 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:361 Renamed 1 shards in 0.50 seconds.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 19:31:12 INFO org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory: Closing environment urn: "beam:env:external:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:46309"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43201 {created_time:"2022-11-15T19:31:12.74770924+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 19:31:12 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 19:31:12 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1115193110-af8ebf6_a26ac81b-86aa-427a-8242-3b92afd799d6 finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 19:31:12 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@3c12e3a0{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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.

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    return airline_df[at_top_airports].mean()

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 255.01s (0:04:15) =
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45439 {created_time:"2022-11-15T19:32:28.31999844+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45083 {created_time:"2022-11-15T19:32:29.883078885+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>


> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 42s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

Publishing build scan...
https://gradle.com/s/7nnsartpcdroo

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_Python_Examples_Spark #1086

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

Changes:

[bulat.safiullin] [Website] update pre tag copy link styles #23064

[noreply] [Dockerized Jenkins] Update README how to use local repo (#24055)

[noreply] [Dockerized Jenkins] Fix build of dockerized jenkins (fixes #24053)

[noreply] Bump github.com/aws/aws-sdk-go-v2/feature/s3/manager in /sdks (#24131)


------------------------------------------
[...truncated 4.61 MB...]
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35187 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-15T13:36:54.530907558+00:00"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33883 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-15T13:36:56.64273168+00:00"}"
>

Exception in thread read_grpc_client_inputs:
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 13:35:51 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 13:35:51 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1115133549-21a40e5c_801ca214-2296-43de-bbba-6bb66d395cab finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 13:35:51 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@3108265{HTTP/1.1, (http/1.1)}{127.0.0.1:4040}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44651 {created_time:"2022-11-15T13:37:01.645617585+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34751 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-15T13:37:03.303095193+00:00"}"
>

  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 544.62s (0:09:04) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 10m 24s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1085

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

Changes:

[noreply] Implement embedded WebAssembly example (#24081)


------------------------------------------
[...truncated 4.65 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38695 {created_time:"2022-11-15T07:31:04.289257812+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44729 {created_time:"2022-11-15T07:31:24.430576693+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41057 {created_time:"2022-11-15T07:31:27.275239967+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43785 {created_time:"2022-11-15T07:31:28.996105029+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38671 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-15T07:31:36.116163975+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42327 {created_time:"2022-11-15T07:31:42.949318843+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 41 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37087 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-15T07:32:08.819438424+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44197 {created_time:"2022-11-15T07:32:13.67159075+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 599 warnings in 243.50s (0:04:03) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 36s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1084

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

Changes:

[noreply] Bump loader-utils

[noreply] Cleanup stale BQ datasets (#24158)

[noreply] Support SqlTypes Date and Timestamp (MicrosInstant) in AvroUtils

[noreply] Add more tests for S3 filesystem (#24138)

[noreply] Merge pull request #23333: Track time on Cloud Dataflow streaming data

[Robert Bradshaw] Rename the test_splits flag to direct_test_splits.

[noreply] Adding a quickstart to README for the TS SDK (#23509)

[noreply] More dataset templates to clean up (#24162)


------------------------------------------
[...truncated 4.72 MB...]
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42789 {created_time:"2022-11-15T01:38:17.783935103+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:17 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:17 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1115013816-e9b408f0_3a8c7c2d-8d3b-41d0-b049-ec5b85f2c187: Pipeline translated successfully. Computing outputs
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:17 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:17 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:17 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:17 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 0
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:182 Creating insecure control channel for localhost:41365.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:190 Control channel established.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:235 Initializing SDKHarness with unbounded number of workers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:17 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 143-1
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:17 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 143-2
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:856 Creating insecure state channel for localhost:43521.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:863 State channel established.
INFO     apache_beam.runners.worker.data_plane:data_plane.py:772 Creating client data channel for localhost:39889
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:17 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:620 Finished listing 1 files in 0.04074215888977051 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:316 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:361 Renamed 1 shards in 0.40 seconds.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:18 INFO org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory: Closing environment urn: "beam:env:external:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:41911"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39889 {created_time:"2022-11-15T01:38:18.456419891+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:18 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:18 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1115013816-e9b408f0_3a8c7c2d-8d3b-41d0-b049-ec5b85f2c187 finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/15 01:38:18 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@6dbd8dd8{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 

Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 643.99s (0:10:43) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 12m 47s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1083

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

Changes:

[chamikaramj] Updates Multi-lang Java quickstart

[bulat.safiullin] [Website] change headers size from h4,h3 to h2 #24082

[Kenneth Knowles] Fix checkArgument format string in AvroIO

[Kenneth Knowles] Fix checkArgument format in GcsPath

[Kenneth Knowles] Remove extraneous jetbrains annotation

[noreply] Bump golang.org/x/net from 0.1.0 to 0.2.0 in /sdks (#24153)

[noreply] Make MonotonicWatermarkEstimator work like its Java SDK equivalent

[noreply] Test Dataproc 2.1 with Flink load tests (#24129)

[noreply] Change DataflowBatchWorkerHarness doWork error level to INFO (#24135)

[noreply] Bump github.com/aws/aws-sdk-go-v2/config from 1.17.10 to 1.18.0 in /sdks

[noreply] [Tour Of Beam] verify that unit exists when saving progress (#24118)


------------------------------------------
[...truncated 4.81 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 19:31:35 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 19:31:35 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 0
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:182 Creating insecure control channel for localhost:45771.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:190 Control channel established.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:235 Initializing SDKHarness with unbounded number of workers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 19:31:35 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 145-1
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 19:31:35 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 145-2
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:856 Creating insecure state channel for localhost:35639.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:863 State channel established.
INFO     apache_beam.runners.worker.data_plane:data_plane.py:772 Creating client data channel for localhost:34741
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 19:31:35 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:620 Finished listing 1 files in 0.04006052017211914 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:316 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:361 Renamed 1 shards in 0.40 seconds.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 19:31:35 INFO org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory: Closing environment urn: "beam:env:external:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:34035"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34741 {created_time:"2022-11-14T19:31:35.88728366+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 19:31:35 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 19:31:35 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1114193133-8c9cf572_f41259e0-f549-4ad0-a9f5-e17df9a7313b finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 19:31:35 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@23e07056{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

Exception in thread read_grpc_client_inputs:
    p.options.view_as(GoogleCloudOptions).temp_location or

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 254.08s (0:04:14) =
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41889 {created_time:"2022-11-14T19:32:51.321862716+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46519 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-14T19:32:52.226667309+00:00"}"
>


> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 7s
78 actionable tasks: 50 executed, 26 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1082

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

Changes:

[bulat.safiullin] [Website] update go-dependencies.md java-dependencies.md


------------------------------------------
[...truncated 4.59 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37225 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-14T13:30:35.983319558+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40847 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-14T13:30:56.641731612+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42451 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-14T13:30:59.409931492+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41815 {created_time:"2022-11-14T13:31:00.927401578+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35143 {created_time:"2022-11-14T13:31:07.8932157+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37369 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-14T13:31:16.294097257+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45027 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-14T13:31:44.085073928+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40419 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-14T13:31:48.658453081+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 601 warnings in 225.23s (0:03:45) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 23s
78 actionable tasks: 50 executed, 26 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1081

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

Changes:

[Kenneth Knowles] Fix checkArgument format string in ExecutionStateTracker


------------------------------------------
[...truncated 4.67 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:26 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:26 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1114073124-aee27d4_94c96dbe-ef9a-4cf3-9d6c-85148a57e817: Pipeline translated successfully. Computing outputs
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:26 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:26 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:26 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:26 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 0
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:182 Creating insecure control channel for localhost:42565.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:190 Control channel established.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:235 Initializing SDKHarness with unbounded number of workers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:26 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 142-1
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:26 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 142-2
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:856 Creating insecure state channel for localhost:38621.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:863 State channel established.
INFO     apache_beam.runners.worker.data_plane:data_plane.py:772 Creating client data channel for localhost:37261
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:26 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:620 Finished listing 1 files in 0.04061770439147949 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:316 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:361 Renamed 1 shards in 0.50 seconds.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:27 INFO org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory: Closing environment urn: "beam:env:external:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:43103"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37261 {created_time:"2022-11-14T07:31:27.245539289+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:27 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:27 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1114073124-aee27d4_94c96dbe-ef9a-4cf3-9d6c-85148a57e817 finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 07:31:27 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@42490249{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33981 {created_time:"2022-11-14T07:32:35.17308818+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 246.86s (0:04:06) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 55s
78 actionable tasks: 50 executed, 26 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1080

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

Changes:


------------------------------------------
[...truncated 4.76 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:24 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:24 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1114013122-1e5db09_b5aab95d-c215-46a2-ae39-25124b34b331: Pipeline translated successfully. Computing outputs
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:24 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:24 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:24 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:24 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 0
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:182 Creating insecure control channel for localhost:35617.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:190 Control channel established.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:235 Initializing SDKHarness with unbounded number of workers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:24 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 142-1
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:24 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 142-2
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:856 Creating insecure state channel for localhost:42525.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:863 State channel established.
INFO     apache_beam.runners.worker.data_plane:data_plane.py:772 Creating client data channel for localhost:43929
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:24 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:620 Finished listing 1 files in 0.04202771186828613 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:316 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:361 Renamed 1 shards in 0.50 seconds.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/14 01:31:25 INFO org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory: Closing environment urn: "beam:env:external:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43929 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-14T01:31:25.05549005+00:00"}"
>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:38833"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
--------------------------- Captured stdout teardown ---------------------------
FAILED                                                                   [ 69%]
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 249.89s (0:04:09) =

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35643 {created_time:"2022-11-14T01:32:40.76817142+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>


> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 57s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1079

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

Changes:


------------------------------------------
[...truncated 4.72 MB...]
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36555 {created_time:"2022-11-13T19:31:43.281056894+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:43 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:43 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1113193141-9a6f30d_02f5a9ec-9b24-4554-a523-7481feaa7bf1: Pipeline translated successfully. Computing outputs
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:43 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:43 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:43 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:43 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 0
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:182 Creating insecure control channel for localhost:41091.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:190 Control channel established.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:235 Initializing SDKHarness with unbounded number of workers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:43 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 144-1
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:43 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 144-2
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:856 Creating insecure state channel for localhost:43871.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:863 State channel established.
INFO     apache_beam.runners.worker.data_plane:data_plane.py:772 Creating client data channel for localhost:46115
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:43 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:620 Finished listing 1 files in 0.04088902473449707 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:316 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:361 Renamed 1 shards in 0.40 seconds.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:44 INFO org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory: Closing environment urn: "beam:env:external:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:42003"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46115 {created_time:"2022-11-13T19:31:44.06927406+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:44 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:44 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1113193141-9a6f30d_02f5a9ec-9b24-4554-a523-7481feaa7bf1 finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 19:31:44 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@3f90bcf{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 261.37s (0:04:21) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 11s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1078

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

Changes:


------------------------------------------
[...truncated 4.84 MB...]
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:25 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:25 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1113133123-e476b214_efd08775-92fd-4ff4-8eb0-000de334e432: Pipeline translated successfully. Computing outputs
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:25 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:25 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:25 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:25 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 0
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:182 Creating insecure control channel for localhost:42167.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:190 Control channel established.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:235 Initializing SDKHarness with unbounded number of workers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:25 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 143-1
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:25 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 143-2
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:856 Creating insecure state channel for localhost:41013.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:863 State channel established.
INFO     apache_beam.runners.worker.data_plane:data_plane.py:772 Creating client data channel for localhost:34031
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:25 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:620 Finished listing 1 files in 0.04131937026977539 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:316 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:361 Renamed 1 shards in 0.40 seconds.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:26 INFO org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory: Closing environment urn: "beam:env:external:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:40095"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34031 {created_time:"2022-11-13T13:31:26.00431766+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:26 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:26 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1113133123-e476b214_efd08775-92fd-4ff4-8eb0-000de334e432 finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 13:31:26 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@7b7b795f{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 654, in _read_inputs
    for elements in elements_iterator:
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 250.31s (0:04:10) =
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37473 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-13T13:32:41.500950433+00:00"}"
>


> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 59s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1077

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

Changes:


------------------------------------------
[...truncated 4.79 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35511 {created_time:"2022-11-13T07:31:24.370042671+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44881 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-13T07:31:45.437792903+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43495 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-13T07:31:48.419654563+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42465 {created_time:"2022-11-13T07:31:50.151227024+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37857 {created_time:"2022-11-13T07:31:58.096215941+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33507 {created_time:"2022-11-13T07:32:05.5743725+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 41 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35241 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-13T07:32:52.622602832+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34233 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-13T07:32:57.556149338+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 599 warnings in 258.29s (0:04:18) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 9s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1076

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

Changes:


------------------------------------------
[...truncated 4.64 MB...]
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37029 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-13T01:32:06.174849689+00:00"}"
>
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:33033"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 01:32:06 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 01:32:06 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1113013204-d0a81154_8cdb7c88-828c-42ed-96ac-b3353a140d16 finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/13 01:32:06 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@4e3feed8{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 654, in _read_inputs
    for elements in elements_iterator:
apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34069 {created_time:"2022-11-13T01:33:16.173042128+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 671, in <lambda>
    target=lambda: self._read_inputs(elements_iterator),
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_da  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43451 {created_time:"2022-11-13T01:33:16.700494748+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36677 {created_time:"2022-11-13T01:33:17.598442922+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

taset' or a cloud.google.bigquery.DatasetReference object, instead.
    dataset_ref = client.dataset(unique_dataset_name, project=project)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 310.58s (0:05:10) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 44s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1075

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

Changes:


------------------------------------------
[...truncated 4.56 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/12 19:30:28 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/12 19:30:28 WARN software.amazon.awssdk.regions.internal.util.EC2MetadataUtils: Unable to retrieve the requested metadata.
INFO     apache_beam.runners.worker.statecache:statecache.py:234 Creating state cache with size 0
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:182 Creating insecure control channel for localhost:45181.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:190 Control channel established.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:235 Initializing SDKHarness with unbounded number of workers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/12 19:30:28 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: Beam Fn Control client connected with id 143-1
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/12 19:30:28 INFO org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService: getProcessBundleDescriptor request with id 143-2
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:856 Creating insecure state channel for localhost:44107.
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:863 State channel established.
INFO     apache_beam.runners.worker.data_plane:data_plane.py:772 Creating client data channel for localhost:45605
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/12 19:30:28 INFO org.apache.beam.runners.fnexecution.data.GrpcDataService: Beam Fn Data client connected.
INFO     apache_beam.io.gcp.gcsio:gcsio.py:620 Finished listing 1 files in 0.034769296646118164 seconds.
INFO     apache_beam.io.filebasedsink:filebasedsink.py:316 Starting finalize_write threads with num_shards: 1 (skipped: 0), batches: 1, num_threads: 1
INFO     apache_beam.io.filebasedsink:filebasedsink.py:361 Renamed 1 shards in 0.40 seconds.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/12 19:30:28 INFO org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory: Closing environment urn: "beam:env:external:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 payload: "\n\021\n\017localhost:42179"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bytes:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:string_utf8:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:kv:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:264 No more requests from control plane
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:bool:v1"
ERROR    apache_beam.runners.worker.data_plane:data_plane.py:661 Failed to read inputs in the data plane.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45605 {created_time:"2022-11-12T19:30:28.579037849+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:265 SDK Harness waiting for in-flight requests to complete
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:varint:v1"
INFO     apache_beam.runners.worker.data_plane:data_plane.py:805 Closing all cached grpc data channels.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:875 Closing all cached gRPC state handlers.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.runners.worker.sdk_worker:sdk_worker.py:277 Done consuming work.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/12 19:30:28 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/12 19:30:28 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1112193026-4e675e0a_dd2536c1-b64f-47e6-9a05-369c41d4ee4d finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/12 19:30:28 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@65106997{HTTP/1.1, (http/1.1)}{127.0.0.1:4040}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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/bigqu  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
ery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 671, in <lambda>
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(

    target=lambda: self._read_inputs(elements_iterator),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33167 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T19:31:43.672948361+00:00"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:32989 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T19:31:43.984285605+00:00"}"
>

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 40 warnings in 238.50s (0:03:58) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 15s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1074

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

Changes:


------------------------------------------
[...truncated 4.70 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40009 {created_time:"2022-11-12T13:32:35.105251696+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43211 {created_time:"2022-11-12T13:32:55.581796936+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41673 {created_time:"2022-11-12T13:32:59.991084997+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43351 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T13:33:01.73752231+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43175 {created_time:"2022-11-12T13:33:09.965438428+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40969 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T13:33:17.181290023+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 42 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34129 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T13:33:44.0482986+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42101 {created_time:"2022-11-12T13:33:49.473740655+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 600 warnings in 241.24s (0:04:01) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 1s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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

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

Changes:

[noreply] Fix checkArgument format string in TestStream (#24134)


------------------------------------------
[...truncated 4.82 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37041 {created_time:"2022-11-12T07:33:18.137182931+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44097 {created_time:"2022-11-12T07:33:39.846629087+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40171 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T07:33:42.303927319+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34631 {created_time:"2022-11-12T07:33:44.706148941+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38993 {created_time:"2022-11-12T07:33:52.318112314+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38499 {created_time:"2022-11-12T07:33:59.996375755+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 41 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41675 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T07:34:27.006446296+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43851 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T07:34:31.947642912+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 599 warnings in 241.13s (0:04:01) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 46s
78 actionable tasks: 50 executed, 26 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1072

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

Changes:

[noreply] upgrade testcontainer dependency (#24123)

[noreply] More cleanup containers (#24105)

[noreply] Bump github.com/aws/aws-sdk-go-v2/service/s3 in /sdks (#24112)

[noreply] Bump google.golang.org/api from 0.102.0 to 0.103.0 in /sdks (#24049)

[noreply] Update staging of Python wheels (#24114)

[noreply] Add a ValidatesContainer integration test for use_sibling_sdk_workers


------------------------------------------
[...truncated 4.65 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37489 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T01:31:47.588431524+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40399 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T01:32:08.564611179+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40021 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T01:32:11.421233801+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36877 {created_time:"2022-11-12T01:32:13.108066585+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39363 {created_time:"2022-11-12T01:32:20.027952256+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36789 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T01:32:27.007475461+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 41 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46015 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T01:32:52.459936239+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40877 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-12T01:32:58.009678714+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6706 deselected, 599 warnings in 227.64s (0:03:47) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 20s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1071

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

Changes:

[noreply] Add TFX support in pydoc (#23960)

[noreply] Bump cloud.google.com/go/bigtable from 1.17.0 to 1.18.0 in /sdks

[noreply] disable (#24121)

[noreply] Implement PubsubRowToMessage transform (#23897)


------------------------------------------
[...truncated 4.62 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41303 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T19:32:21.05996516+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40475 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T19:32:41.431423142+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46779 {created_time:"2022-11-11T19:32:44.308383125+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37497 {created_time:"2022-11-11T19:32:46.20020346+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46179 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T19:32:53.218743759+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35507 {created_time:"2022-11-11T19:33:00.714960946+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 42 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40055 {created_time:"2022-11-11T19:33:26.460228285+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33787 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T19:33:31.266285613+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6705 deselected, 600 warnings in 227.18s (0:03:47) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 47s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1070

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

Changes:


------------------------------------------
[...truncated 4.59 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38941 {created_time:"2022-11-11T13:40:52.852315308+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45777 {created_time:"2022-11-11T13:41:13.292811854+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46047 {created_time:"2022-11-11T13:41:16.094291003+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35081 {created_time:"2022-11-11T13:41:17.72421361+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43491 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T13:41:26.4079886+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36739 {created_time:"2022-11-11T13:41:33.625220107+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 41 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39041 {created_time:"2022-11-11T13:41:59.477852576+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39553 {created_time:"2022-11-11T13:42:04.448554843+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6705 deselected, 599 warnings in 616.14s (0:10:16) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 14m 55s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1069

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

Changes:


------------------------------------------
[...truncated 4.78 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43787 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T07:32:58.093750234+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41787 {created_time:"2022-11-11T07:33:20.289582706+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34893 {created_time:"2022-11-11T07:33:23.061469518+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35145 {created_time:"2022-11-11T07:33:25.42150545+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41947 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T07:33:33.006491739+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43809 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T07:33:42.153371955+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 42 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33323 {created_time:"2022-11-11T07:34:09.451754127+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36447 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T07:34:14.477214168+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6705 deselected, 600 warnings in 245.22s (0:04:05) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 30s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1068

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

Changes:

[noreply] Num failed inferences (#23830)

[noreply] Bump github.com/aws/aws-sdk-go-v2/config from 1.5.0 to 1.17.10 in /sdks

[noreply] Add blog post on new ML resources (#24071)

[noreply] fixing linter error (#24104)

[noreply] Support using BigQueryIO Storage Read API with SchemaTransforms (#23827)

[noreply] Wire SamzaPipelineOptions to Exeption listener interface (#24109)

[noreply] Remove TheNeuralBit from the pool of Python reviewers (#24108)


------------------------------------------
[...truncated 4.60 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39557 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T01:31:39.01595242+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35641 {created_time:"2022-11-11T01:31:59.690150389+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34755 {created_time:"2022-11-11T01:32:02.599529134+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35325 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T01:32:04.295703517+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41037 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T01:32:11.009054629+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39703 {created_time:"2022-11-11T01:32:17.853296875+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 40 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46761 {created_time:"2022-11-11T01:32:43.590900383+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41317 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-11T01:32:48.299471385+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6705 deselected, 598 warnings in 223.78s (0:03:43) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 21s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1067

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

Changes:

[Robert Bradshaw] Compute element counts for all PCollections.

[Robert Bradshaw] Add the ability to schedule splits on the ULR via a pipeline option.

[Robert Bradshaw] Add the a Reshuffle operation and use it in Create.

[Robert Bradshaw] Add dynamic splitting support to the worker.

[noreply] Update style

[Robert Bradshaw] Clarifying comments.

[Robert Bradshaw] Make mypy happy.

[Robert Bradshaw] Reduce flakiness of time-based split manager test.

[noreply] Fix FhirIO javadoc format broken (#24072)

[noreply] Bump github.com/aws/aws-sdk-go-v2/service/s3 in /sdks (#24077)

[noreply] [BEAM-12792] Install pipline dependencies to temporary venv (#16658)

[noreply] [Python]Set pickle library at the Pipeline creation stage (#24069)

[noreply] Improving stale container cleanup script (#24040)

[noreply] Add random string at the end of BigQuery query job name to make it

[noreply] [Playground] update snippet by persistence_key (#24056)

[noreply] [Tour Of Beam] handle CORS pre-flight requests (#24083)


------------------------------------------
[...truncated 4.58 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:double:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:timer:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:interval_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:length_prefix:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:global_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:param_windowed_value:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:state_backed_iterable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:custom_window:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:row:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:sharded_key:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:coder:nullable:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:progress_reporting:v0"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:harness_monitoring_infos:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:protocol:worker_status:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:combinefn:packed_python:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:version:sdk_base:apache/beam_python3.7_sdk:2.44.0.dev"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 capabilities: "beam:transform:to_string:v1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/10 19:32:25 WARN org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer: Hanged up for unknown endpoint.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/10 19:32:25 INFO org.apache.beam.runners.spark.SparkPipelineRunner: Job BeamApp-jenkins-1110193223-56e255f_370cea7a-0b05-4124-86df-d841dc69d57b finished.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/10 19:32:25 INFO org.sparkproject.jetty.server.AbstractConnector: Stopped Spark@72571ff9{HTTP/1.1, (http/1.1)}{127.0.0.1:4041}
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to DONE
INFO     root:custom_ptransform.py:67 Running second pipeline
INFO     root:pipeline.py:191 Missing pipeline option (runner). Executing pipeline using the default runner: DirectRunner.
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1149: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1151: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
    self._target(*self._args, **self._kwargs)
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6703 deselected, 40 warnings in 233.85s (0:03:53) =
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43665 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T19:33:04.476846092+00:00"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33037 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T19:33:05.201223927+00:00"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42407 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T19:33:27.896323219+00:00"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37219 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T19:33:35.974436506+00:00"}"
>


> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 13s
78 actionable tasks: 51 executed, 25 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1066

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

Changes:


------------------------------------------
[...truncated 4.67 MB...]
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41803 {created_time:"2022-11-10T13:33:15.506572465+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34163 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T13:33:37.699995212+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40473 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T13:33:41.448197702+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42105 {created_time:"2022-11-10T13:33:44.253533322+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38855 {created_time:"2022-11-10T13:33:52.417345391+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34813 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T13:34:00.240312627+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 45 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39005 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T13:34:28.642143406+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44607 {created_time:"2022-11-10T13:34:33.885013826+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 603 warnings in 258.56s (0:04:18) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED
> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 49s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

Publishing build scan...
https://gradle.com/s/2jbhz4lfmu2r4

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_Python_Examples_Spark #1065

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

Changes:


------------------------------------------
[...truncated 4.69 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36971 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T07:35:24.517511384+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45113 {created_time:"2022-11-10T07:35:45.549262994+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34869 {created_time:"2022-11-10T07:35:48.862415784+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39799 {created_time:"2022-11-10T07:35:51.113943427+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40301 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T07:35:59.952455852+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41449 {created_time:"2022-11-10T07:36:07.680762451+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 41 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40451 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T07:36:34.461627556+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41823 {created_time:"2022-11-10T07:36:39.916203625+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 599 warnings in 264.51s (0:04:24) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 9m 56s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1064

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

Changes:

[noreply] skip output coder field in exp request (#24066)

[noreply] test: add more tests to throughput estimator (#23915)

[noreply] Remove a duplicate label (#24043)

[noreply] Update datastore_wordcount.py (#23724)


------------------------------------------
[...truncated 4.78 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34835 {created_time:"2022-11-10T01:33:05.461311441+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43857 {created_time:"2022-11-10T01:33:26.455817905+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:32985 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T01:33:29.509823732+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36115 {created_time:"2022-11-10T01:33:31.76046664+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40341 {created_time:"2022-11-10T01:33:39.871352402+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38583 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T01:33:47.66328106+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 40 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40583 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-10T01:34:15.077385295+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38893 {created_time:"2022-11-10T01:34:20.096987373+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 598 warnings in 245.22s (0:04:05) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 37s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1063

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

Changes:

[Moritz Mack] [Spark Dataset runner] Enable projection pushdown for Spark dataset

[noreply] Fix dependency mismatch in Playground Java runner  (#24059)

[noreply] added comments for tensorflow notebook (#23726)

[noreply] Convert initialisms to all caps (#24061)


------------------------------------------
[...truncated 5.03 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46857 {created_time:"2022-11-09T19:40:49.377852693+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38563 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T19:41:12.122716196+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44719 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T19:41:15.433884665+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44883 {created_time:"2022-11-09T19:41:18.174589096+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42477 {created_time:"2022-11-09T19:41:27.379791563+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40763 {created_time:"2022-11-09T19:41:37.244722988+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46393 {created_time:"2022-11-09T19:42:08.418023965+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37399 {created_time:"2022-11-09T19:42:14.080293792+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 601 warnings in 362.02s (0:06:02) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 14m 59s
78 actionable tasks: 50 executed, 26 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1062

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

Changes:


------------------------------------------
[...truncated 5.14 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41039 {created_time:"2022-11-09T13:38:55.120092715+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40247 {created_time:"2022-11-09T13:39:20.779981406+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38015 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T13:39:27.76573729+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39271 {created_time:"2022-11-09T13:39:31.448438861+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45407 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T13:39:46.892144257+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46815 {created_time:"2022-11-09T13:40:00.1851323+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 37 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38501 {created_time:"2022-11-09T13:40:48.466330864+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37107 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T13:40:56.305643501+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 595 warnings in 450.58s (0:07:30) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 14m 4s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1061

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

Changes:

[noreply] Handle Avro schema generation for logical data types in

[noreply] [Go SDK] S3 implementation of the Beam filesystem (#23992)


------------------------------------------
[...truncated 4.69 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36255 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T07:32:55.405872087+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39711 {created_time:"2022-11-09T07:33:16.600774586+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:32969 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T07:33:19.842605421+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42355 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T07:33:21.714131483+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40941 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T07:33:29.155356898+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33935 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T07:33:37.127397916+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33089 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T07:34:03.843751054+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41249 {created_time:"2022-11-09T07:34:08.738630446+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 601 warnings in 238.60s (0:03:58) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 20s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1060

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

Changes:

[noreply] Retroactively announce Batched DoFn support in 2.42.0 Blog (#24011)

[noreply] Bump cloud.google.com/go/storage from 1.27.0 to 1.28.0 in /sdks (#24028)

[noreply] [Go] Add pipeline resource hints to CHANGES.md (#24036)


------------------------------------------
[...truncated 4.60 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36369 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T01:31:50.489776596+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34619 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T01:32:10.632964295+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34593 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T01:32:13.785157205+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39371 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T01:32:15.405416055+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:32875 {created_time:"2022-11-09T01:32:22.20193562+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44871 {created_time:"2022-11-09T01:32:29.312515131+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 42 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46533 {created_time:"2022-11-09T01:32:55.087276925+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44501 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-09T01:32:59.869260347+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 600 warnings in 222.89s (0:03:42) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 23s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1059

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

Changes:

[noreply] Update release notes. (#23986)

[noreply] [Go] Pipeline Resource Hints (#23990)

[noreply] [#21250] Trivial removal of loop over something that always has one

[noreply] Bump cloud.google.com/go/bigtable from 1.16.0 to 1.17.0 in /sdks

[noreply] Editorial review of the ML base API descriptions (#24026)

[noreply] Update my Twitter handle (#23653)


------------------------------------------
[...truncated 4.76 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46437 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T19:32:58.078818949+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35699 {created_time:"2022-11-08T19:33:19.083581289+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42933 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T19:33:22.191830185+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46117 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T19:33:24.022784564+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37445 {created_time:"2022-11-08T19:33:32.301854082+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34355 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T19:33:39.633589895+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 42 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38639 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T19:34:07.228747763+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33311 {created_time:"2022-11-08T19:34:12.538998987+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 600 warnings in 244.77s (0:04:04) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 28s
78 actionable tasks: 50 executed, 26 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1058

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

Changes:


------------------------------------------
[...truncated 4.56 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35937 {created_time:"2022-11-08T13:32:00.867636548+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43965 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T13:32:21.474977456+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37611 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T13:32:24.381757541+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:32879 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T13:32:25.879633849+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46101 {created_time:"2022-11-08T13:32:32.352757664+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43935 {created_time:"2022-11-08T13:32:38.785068373+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 41 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45171 {created_time:"2022-11-08T13:33:03.982796437+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43951 {created_time:"2022-11-08T13:33:08.628334873+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 599 warnings in 221.59s (0:03:41) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 37s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

Publishing build scan...
https://gradle.com/s/6rrmknvzlrp2u

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_Python_Examples_Spark #1057

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

Changes:


------------------------------------------
[...truncated 4.73 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38901 {created_time:"2022-11-08T07:32:58.891212888+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35677 {created_time:"2022-11-08T07:33:19.534202217+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44893 {created_time:"2022-11-08T07:33:23.180003205+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35627 {created_time:"2022-11-08T07:33:24.94513211+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37525 {created_time:"2022-11-08T07:33:32.894719272+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44291 {created_time:"2022-11-08T07:33:40.809287895+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 42 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33619 {created_time:"2022-11-08T07:34:06.85266+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33949 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T07:34:13.475812916+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 600 warnings in 241.28s (0:04:01) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 28s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1056

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

Changes:

[Robert Bradshaw] Better surfacing of Scala support via Scio.

[noreply] Add files then check cached diff to get untracked files

[noreply] Switch && for || to fix bug in #23889 resolution (#24017)


------------------------------------------
[...truncated 5.31 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33227 {created_time:"2022-11-08T01:41:10.028843591+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42953 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T01:41:38.363574373+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40607 {created_time:"2022-11-08T01:41:47.672334573+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46525 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T01:41:51.872949566+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37707 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T01:42:13.496625855+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40153 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T01:42:31.278894208+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34023 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-08T01:43:19.595145005+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38063 {created_time:"2022-11-08T01:43:30.090120575+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 601 warnings in 463.19s (0:07:43) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 16m 25s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

Publishing build scan...
https://gradle.com/s/7isuxumlb6yfe

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_Python_Examples_Spark #1055

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

Changes:

[bulat.safiullin] [Website] change case-study-card width on mobile

[vitaly.terentyev] Add sparkreceiver:2 module.

[vitaly.terentyev] Fix sparkreceiver dependencies

[noreply] Print diff and scope to state path

[noreply] Correctly print diff and swallow empty commits for the moment

[noreply] Remove quiet flag on debug

[noreply] Use git diff instead of git diff-index to avoid file timestamp changes

[noreply] Make `documentation/io/connectors/` canonical (#23877)

[noreply] [Tour of Beam] Learning content for "Introduction" module (#23085)

[noreply] feat: implement bigtable io connector with write capabilities (#23411)

[noreply] Bump google.golang.org/api from 0.101.0 to 0.102.0 in /sdks (#23957)

[noreply] Enforce splitting invariants by ensuring split state is reset in the


------------------------------------------
[...truncated 4.78 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:32911 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T19:32:20.449198868+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37317 {created_time:"2022-11-07T19:32:47.291919989+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46257 {created_time:"2022-11-07T19:32:53.292185423+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46611 {created_time:"2022-11-07T19:32:56.514289195+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43993 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T19:33:11.259579938+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35657 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T19:33:23.898856407+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 40 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45449 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T19:34:02.61177664+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35919 {created_time:"2022-11-07T19:34:08.393536569+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 598 warnings in 284.27s (0:04:44) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 41s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1054

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

Changes:


------------------------------------------
[...truncated 4.63 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46357 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T13:31:48.504060159+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36705 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T13:32:08.651255664+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40663 {created_time:"2022-11-07T13:32:11.786419047+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34403 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T13:32:13.284027681+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34935 {created_time:"2022-11-07T13:32:19.698968354+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36619 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T13:32:26.176292497+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41167 {created_time:"2022-11-07T13:32:51.726980199+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41065 {created_time:"2022-11-07T13:32:56.223393925+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 601 warnings in 232.73s (0:03:52) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 26s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

Publishing build scan...
https://gradle.com/s/3hy6qhrzsed5o

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_Python_Examples_Spark #1053

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

Changes:


------------------------------------------
[...truncated 4.59 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37943 {created_time:"2022-11-07T07:31:37.380690789+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41569 {created_time:"2022-11-07T07:31:58.279043873+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37015 {created_time:"2022-11-07T07:32:01.125644359+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46771 {created_time:"2022-11-07T07:32:02.721568404+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39201 {created_time:"2022-11-07T07:32:09.252365165+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33823 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T07:32:15.50775456+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 41 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40233 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T07:32:40.721598154+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45055 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T07:32:45.56680476+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 599 warnings in 219.42s (0:03:39) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 15s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1052

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

Changes:


------------------------------------------
[...truncated 4.60 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39415 {created_time:"2022-11-07T01:33:50.863106865+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36893 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T01:34:10.892053581+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33529 {created_time:"2022-11-07T01:34:13.665695425+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35555 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T01:34:15.357410654+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36465 {created_time:"2022-11-07T01:34:22.46556013+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39375 {created_time:"2022-11-07T01:34:28.763115356+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 42 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40365 {created_time:"2022-11-07T01:34:54.199445993+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39263 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-07T01:34:58.818637838+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 600 warnings in 353.23s (0:05:53) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 8m 28s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1051

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

Changes:

[noreply] Fix diff to stop repeated bot runs

[noreply] Fix pr bot - exec doesn't allow command chaining

[noreply] PR Bot - Dont throw error on return code 1


------------------------------------------
[...truncated 4.59 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34769 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T19:31:52.99821845+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33439 {created_time:"2022-11-06T19:32:13.486749013+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40501 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T19:32:17.666039082+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39859 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T19:32:19.310273714+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41185 {created_time:"2022-11-06T19:32:26.342133649+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42407 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T19:32:32.705492128+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 45 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39701 {created_time:"2022-11-06T19:32:59.505445055+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45685 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T19:33:05.072343313+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 603 warnings in 233.60s (0:03:53) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 32s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1050

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

Changes:


------------------------------------------
[...truncated 4.57 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45939 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T13:31:52.372091239+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37673 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T13:32:13.036754784+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45337 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T13:32:16.802235221+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:32879 {created_time:"2022-11-06T13:32:18.584789734+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42983 {created_time:"2022-11-06T13:32:25.896688802+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36509 {created_time:"2022-11-06T13:32:32.413749815+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 42 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38547 {created_time:"2022-11-06T13:33:00.323748873+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39561 {created_time:"2022-11-06T13:33:05.327367385+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 600 warnings in 230.68s (0:03:50) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 35s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1049

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

Changes:


------------------------------------------
[...truncated 4.59 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33767 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T07:31:48.901896871+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39539 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T07:32:08.829996684+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41579 {created_time:"2022-11-06T07:32:11.732746508+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44877 {created_time:"2022-11-06T07:32:13.372822582+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41861 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T07:32:20.933510149+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45505 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T07:32:27.867815365+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39389 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T07:32:53.556426733+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38289 {created_time:"2022-11-06T07:32:58.345953987+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 601 warnings in 220.75s (0:03:40) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 32s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1048

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

Changes:


------------------------------------------
[...truncated 4.61 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37751 {created_time:"2022-11-06T01:31:32.286999537+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46095 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T01:31:52.078741659+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34199 {created_time:"2022-11-06T01:31:54.995251572+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38503 {created_time:"2022-11-06T01:31:56.690741875+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34267 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T01:32:03.000171409+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42487 {created_time:"2022-11-06T01:32:09.870161972+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35313 {created_time:"2022-11-06T01:32:35.037077665+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43763 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-06T01:32:39.454377048+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 601 warnings in 214.19s (0:03:34) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 10s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1047

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

Changes:


------------------------------------------
[...truncated 4.55 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35563 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T19:32:37.797862157+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39353 {created_time:"2022-11-05T19:32:58.700014282+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36105 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T19:33:02.449335959+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40325 {created_time:"2022-11-05T19:33:04.242305997+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38763 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T19:33:12.389466543+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36473 {created_time:"2022-11-05T19:33:21.533124291+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38055 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T19:33:49.573937285+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36399 {created_time:"2022-11-05T19:33:54.706180628+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 601 warnings in 245.03s (0:04:05) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 7m 20s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1046

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

Changes:


------------------------------------------
[...truncated 4.54 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43665 {created_time:"2022-11-05T13:31:52.523443446+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35483 {created_time:"2022-11-05T13:32:13.723098592+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35891 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T13:32:16.535935687+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40319 {created_time:"2022-11-05T13:32:17.990880719+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45169 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T13:32:24.947706966+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41771 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T13:32:32.494652881+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 45 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37787 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T13:32:59.081911475+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40963 {created_time:"2022-11-05T13:33:03.85262647+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 603 warnings in 223.86s (0:03:43) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 34s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

Publishing build scan...
https://gradle.com/s/2at5uu2bepjqo

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_Python_Examples_Spark #1045

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

Changes:


------------------------------------------
[...truncated 4.57 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:32925 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T07:31:31.374146043+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39569 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T07:31:51.107553621+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42265 {created_time:"2022-11-05T07:31:53.720534181+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42479 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T07:31:56.168445246+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44243 {created_time:"2022-11-05T07:32:02.443580956+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33203 {created_time:"2022-11-05T07:32:09.228775143+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 44 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39053 {created_time:"2022-11-05T07:32:34.315872104+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33537 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T07:32:38.852595172+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 602 warnings in 212.57s (0:03:32) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 5s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1044

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

Changes:

[noreply] Add custom inference fn suport to the sklearn model handlers (#23642)

[noreply] removed trailing whitespace (#23987)

[noreply] Beam starter projects blog post (#23964)

[noreply] Enable more portable-runner requiring tests. (#23970)

[noreply] Website add and update logos (#23899)


------------------------------------------
[...truncated 4.63 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41155 {created_time:"2022-11-05T01:31:33.479942869+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45269 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T01:31:53.497571028+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37693 {created_time:"2022-11-05T01:31:56.608039068+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39411 {created_time:"2022-11-05T01:31:58.201405904+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34171 {created_time:"2022-11-05T01:32:04.737553978+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44769 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-05T01:32:11.309183849+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 39 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43889 {created_time:"2022-11-05T01:32:37.143674537+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33181 {created_time:"2022-11-05T01:32:46.856672683+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6702 deselected, 597 warnings in 223.45s (0:03:43) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 15s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1043

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

Changes:

[Robert Bradshaw] Move logging to its own module.

[Robert Bradshaw] Cleanup worker logging.

[Robert Bradshaw] Add basic counter setting and getting to the typescript SDK.

[Robert Bradshaw] Support metrics over the portability API.

[Robert Bradshaw] Add distribution metric type.

[Robert Bradshaw] old prettier change

[noreply] Immediately truncate full restriction on drain of periodic impulse

[noreply] [Task]: PR Bot will push commits only if they are non-empty (#23937)

[noreply] Bump cloud.google.com/go/datastore from 1.8.0 to 1.9.0 in /sdks (#23916)

[Robert Bradshaw] Remove obsolete TODO.

[Robert Bradshaw] Only report counters that were actually used.


------------------------------------------
[...truncated 4.57 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40591 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T19:31:37.428955781+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38037 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T19:31:58.104881673+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44051 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T19:32:01.094178153+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35767 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T19:32:02.746184636+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42325 {created_time:"2022-11-04T19:32:09.439315932+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39893 {created_time:"2022-11-04T19:32:15.991163649+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41701 {created_time:"2022-11-04T19:32:41.739706475+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40607 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T19:32:46.611754697+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6700 deselected, 601 warnings in 224.42s (0:03:44) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 15s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1042

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

Changes:

[noreply] Improve Iterator error message (#23972)

[noreply] Update watermark during periodic sequence/impulse (#23507)

[noreply] TFX image classification example (#23456)


------------------------------------------
[...truncated 4.61 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35811 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T13:31:26.356721234+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35337 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T13:31:46.717987621+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34419 {created_time:"2022-11-04T13:31:49.520045376+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46451 {created_time:"2022-11-04T13:31:51.101948753+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36537 {created_time:"2022-11-04T13:31:57.766828219+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43699 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T13:32:05.18926425+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 46 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45589 {created_time:"2022-11-04T13:32:30.879290826+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46521 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T13:32:35.45676164+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6700 deselected, 604 warnings in 221.17s (0:03:41) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 6s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1041

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

Changes:

[noreply] Make BatchConverter inference errors more helpful (#23965)


------------------------------------------
[...truncated 4.60 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39777 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T07:31:19.211486333+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35131 {created_time:"2022-11-04T07:31:39.138834426+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34811 {created_time:"2022-11-04T07:31:41.593254022+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42041 {created_time:"2022-11-04T07:31:43.162379451+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46387 {created_time:"2022-11-04T07:31:49.312672274+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39743 {created_time:"2022-11-04T07:31:55.414316447+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 39 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36109 {created_time:"2022-11-04T07:32:20.294901161+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45419 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T07:32:24.519188541+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6698 deselected, 597 warnings in 210.61s (0:03:30) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 52s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1040

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

Changes:

[noreply] [Tour Of Beam] saving user code (#23938)

[noreply] Disable flaky fn_api_runner tests (#23971)


------------------------------------------
[...truncated 4.59 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34337 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T01:31:12.304304225+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38163 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T01:31:32.21918437+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37611 {created_time:"2022-11-04T01:31:34.714860153+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41049 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T01:31:36.337175115+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37023 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T01:31:43.212674748+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33513 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-04T01:31:49.628247064+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 44 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:41951 {created_time:"2022-11-04T01:32:19.719385516+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:38687 {created_time:"2022-11-04T01:32:24.16766375+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6696 deselected, 602 warnings in 217.90s (0:03:37) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 54s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1039

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

Changes:

[ahmedabualsaud] emit load job IDs as soon as they come up

[ahmedabualsaud] style fix

[noreply] Concept guide on orchestrating Beam preprocessing (#23094)

[noreply] Initial draft of Batched DoFn user guide (#23909)

[noreply] WIP: Dataframe API ML preprocessing notebook (#22587)

[noreply] [Python] Added none check while accessing active_process_bundle (#23947)


------------------------------------------
[...truncated 4.62 MB...]
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:37833 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T19:31:49.18408301+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36247 {created_time:"2022-11-03T19:32:09.093622138+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43585 {created_time:"2022-11-03T19:32:11.701757142+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36113 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T19:32:13.272694324+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35153 {created_time:"2022-11-03T19:32:19.694030291+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:46169 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T19:32:25.984963988+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 42 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33945 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T19:32:56.915543123+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45363 {created_time:"2022-11-03T19:33:01.384299123+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
= 1 failed, 21 passed, 6 skipped, 6696 deselected, 600 warnings in 232.51s (0:03:52) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 6m 35s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1038

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

Changes:

[Moritz Mack] [Spark dataset runner] Add direct translation of Combine.GroupedValues


------------------------------------------
[...truncated 4.28 MB...]
E       is_bounded: BOUNDED
E       windowing_strategy_id: "ref_Windowing_Windowing_1"
E       }] were consumed but never produced

apache_beam/runners/portability/portable_runner.py:607: RuntimeError
------------------------------ Captured log call -------------------------------
INFO     apache_beam.runners.worker.worker_pool_main:worker_pool_main.py:93 Listening for workers at localhost:40341
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.7_sdk:2.44.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function pack_combiners at 0x7f24a255ab90> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function lift_combiners at 0x7f24a255ac20> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function sort_stages at 0x7f24a25503b0> ====================
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/03 13:33:42 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Staging artifacts for job_f18b6029-0e80-4840-985d-b29b50c4dc63.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/03 13:33:42 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Resolving artifacts for job_f18b6029-0e80-4840-985d-b29b50c4dc63.ref_Environment_default_environment_1.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/03 13:33:42 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Getting 0 artifacts for job_f18b6029-0e80-4840-985d-b29b50c4dc63.null.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/03 13:33:42 INFO org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Artifacts fully staged for job_f18b6029-0e80-4840-985d-b29b50c4dc63.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/03 13:33:42 INFO org.apache.beam.runners.spark.SparkJobInvoker: Invoking job BeamApp-jenkins-1103133342-7e8f83d1_a08846d5-109d-4cf9-a110-10f37084660a
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/03 13:33:42 INFO org.apache.beam.runners.jobsubmission.JobInvocation: Starting job invocation BeamApp-jenkins-1103133342-7e8f83d1_a08846d5-109d-4cf9-a110-10f37084660a
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:458 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:portable_runner.py:583 Job state changed to STOPPED
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to STARTING
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to RUNNING
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/03 13:33:42 ERROR org.apache.beam.runners.jobsubmission.JobInvocation: Error during job invocation BeamApp-jenkins-1103133342-7e8f83d1_a08846d5-109d-4cf9-a110-10f37084660a.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_60, PCollection=unique_name: "64SaveToBQ/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 coder_id: "ref_Coder_FastPrimitivesCoder_3"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 is_bounded: BOUNDED
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 windowing_strategy_id: "ref_Windowing_Windowing_1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 }] were consumed but never produced
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.buildNetwork(QueryablePipeline.java:234)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.<init>(QueryablePipeline.java:127)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.forTransforms(QueryablePipeline.java:107)
ERROR    root:portable_runner.py:577 java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_60, PCollection=unique_name: "64SaveToBQ/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.core.construction.graph.FusedPipeline.toPipeline(FusedPipeline.java:81)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.spark.SparkPipelineRunner.run(SparkPipelineRunner.java:110)
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to FAILED
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:86)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
INFO     apache_beam.io.gcp.tests.utils:utils.py:98 Clean up a BigQuery table with project: apache-beam-testing, dataset: FiltersTestIT, table: cold_days_1667482421540.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at java.lang.Thread.run(Thread.java:750)
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
    is_streaming_pipeline = p.options.view_as(StandardOptions).streaming

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: BeamDeprecationWarning: options is depreca  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
ted since First stable release. References to <pipeline>.options will not be supported
    experiments = p.options.view_as(DebugOptions).experiments or []

    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:44163 {created_time:"2022-11-03T13:34:32.774736681+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43881 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T13:34:37.823951006+00:00"}"
>

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1140: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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
    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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input - RuntimeError: Pipeline BeamApp-jenkins-1103133040-992dfa1_f8407976-39bf-4010-b275-f0fb5e0a9a9c failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_48, PCollection=unique_name: "90WriteTeamScoreSums/WriteToBigQuery/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_6"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
FAILED apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - RuntimeError: Pipeline BeamApp-jenkins-1103133335-d0afd12e_ac18338e-0ed5-420a-b24c-4cd9f7db3684 failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_52, PCollection=unique_name: "61Write/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
FAILED apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - RuntimeError: Pipeline BeamApp-jenkins-1103133342-7e8f83d1_a08846d5-109d-4cf9-a110-10f37084660a failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_60, PCollection=unique_name: "64SaveToBQ/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
ERROR apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.BigQueryTornadoesIT.monthly_tornadoes_1667482414499
ERROR apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.FiltersTestIT.cold_days_1667482421540
= 4 failed, 18 passed, 6 skipped, 6696 deselected, 40 warnings, 2 errors in 303.29s (0:05:03) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 8m 4s
78 actionable tasks: 51 executed, 25 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1037

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

Changes:


------------------------------------------
[...truncated 4.21 MB...]
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34295 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T07:30:13.782630284+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45257 {created_time:"2022-11-03T07:30:16.94825773+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:43303 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T07:30:18.32648751+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39675 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T07:30:24.593201375+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35531 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T07:30:31.269168853+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 45 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:45275 {created_time:"2022-11-03T07:30:55.075967365+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36947 {created_time:"2022-11-03T07:30:59.163808318+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input - RuntimeError: Pipeline BeamApp-jenkins-1103072927-19bd83a6_02454276-d737-4122-814f-d09e9952c3a4 failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_48, PCollection=unique_name: "90WriteTeamScoreSums/WriteToBigQuery/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_6"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
FAILED apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - RuntimeError: Pipeline BeamApp-jenkins-1103073008-da77875f_f5bfb42e-f79c-44cc-bfc8-cddac47254cb failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_52, PCollection=unique_name: "61Write/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
FAILED apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - RuntimeError: Pipeline BeamApp-jenkins-1103073014-ec8b8edc_8c8d8cbe-fcf6-450c-8033-97cb19a92200 failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_60, PCollection=unique_name: "64SaveToBQ/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
ERROR apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.BigQueryTornadoesIT.monthly_tornadoes_1667460608121
ERROR apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.FiltersTestIT.cold_days_1667460613869
= 4 failed, 18 passed, 6 skipped, 6696 deselected, 556 warnings, 2 errors in 144.21s (0:02:24) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 4m 30s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1036

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

Changes:

[noreply] Unify PerformanceTest metric dashboard naming and series (#23914)

[noreply] Update REVIEWERS.yaml (#23955)


------------------------------------------
[...truncated 4.20 MB...]
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:33023 {created_time:"2022-11-03T01:30:15.335759311+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36075 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T01:30:18.668676312+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:36761 {created_time:"2022-11-03T01:30:20.175215412+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:34959 {created_time:"2022-11-03T01:30:26.727675601+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39405 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T01:30:32.811552333+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/flight_delays_it_test.py: 43 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42699 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-03T01:30:57.161504965+00:00"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/_pytest/threadexception.py>:73: PytestUnhandledThreadExceptionWarning: Exception in thread read_grpc_client_inputs
  
  Traceback (most recent call last):
    File "/usr/lib/python3.10/threading.py", line 1009, in _bootstrap_inner
      self.run()
    File "/usr/lib/python3.10/threading.py", line 946, in run
      self._target(*self._args, **self._kwargs)
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 426, in __next__
      return self._next()
    File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/grpc/_channel.py",> line 826, in _next
      raise self
  grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
  	status = StatusCode.CANCELLED
  	details = "Multiplexer hanging up"
  	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:40967 {created_time:"2022-11-03T01:31:01.415282193+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
  >
  
    warnings.warn(pytest.PytestUnhandledThreadExceptionWarning(msg))

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input - RuntimeError: Pipeline BeamApp-jenkins-1103012927-c02e7293_5bcecf0a-5e1c-4b3e-a5de-a315d11846c7 failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_48, PCollection=unique_name: "90WriteTeamScoreSums/WriteToBigQuery/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_6"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
FAILED apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - RuntimeError: Pipeline BeamApp-jenkins-1103013009-544353da_076888ff-72bb-4703-ae74-c2b849740b1e failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_52, PCollection=unique_name: "61Write/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
FAILED apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - RuntimeError: Pipeline BeamApp-jenkins-1103013016-54e8a231_46a5f759-60ed-44f5-845d-7d7edff09f71 failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_60, PCollection=unique_name: "64SaveToBQ/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
ERROR apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.BigQueryTornadoesIT.monthly_tornadoes_1667439008973
ERROR apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.FiltersTestIT.cold_days_1667439015428
= 4 failed, 18 passed, 6 skipped, 6696 deselected, 554 warnings, 2 errors in 148.87s (0:02:28) =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 4m 36s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1035

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

Changes:

[Moritz Mack] Fix Spark 3 job-server jar path for Python test suites (closes #23935,

[noreply] [CdapIO] Add integration tests for SparkReceiverIO (#23305)

[noreply] [Go] Ensure iterated and emitted types are registered. (#23890)

[chamikaramj] Updates Multi-language Java examples documentation

[noreply] [Python SDK] Re-enable PipelineOptionsTest.test_display_data (#23787)


------------------------------------------
[...truncated 4.18 MB...]
This ensures that the pipeline finishes before this program exits.
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to STOPPED
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to STARTING
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to RUNNING
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/11/02 19:31:11 ERROR org.apache.beam.runners.jobsubmission.JobInvocation: Error during job invocation BeamApp-jenkins-1102193111-5529e9c8_c2322508-548c-40fb-8a83-78e6ee03dd17.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_60, PCollection=unique_name: "64SaveToBQ/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 coder_id: "ref_Coder_FastPrimitivesCoder_3"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 is_bounded: BOUNDED
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 windowing_strategy_id: "ref_Windowing_Windowing_1"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 }] were consumed but never produced
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.buildNetwork(QueryablePipeline.java:234)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.<init>(QueryablePipeline.java:127)
ERROR    root:portable_runner.py:577 java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_60, PCollection=unique_name: "64SaveToBQ/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.forTransforms(QueryablePipeline.java:107)
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to FAILED
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.core.construction.graph.FusedPipeline.toPipeline(FusedPipeline.java:81)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.spark.SparkPipelineRunner.run(SparkPipelineRunner.java:110)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:86)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
INFO     apache_beam.io.gcp.tests.utils:utils.py:98 Clean up a BigQuery table with project: apache-beam-testing, dataset: FiltersTestIT, table: cold_days_1667417470319.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 	at java.lang.Thread.run(Thread.java:750)
=============================== warnings summary ===============================
../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib; see the module's documentation for alternative uses
    from imp import load_source

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1140: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    temp_location = pcoll.pipeline.options.view_as(
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)

apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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

  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/runners/worker/data_plane.py",> line 671, in <lambda>
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2518: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    | _PassThroughThenCleanup(files_to_remove_pcoll))

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
    target=lambda: self._read_inputs(elements_iterator),
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:42627 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-02T19:32:03.485910194+00:00"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:35613 {grpc_message:"Multiplexer hanging up", grpc_status:1, created_time:"2022-11-02T19:32:04.306253166+00:00"}"
>

Exception in thread read_grpc_client_inputs:
Traceback (most recent call last):
  File "/usr/lib/python3.7/threading.py", line 926, in _bootstrap_inner
    self.run()
  File "/usr/lib/python3.7/threading.py", line 870, in run
    self._target(*self._args, **self._kwargs)
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 426, in __next__
    return self._next()
  File "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/2022703441/lib/python3.7/site-packages/grpc/_channel.py",> line 826, in _next
    raise self
grpc._channel._MultiThreadedRendezvous: <_MultiThreadedRendezvous of RPC that terminated with:
	status = StatusCode.CANCELLED
	details = "Multiplexer hanging up"
	debug_error_string = "UNKNOWN:Error received from peer ipv6:%5B::1%5D:39605 {created_time:"2022-11-02T19:32:05.70209712+00:00", grpc_status:1, grpc_message:"Multiplexer hanging up"}"
>

  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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
    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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/dataframe/io.py>:664: FutureWarning: WriteToFiles is experimental.
    sink=lambda _: _WriteToPandasFileSink(

apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py37.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input - RuntimeError: Pipeline BeamApp-jenkins-1102193019-7531c295_51faef0a-6036-480d-96c4-9dc622124346 failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_48, PCollection=unique_name: "90WriteTeamScoreSums/WriteToBigQuery/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_6"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
FAILED apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - RuntimeError: Pipeline BeamApp-jenkins-1102193104-3af00067_75a9f670-6363-4e24-89bd-3cd6f6bb082b failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_52, PCollection=unique_name: "61Write/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Pipeline has validations errors: 
Option environment_config is not compatible with environment type LOOPBACK.
FAILED apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - RuntimeError: Pipeline BeamApp-jenkins-1102193111-5529e9c8_c2322508-548c-40fb-8a83-78e6ee03dd17 failed in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes [PCollectionNode{id=ref_PCollection_PCollection_60, PCollection=unique_name: "64SaveToBQ/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
coder_id: "ref_Coder_FastPrimitivesCoder_3"
is_bounded: BOUNDED
windowing_strategy_id: "ref_Windowing_Windowing_1"
}] were consumed but never produced
ERROR apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.BigQueryTornadoesIT.monthly_tornadoes_1667417463408
ERROR apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.FiltersTestIT.cold_days_1667417470319
= 4 failed, 18 passed, 6 skipped, 6696 deselected, 40 warnings, 2 errors in 172.86s (0:02:52) =

> Task :sdks:python:test-suites:portable:py37:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 5m 38s
78 actionable tasks: 51 executed, 25 from cache, 2 up-to-date

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

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_Python_Examples_Spark #1034

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

Changes:

[bulat.safiullin] [Website] add shuffle to logos

[noreply] Bump actions/setup-java from 3.5.1 to 3.6.0 (#23797)


------------------------------------------
[...truncated 393.24 KB...]
apache_beam/examples/dataframe/wordcount_test.py:57: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/dataframe/wordcount.py:52: in run
    with beam.Pipeline(options=PipelineOptions(pipeline_args)) as p:
apache_beam/pipeline.py:597: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:574: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/portability/spark_runner.py:47: in run_pipeline
    return super().run_pipeline(pipeline, options)
apache_beam/runners/portability/portable_runner.py:439: in run_pipeline
    job_service_handle = self.create_job_service(options)
apache_beam/runners/portability/portable_runner.py:318: in create_job_service
    return self.create_job_service_handle(server.start(), options)
apache_beam/runners/portability/job_server.py:81: in start
    self._endpoint = self._job_server.start()
apache_beam/runners/portability/job_server.py:106: in start
    cmd, endpoint = self.subprocess_cmd_and_endpoint()
apache_beam/runners/portability/job_server.py:150: in subprocess_cmd_and_endpoint
    jar_path = self.local_jar(self.path_to_jar())
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.spark_runner.SparkJarJobServer object at 0x7fb93e4e0ca0>

    def path_to_jar(self):
      if self._jar:
        if not os.path.exists(self._jar):
          url = urllib.parse.urlparse(self._jar)
          if not url.scheme:
>           raise ValueError(
                'Unable to parse jar URL "%s". If using a full URL, make sure '
                'the scheme is specified. If using a local file path, make sure '
                'the file exists; you may have to first build the job server '
                'using `./gradlew runners:spark:3:job-server:shadowJar`.' %
                self._jar)
E           ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.

apache_beam/runners/portability/spark_runner.py:87: ValueError
------------------------------ Captured log call -------------------------------
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[set_column_DataFrame_140433601216176], ComputedExpression[set_index_DataFrame_140433601215408], ComputedExpression[pre_combine_sum_DataFrame_140433601213920]]:140433553357168]> for Stage[inputs={PlaceholderExpression[placeholder_DataFrame_140433563738000]}, partitioning=Arbitrary, ops=[ComputedExpression[set_column_DataFrame_140433601216176], ComputedExpression[set_index_DataFrame_140433601215408], ComputedExpression[pre_combine_sum_DataFrame_140433601213920]], outputs={ComputedExpression[pre_combine_sum_DataFrame_140433601213920], PlaceholderExpression[placeholder_DataFrame_140433563738000]}]
INFO     root:transforms.py:182 Computing dataframe stage <ComputeStage(PTransform) label=[[ComputedExpression[post_combine_sum_DataFrame_140433601208544]]:140433563734784]> for Stage[inputs={ComputedExpression[pre_combine_sum_DataFrame_140433601213920]}, partitioning=Index, ops=[ComputedExpression[post_combine_sum_DataFrame_140433601208544]], outputs={ComputedExpression[post_combine_sum_DataFrame_140433601208544]}]
INFO     apache_beam.io.fileio:fileio.py:595 Added temporary directory gs://temp-storage-for-end-to-end-tests/temp-it/.tempf1d0e01d-ea75-4922-ba34-4fc3a6a3ffb1
INFO     apache_beam.runners.worker.worker_pool_main:worker_pool_main.py:93 Listening for workers at localhost:40697
INFO     root:environments.py:376 Default Python SDK image for environment is apache/beam_python3.10_sdk:2.44.0.dev
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function pack_combiners at 0x7fb98172d870> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function lift_combiners at 0x7fb98172d900> ====================
INFO     apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 ==================== <function sort_stages at 0x7fb98172e050> ====================
=============================== warnings summary ===============================
../../build/gradleenv/-1720702907/lib/python3.10/site-packages/hdfs/config.py:15
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/hdfs/config.py>:15: DeprecationWarning: the imp module is deprecated in favour of importlib and slated for removal in Python 3.12; see the module's documentation for alternative uses
    from imp import load_source

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

../../build/gradleenv/-1720702907/lib/python3.10/site-packages/tenacity/_asyncio.py:42
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/tenacity/_asyncio.py>:42: DeprecationWarning: "@coroutine" decorator is deprecated since Python 3.8, use "async def" instead
    def call(self, fn, *args, **kwargs):

apache_beam/typehints/pandas_type_compatibility_test.py:66
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/examples/wordcount_debugging_test.py: 3 warnings
apache_beam/examples/wordcount_minimal_test.py: 3 warnings
apache_beam/examples/wordcount_test.py: 3 warnings
apache_beam/examples/complete/autocomplete_it_test.py: 3 warnings
apache_beam/examples/complete/distribopt_test.py: 3 warnings
apache_beam/examples/complete/tfidf_it_test.py: 10 warnings
apache_beam/examples/complete/top_wikipedia_sessions_it_test.py: 3 warnings
apache_beam/examples/complete/game/hourly_team_score_it_test.py: 2 warnings
apache_beam/examples/complete/game/user_score_it_test.py: 3 warnings
apache_beam/examples/cookbook/bigquery_side_input_it_test.py: 1 warning
apache_beam/examples/cookbook/coders_it_test.py: 3 warnings
apache_beam/examples/cookbook/custom_ptransform_it_test.py: 3 warnings
apache_beam/examples/cookbook/group_with_coder_test.py: 6 warnings
apache_beam/examples/cookbook/mergecontacts_test.py: 9 warnings
apache_beam/examples/cookbook/multiple_output_pardo_test.py: 3 warnings
apache_beam/examples/dataframe/flight_delays_it_test.py: 1 warning
apache_beam/examples/dataframe/wordcount_test.py: 3 warnings
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/build/gradleenv/-1720702907/lib/python3.10/site-packages/httplib2/__init__.py>:147: DeprecationWarning: ssl.PROTOCOL_TLS is deprecated
    context = ssl.SSLContext(DEFAULT_TLS_VERSION)

apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1992: 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/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1998: 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/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1140: 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::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1142: 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_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2485: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2487: 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/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2511: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:1988: 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::BigqueryTornadoesIT::test_bigquery_tornadoes_it
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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
    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
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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/wordcount_test.py::WordCountTest::test_basics
  <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/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

-- Docs: https://docs.pytest.org/en/stable/how-to/capture-warnings.html
- generated xml file: <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/pytest_postCommitExamples-spark-py310.xml> -
=========================== short test summary info ============================
FAILED apache_beam/examples/wordcount_debugging_test.py::WordCountDebuggingTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/wordcount_minimal_test.py::WordCountMinimalTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/wordcount_test.py::WordCountTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/autocomplete_it_test.py::AutocompleteIT::test_autocomplete_output_files_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/distribopt_test.py::DistribOptimizationTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/estimate_pi_it_test.py::EstimatePiIT::test_estimate_pi_output_file - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/tfidf_it_test.py::TfIdfIT::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/top_wikipedia_sessions_it_test.py::ComputeTopSessionsIT::test_top_wikipedia_sessions_output_files_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/game/hourly_team_score_it_test.py::HourlyTeamScoreIT::test_hourly_team_score_output_checksum_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/complete/game/user_score_it_test.py::UserScoreIT::test_userscore_output_checksum_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/bigquery_side_input_it_test.py::BigQuerySideInputIT::test_bigquery_side_input_it - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/coders_it_test.py::CodersIT::test_coders_output_files_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/custom_ptransform_it_test.py::CustomPTransformIT::test_custom_ptransform_output_files_on_small_input - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_with_type_check - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/group_with_coder_test.py::GroupWithCoderTest::test_basics_without_type_check - AssertionError: 'Unable to deterministically encode' not found in 'Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.'
FAILED apache_beam/examples/cookbook/mergecontacts_test.py::MergeContactsTest::test_mergecontacts - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/cookbook/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/dataframe/flight_delays_it_test.py::FlightDelaysTest::test_flight_delays - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
FAILED apache_beam/examples/dataframe/wordcount_test.py::WordCountTest::test_basics - ValueError: Unable to parse jar URL "<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/runners/spark/2/job-server/build/libs/beam-runners-spark-3-job-server-2.44.0-SNAPSHOT.jar".> If using a full URL, make sure the scheme is specified. If using a local file path, make sure the file exists; you may have to first build the job server using `./gradlew runners:spark:3:job-server:shadowJar`.
ERROR apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.BigQueryTornadoesIT.monthly_tornadoes_1667395752699
ERROR apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher - apache_beam.io.gcp.tests.utils.GcpTestIOError: BigQuery table does not exist: apache-beam-testing.FiltersTestIT.cold_days_1667395755192
= 21 failed, 1 passed, 6 skipped, 6696 deselected, 107 warnings, 2 errors in 31.70s =

> Task :sdks:python:test-suites:portable:py310:sparkExamples FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py37:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

2: Task failed with an exception.
-----------
* Where:
Script '<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Spark/ws/src/sdks/python/test-suites/portable/common.gradle'> line: 271

* What went wrong:
Execution failed for task ':sdks:python:test-suites:portable:py310:sparkExamples'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

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

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

BUILD FAILED in 2m 57s
78 actionable tasks: 49 executed, 27 from cache, 2 up-to-date

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

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