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

Changes:

[rarokni] [BEAM-14307] Fix Slow Side input pattern bug in sample

[noreply] [BEAM-14316] Introducing KafkaIO.Read implementation compatibility

[noreply] [BEAM-14290] Address staticcheck warnings in the reflectx package

[noreply] [BEAM-14302] Simply bools in fn.go, genx_test.go (#17356)


------------------------------------------
[...truncated 93.91 MB...]
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
return self.do_fn_invoker.invoke_process(windowed_value)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 536, in invoke_process'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
self.output_processor.process_outputs('
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 1361, in process_outputs'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
self.main_receivers.receive(windowed_value)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/worker/operations.py";,>
 line 215, in receive'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
self.consumer.process(windowed_value)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/worker/operations.py";,>
 line 708, in process'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
delayed_applications = self.dofn_runner.process(o)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 1200, in process'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
self._reraise_augmented(exn)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 1281, in _reraise_augmented'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
raise new_exn.with_traceback(tb)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 1198, in process'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
return self.do_fn_invoker.invoke_process(windowed_value)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 536, in invoke_process'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
self.output_processor.process_outputs('
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/common.py";,>
 line 1334, in process_outputs'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    for 
result in results:'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/runners/worker/bundle_processor.py";,>
 line 1446, in process'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    for 
part, size in self.restriction_provider.split_and_size('
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/transforms/core.py";,>
 line 328, in split_and_size'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    for 
part in self.split(element, restriction):'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/io/iobase.py";,>
 line 1627, in split'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
estimated_size = restriction.source().estimate_size()'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py";,>
 line 762, in estimate_size'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    job 
= bq._start_query_job('
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/utils/retry.py";,>
 line 253, in wrapper'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
return fun(*args, **kwargs)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery_tools.py";,>
 line 605, in _start_query_job'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
return self._start_job(request)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery_tools.py";,>
 line 551, in _start_job'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
response = self.client.jobs.Insert(request, upload=upload)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/io/gcp/internal/clients/bigquery/bigquery_v2_client.py";,>
 line 343, in Insert'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
return self._RunMethod('
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/apitools/base/py/base_api.py";,>
 line 731, in _RunMethod'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
return self.ProcessHttpResponse(method_config, http_response, request)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/apitools/base/py/base_api.py";,>
 line 737, in ProcessHttpResponse'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
self.__ProcessHttpResponse(method_config, http_response, request))'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  File 
"<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/apitools/base/py/base_api.py";,>
 line 603, in __ProcessHttpResponse'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
raise exceptions.HttpError.FromResponse('
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 
b"RuntimeError: apitools.base.py.exceptions.HttpForbiddenError: HttpError 
accessing 
<https://bigquery.googleapis.com/bigquery/v2/projects/apache-beam-testing/jobs?alt=json>:
 response: <{'vary': 'Origin, X-Origin, Referer', 'content-type': 
'application/json; charset=UTF-8', 'date': 'Mon, 18 Apr 2022 21:49:23 GMT', 
'server': 'ESF', 'cache-control': 'private', 'x-xss-protection': '0', 
'x-frame-options': 'SAMEORIGIN', 'x-content-type-options': 'nosniff', 
'transfer-encoding': 'chunked', 'status': '403', 'content-length': '528', 
'-content-encoding': 'gzip'}>, content <{"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  
"error": {'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
"code": 403,'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
"message": "Access Denied: Table bigquery-samples:airline_ontime_data.flights: 
User does not have permission to query table 
bigquery-samples:airline_ontime_data.flights.",'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
"errors": ['
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'      {'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'        
"message": "Access Denied: Table bigquery-samples:airline_ontime_data.flights: 
User does not have permission to query table 
bigquery-samples:airline_ontime_data.flights.",'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'        
"domain": "global",'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'        
"reason": "accessDenied"'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'      }'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    ],'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'    
"status": "PERMISSION_DENIED"'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'  }'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'}'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b"> 
[while running 'read 
table/Read/SDFBoundedSourceReader/ParDo(SDFBoundedSourceDoFn)/SplitAndSize0']"
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b''
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:180)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.runners.fnexecution.control.FnApiControlClient$ResponseStreamObserver.onNext(FnApiControlClient.java:160)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.vendor.grpc.v1p43p2.io.grpc.stub.ServerCalls$StreamingServerCallHandler$StreamingServerCallListener.onMessage(ServerCalls.java:262)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.vendor.grpc.v1p43p2.io.grpc.ForwardingServerCallListener.onMessage(ForwardingServerCallListener.java:33)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.vendor.grpc.v1p43p2.io.grpc.Contexts$ContextualizedServerCallListener.onMessage(Contexts.java:76)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.vendor.grpc.v1p43p2.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailableInternal(ServerCallImpl.java:318)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.vendor.grpc.v1p43p2.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.messagesAvailable(ServerCallImpl.java:301)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.vendor.grpc.v1p43p2.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1MessagesAvailable.runInContext(ServerImpl.java:834)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.vendor.grpc.v1p43p2.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)'
INFO     apache_beam.runners.portability.portable_runner:portable_runner.py:580 
Job state changed to FAILED
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
org.apache.beam.vendor.grpc.v1p43p2.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\tat 
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)'
INFO     apache_beam.io.gcp.gcsio:gcsio.py:559 Starting the size estimation of 
the input
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'\t... 1 
more'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b''
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM 
org.apache.flink.runtime.resourcemanager.slotmanager.DeclarativeSlotManager 
close'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
Closing the slot manager.'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.dispatcher.Dispatcher 
terminateRunningJobs'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
Stopping all currently running jobs of dispatcher 
akka://flink/user/rpc/dispatcher_1.'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM 
org.apache.flink.runtime.resourcemanager.slotmanager.DeclarativeSlotManager 
suspend'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
Suspending the slot manager.'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.io.disk.FileChannelManagerImpl 
lambda$getFileCloser$0'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
FileChannelManager removed spill file directory 
/tmp/flink-io-bd5d5014-29c5-42de-87a3-7d9f3a7ccbf1'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.io.network.NettyShuffleEnvironment 
close'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
Shutting down the network environment and its components.'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.io.disk.FileChannelManagerImpl 
lambda$getFileCloser$0'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
FileChannelManager removed spill file directory 
/tmp/flink-netty-shuffle-127621ec-8e74-4509-904f-6a1feca7aaae'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.dispatcher.Dispatcher lambda$onStop$0'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
Stopped dispatcher akka://flink/user/rpc/dispatcher_1.'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.taskexecutor.KvStateService shutdown'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
Shutting down the kvState service and its components.'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService 
stop'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
Stop job leader service.'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.filecache.FileCache shutdown'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
removed file cache directory 
/tmp/flink-dist-cache-fc3d0267-cba1-4da2-9c6b-65b675c6b0f8'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.taskexecutor.TaskExecutor 
handleOnStopException'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
Stopped TaskExecutor akka://flink/user/rpc/taskmanager_0.'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'Apr 18, 
2022 9:49:25 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService stopService'
INFO     apache_beam.utils.subprocess_server:subprocess_server.py:125 b'INFO: 
Stopping Akka RPC service.'
INFO     apache_beam.io.gcp.gcsio:gcsio.py:572 Finished listing 0 files in 
0.034861087799072266 seconds.
--------------------------- Captured stdout teardown ---------------------------
FAILED                                                                   [ 95%]
=============================== warnings summary ===============================
apache_beam/io/filesystems_test.py:54
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/io/filesystems_test.py>:54:
 DeprecationWarning: invalid escape sequence \c
    self.assertIsNone(FileSystems.get_scheme('c:\\abc\cdf'))  # pylint: 
disable=anomalous-backslash-in-string

apache_beam/io/filesystems_test.py:62
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/apache_beam/io/filesystems_test.py>:62:
 DeprecationWarning: invalid escape sequence \d
    self.assertTrue(isinstance(FileSystems.get_filesystem('c:\\abc\def'),  # 
pylint: disable=anomalous-backslash-in-string

<unknown>:54
  <unknown>:54: DeprecationWarning: invalid escape sequence \c

<unknown>:62
  <unknown>:62: DeprecationWarning: invalid escape sequence \d

<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/build/gradleenv/2022703443/lib/python3.9/site-packages/tenacity/_asyncio.py>:42
  
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/build/gradleenv/2022703443/lib/python3.9/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/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_Flink/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_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2143:
 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_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2149:
 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_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1128:
 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_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery_file_loads.py>:1130:
 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_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2443:
 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_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2445:
 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_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2469:
 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_Flink/ws/src/sdks/python/apache_beam/io/gcp/bigquery.py>:2139:
 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_Flink/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_Flink/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_Flink/ws/src/sdks/python/apache_beam/dataframe/io.py>:629:
 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_Flink/ws/src/sdks/python/apache_beam/io/fileio.py>:550:
 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/latest/warnings.html
- generated xml file: 
<https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/ws/src/sdks/python/pytest_postCommitExamples-flink-py39.xml>
 -
= 2 failed, 20 passed, 1 skipped, 5293 deselected, 42 warnings in 412.73 
seconds =

> Task :sdks:python:test-suites:portable:py39:flinkExamples 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_Flink/ws/src/sdks/python/test-suites/portable/common.gradle'>
 line: 240

* What went wrong:
Execution failed for task 
':sdks:python:test-suites:portable:py37:flinkExamples'.
> 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.
> Run with --scan to get full insights.
==============================================================================

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

* What went wrong:
Execution failed for task 
':sdks:python:test-suites:portable:py39:flinkExamples'.
> 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.
> Run with --scan to get full insights.
==============================================================================

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

BUILD FAILED in 11m 21s
133 actionable tasks: 90 executed, 41 from cache, 2 up-to-date

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

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