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

Changes:

[Robert Bradshaw] Python cross language docs.

[srohde] Add documentation link to the interactive environment

[noreply] Fix Small pytorch notebook bug fix (#23407)

[noreply] PubsubIO - Improve limit validations to consider attributes (#23023)

[noreply] Example of Online Clustering  (#23289)

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

[noreply] Increase Go Dataflow Postcommit timeout to 5h (#23423)

[noreply] [Playground] [Backend] Updating endpoints for playground examples

[noreply] Send JavaScript messages to Playground iframes when switching the

[noreply] [Playground] [Backend] Adding SDK to the example response (#22871)

[noreply] [Playground] [Backend] Removing the code related to the Cloud Storage

[Robert Bradshaw] Batch encoding and decoding of schema data.

[Robert Bradshaw] Add microbenchmark for batch row encoding.

[Robert Bradshaw] Add batch testing for standard row coders.

[noreply] [BEAM-10785] Change RowAsDictJsonCoder to not ensure ASCII while

[noreply] Update Python katas to latest version of EduTools and Beam 2.41 
(#23180)

[bulat.safiullin] [Website] fix navbar footer overlap #22698

[noreply] RunInference Benchmarks UI (#23426)

[noreply] Relax `pip` check in setup.py to allow installation via other package

[noreply] replaced tabs with spaces in readme file (#23446)

[noreply] [Playground] [Backend] Adding the tags field to the example response

[noreply] [Playground] [Backend] Edited the function for getting executable name

[noreply] Fix type inference for set/delete attr. (#23242)

[noreply] Support VR test including TestStream for Spark runner in streaming 
mode

[noreply] Add cron job to trigger Java JMH micro-benchmarks weekly  (#23388)

[noreply] JdbcIO fetchSize can be set to Integer.MIN_VALUE (#23444)

[noreply] [Tour Of Beam] return taskSnippetId/solutionSnippedId (#23419)

[noreply] Beam 21465 add requires stable input (#23230)

[noreply] [Website] Add new Java quickstart (#22747)

[ningkang0957] Prep sidepanel 3.0.0 release

[Robert Bradshaw] Require time-bound flag for non-UW streaming Python jobs for 
new SDKs.

[noreply] Fix JdbcIOIT, which seems to have never worked (#21796)

[noreply] Support DECIMAL logical type in python SDK (#23014)

[noreply] AI/ML pipelines master page documentation (#23443)

[noreply] Fix go fmt error (#23474)

[noreply] Revert "Add drop_example flag to the RunInference and Model Handler

[noreply] Documented supported PyTorch versions (#22974)

[noreply] [Go SDK] Add fake impulse for inputs in Xlang Transform (#23383)

[noreply] Write permissions for issue closer/assigner

[noreply] GA Migration Adding Removal of /.m2/settings.xml (#23481)

[noreply] Bump google-cloud-spanner version for py containers (#23480)

[Moritz Mack] Ensure Java JMH benchmark tasks run sequentially to prevent 
failure when

[Moritz Mack] Fix validation of measurement name in InfluxDBPublisher (addresses

[noreply] group_id (#23445)

[noreply] Give issue tagger permission to write issues (#23485)

[noreply] Update UID (#23486)

[noreply] Improve error message in GcsUtil (#23482)

[noreply] Add more typescript examples to the programming guide. (#23058)

[noreply] Merge pull request #23505: opt in for schema update. addresses #23504

[noreply] fix: only report backlog bytes on data records (#23493)

[noreply] Fix broken link in online clustering documentation (#23516)

[toran.sahu] fix typo - s/befrehand/beforehand

[noreply] Grant actions using GITHUB_TOKEN the appropriate permission set 
(#23521)

[Moritz Mack] Correctly detect retryable TransientKinesisExceptions (fixes 
#23517)

[noreply] Fix failing Py37 BQ file loads test (#23334)

[noreply] [Website] update links to https (#23523)

[noreply] Support custom avro DatumReader when reading from BigQuery (#22718)

[noreply] Rename 'clean' Gradle task that required Flutter and has been breaking

[noreply] Model handler unit test (#23506)

[noreply] Content/multi model pipelines (#23498)

[noreply] [Tour of Beam][Frontend] Content Tree and SDK models (#23316) (#23417)

[noreply] Fix bug where `astype(CategoricalDtype)` is rejected (#23513)

[noreply] Bump actions/stale from 5 to 6 (#23331)

[noreply] Fix small error message typo

[noreply] Fixing right nav on Get Started page (#23543)

[noreply] Bump google.golang.org/grpc from 1.49.0 to 1.50.0 in /sdks (#23533)

[noreply] Merge pull request #23547: update bom to the latest one.


------------------------------------------
[...truncated 1.61 MB...]
apache_beam/pipeline.py:598: in __exit__
    self.result.wait_until_finish()
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

self = <apache_beam.runners.portability.portable_runner.PipelineResult object 
at 0x7f9d29e27110>
duration = None

    def wait_until_finish(self, duration=None):
      """
      :param duration: The maximum time in milliseconds to wait for the result 
of
      the execution. If None or zero, will wait until the pipeline finishes.
      :return: The result of the pipeline, i.e. PipelineResult.
      """
      def read_messages():
        # type: () -> None
        previous_state = -1
        for message in self._message_stream:
          if message.HasField('message_response'):
            logging.log(
                MESSAGE_LOG_LEVELS[message.message_response.importance],
                "%s",
                message.message_response.message_text)
          else:
            current_state = message.state_response.state
            if current_state != previous_state:
              _LOGGER.info(
                  "Job state changed to %s",
                  self.runner_api_state_to_pipeline_state(current_state))
              previous_state = current_state
          self._messages.append(message)
    
      message_thread = threading.Thread(
          target=read_messages, name='wait_until_finish_read')
      message_thread.daemon = True
      message_thread.start()
    
      if duration:
        state_thread = threading.Thread(
            target=functools.partial(self._observe_state, message_thread),
            name='wait_until_finish_state_observer')
        state_thread.daemon = True
        state_thread.start()
        start_time = time.time()
        duration_secs = duration / 1000
        while (time.time() - start_time < duration_secs and
               state_thread.is_alive()):
          time.sleep(1)
      else:
        self._observe_state(message_thread)
    
      if self._runtime_exception:
>       raise self._runtime_exception
E       RuntimeError: Pipeline 
BeamApp-jenkins-1009015045-551aa352_cc23c528-dd04-4c27-8e7d-e63d791aafe6 failed 
in state FAILED: java.lang.IllegalArgumentException: PCollectionNodes 
[PCollectionNode{id=ref_PCollection_PCollection_60, PCollection=unique_name: 
"64SaveToBQ/BigQueryBatchFileLoads/TriggerLoadJobsWithoutTempTables.None"
E       coder_id: "ref_Coder_FastPrimitivesCoder_3"
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:34115
INFO     root:environments.py:376 Default Python SDK image for environment is 
apache/beam_python3.7_sdk:2.43.0.dev
INFO     
apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 
==================== <function pack_combiners at 0x7f9d5914a9e0> 
====================
INFO     
apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 
==================== <function lift_combiners at 0x7f9d5914aa70> 
====================
INFO     
apache_beam.runners.portability.fn_api_runner.translations:translations.py:714 
==================== <function sort_stages at 0x7f9d5914e200> 
====================
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/10/09 
01:50:45 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Staging 
artifacts for job_8cbe015c-e17d-4fd7-99d9-04e8dded3676.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/10/09 
01:50:45 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Resolving 
artifacts for 
job_8cbe015c-e17d-4fd7-99d9-04e8dded3676.ref_Environment_default_environment_1.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/10/09 
01:50:45 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Getting 0 
artifacts for job_8cbe015c-e17d-4fd7-99d9-04e8dded3676.null.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/10/09 
01:50:45 INFO 
org.apache.beam.runners.fnexecution.artifact.ArtifactStagingService: Artifacts 
fully staged for job_8cbe015c-e17d-4fd7-99d9-04e8dded3676.
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/10/09 
01:50:45 INFO org.apache.beam.runners.spark.SparkJobInvoker: Invoking job 
BeamApp-jenkins-1009015045-551aa352_cc23c528-dd04-4c27-8e7d-e63d791aafe6
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:126 22/10/09 
01:50:45 INFO org.apache.beam.runners.jobsubmission.JobInvocation: Starting job 
invocation 
BeamApp-jenkins-1009015045-551aa352_cc23c528-dd04-4c27-8e7d-e63d791aafe6
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/10/09 
01:50:45 ERROR org.apache.beam.runners.jobsubmission.JobInvocation: Error 
during job invocation 
BeamApp-jenkins-1009015045-551aa352_cc23c528-dd04-4c27-8e7d-e63d791aafe6.
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
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.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.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.QueryablePipeline.forTransforms(QueryablePipeline.java:107)
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:109)
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_1665280245249.
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>:2285:
 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>:2291:
 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>:1133:
 BeamDeprecationWarning: options is deprecated since First stable release. 
References to <pipeline>.options will not be supported
    temp_location = p.options.view_as(GoogleCloudOptions).temp_location

apache_beam/examples/complete/game/hourly_team_score_it_test.py::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>:1135:
 BeamDeprecationWarning: options is deprecated since First stable release. 
References to <pipeline>.options will not be supported
    p.options.view_as(GoogleCloudOptions).job_name or 'AUTOMATIC_JOB_NAME')

apache_beam/examples/cookbook/bigquery_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>:2775:
 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>:2777:
 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>:2808:
 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>:2281:
 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>:1126:
 BeamDeprecationWarning: options is deprecated since First stable release. 
References to <pipeline>.options will not be supported
    self.project = self.project or p.options.view_as(GoogleCloudOptions).project

apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
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
FAILED 
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
FAILED 
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
ERROR 
apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py::BigqueryTornadoesIT::test_bigquery_tornadoes_it
ERROR 
apache_beam/examples/cookbook/filters_test.py::FiltersTest::test_filters_output_bigquery_matcher
= 3 failed, 19 passed, 4 skipped, 6658 deselected, 40 warnings, 2 errors in 
282.51s (0:04:42) =

> 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:py39: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 10s
80 actionable tasks: 51 executed, 27 from cache, 2 up-to-date

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: [email protected]
For additional commands, e-mail: [email protected]

Reply via email to