See <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/1103/display/redirect?page=changes>
Changes: [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 181.23 MB...] INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.concurrent.Future.$anonfun$andThen$1(Future.scala:532) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.concurrent.impl.Promise.liftedTree1$1(Promise.scala:29) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.concurrent.impl.Promise.$anonfun$transform$1(Promise.scala:29) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:60) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.dispatch.BatchingExecutor$AbstractBatch.processBatch(BatchingExecutor.scala:63) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.dispatch.BatchingExecutor$BlockableBatch.$anonfun$run$1(BatchingExecutor.scala:100) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.runtime.java8.JFunction0$mcV$sp.apply(JFunction0$mcV$sp.java:12) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.concurrent.BlockContext$.withBlockContext(BlockContext.scala:81) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.dispatch.BatchingExecutor$BlockableBatch.run(BatchingExecutor.scala:100) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.dispatch.TaskInvocation.run(AbstractDispatcher.scala:49) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(ForkJoinExecutorConfigurator.scala:48) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at java.util.concurrent.ForkJoinTask.doExec(ForkJoinTask.java:289) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at java.util.concurrent.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1056) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at java.util.concurrent.ForkJoinPool.runWorker(ForkJoinPool.java:1692) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at java.util.concurrent.ForkJoinWorkerThread.run(ForkJoinWorkerThread.java:175) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Caused by: org.apache.flink.runtime.JobException: Recovery is suppressed by NoRestartBackoffTimeStrategy INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.handleFailure(ExecutionFailureHandler.java:138) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler.getFailureHandlingResult(ExecutionFailureHandler.java:82) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.scheduler.DefaultScheduler.handleTaskFailure(DefaultScheduler.java:301) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.scheduler.DefaultScheduler.maybeHandleTaskFailure(DefaultScheduler.java:291) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.scheduler.DefaultScheduler.updateTaskExecutionStateInternal(DefaultScheduler.java:282) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.scheduler.SchedulerBase.updateTaskExecutionState(SchedulerBase.java:739) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.scheduler.SchedulerNG.updateTaskExecutionState(SchedulerNG.java:78) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.jobmaster.JobMaster.updateTaskExecutionState(JobMaster.java:443) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at sun.reflect.GeneratedMethodAccessor29.invoke(Unknown Source) ERROR root:portable_runner.py:577 java.io.IOException: Insufficient number of network buffers: required 16, but only 1 available. The total number of network buffers is currently set to 2048 of 32768 bytes each. You can increase this number by setting the configuration keys 'taskmanager.memory.network.fraction', 'taskmanager.memory.network.min', and 'taskmanager.memory.network.max'. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at java.lang.reflect.Method.invoke(Method.java:498) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.lambda$handleRpcInvocation$1(AkkaRpcActor.java:304) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.concurrent.akka.ClassLoadingUtils.runWithContextClassLoader(ClassLoadingUtils.java:83) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcInvocation(AkkaRpcActor.java:302) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleRpcMessage(AkkaRpcActor.java:217) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor.handleRpcMessage(FencedAkkaRpcActor.java:78) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.rpc.akka.AkkaRpcActor.handleMessage(AkkaRpcActor.java:163) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:24) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.japi.pf.UnitCaseStatement.apply(CaseStatements.scala:20) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.PartialFunction.applyOrElse(PartialFunction.scala:123) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.PartialFunction.applyOrElse$(PartialFunction.scala:122) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.japi.pf.UnitCaseStatement.applyOrElse(CaseStatements.scala:20) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:171) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at scala.PartialFunction$OrElse.applyOrElse(PartialFunction.scala:172) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.actor.Actor.aroundReceive(Actor.scala:537) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.actor.Actor.aroundReceive$(Actor.scala:535) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.actor.AbstractActor.aroundReceive(AbstractActor.scala:220) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.actor.ActorCell.receiveMessage(ActorCell.scala:580) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.actor.ActorCell.invoke(ActorCell.scala:548) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.dispatch.Mailbox.processMailbox(Mailbox.scala:270) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.dispatch.Mailbox.run(Mailbox.scala:231) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at akka.dispatch.Mailbox.exec(Mailbox.scala:243) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 ... 4 more INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Caused by: java.io.IOException: Insufficient number of network buffers: required 16, but only 1 available. The total number of network buffers is currently set to 2048 of 32768 bytes each. You can increase this number by setting the configuration keys 'taskmanager.memory.network.fraction', 'taskmanager.memory.network.min', and 'taskmanager.memory.network.max'. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.io.network.buffer.NetworkBufferPool.internalCreateBufferPool(NetworkBufferPool.java:483) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.io.network.buffer.NetworkBufferPool.createBufferPool(NetworkBufferPool.java:461) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.io.network.partition.ResultPartitionFactory.lambda$createBufferPoolFactory$0(ResultPartitionFactory.java:279) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.io.network.partition.ResultPartition.setup(ResultPartition.java:160) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.io.network.partition.SortMergeResultPartition.setup(SortMergeResultPartition.java:190) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.taskmanager.Task.setupPartitionsAndGates(Task.java:959) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:652) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at org.apache.flink.runtime.taskmanager.Task.run(Task.java:563) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 at java.lang.Thread.run(Thread.java:750) INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.webmonitor.WebMonitorEndpoint lambda$shutDownInternal$5 INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Removing cache directory /tmp/flink-web-ui INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.rest.RestServerEndpoint lambda$closeAsync$1 INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Shut down complete. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.resourcemanager.ResourceManager closeJobManagerConnection INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Disconnect job manager 9ad672d70a2e2bf794b7e39696124576@akka://flink/user/rpc/jobmanager_3 for job 5ff72d4891bf7fa13cb8ef285effe72d from the resource manager. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.resourcemanager.ResourceManager deregisterApplication INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Shut down cluster because application is in CANCELED, diagnostics DispatcherResourceManagerComponent has been closed.. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent closeAsyncInternal INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Closing components. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess closeInternal INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Stopping SessionDispatcherLeaderProcess. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl closeAsync INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Stopping resource manager service. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0 INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: FileChannelManager removed spill file directory /tmp/flink-io-7d5c721e-4cdc-44be-9710-7c1774efc6fd INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.io.network.NettyShuffleEnvironment close INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Shutting down the network environment and its components. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.dispatcher.Dispatcher onStop INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Stopping dispatcher akka://flink/user/rpc/dispatcher_2. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.resourcemanager.slotmanager.DeclarativeSlotManager close INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Closing the slot manager. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.resourcemanager.slotmanager.DeclarativeSlotManager suspend INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Suspending the slot manager. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.dispatcher.Dispatcher terminateRunningJobs INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Stopping all currently running jobs of dispatcher akka://flink/user/rpc/dispatcher_2. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0 INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: FileChannelManager removed spill file directory /tmp/flink-netty-shuffle-727a44b7-f7c1-4a94-ab04-6fd654c2ab17 INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.taskexecutor.KvStateService shutdown INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Shutting down the kvState service and its components. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService stop INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Stop job leader service. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.dispatcher.Dispatcher lambda$onStop$1 INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Stopped dispatcher akka://flink/user/rpc/dispatcher_2. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.filecache.FileCache shutdown INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: removed file cache directory /tmp/flink-dist-cache-7ef576d4-a7c7-4541-b510-fd5a5ea536bd INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.taskexecutor.TaskExecutor handleOnStopException INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Stopped TaskExecutor akka://flink/user/rpc/taskmanager_0. INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 Nov 11, 2022 3:57:02 AM org.apache.flink.runtime.rpc.akka.AkkaRpcService stopService INFO apache_beam.utils.subprocess_server:subprocess_server.py:126 INFO: Stopping Akka RPC service. INFO apache_beam.runners.portability.portable_runner:portable_runner.py:583 Job state changed to FAILED =============================== warnings summary =============================== ../../build/gradleenv/2022703441/lib/python3.7/site-packages/hdfs/config.py:15 <https://ci-beam.apache.org/job/beam_PostCommit_Python_Examples_Flink/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_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>: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_Flink/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_Flink/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_Flink/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_Flink/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_Flink/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_Flink/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_Flink/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_Flink/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_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 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>: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_Flink/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_Flink/ws/src/sdks/python/pytest_postCommitExamples-flink-py37.xml> - =========================== short test summary info ============================ FAILED apache_beam/examples/complete/tfidf_it_test.py::TfIdfIT::test_basics - RuntimeError: Pipeline BeamApp-jenkins-1111034256-a7cb6bc7_1deb2a8f-c4d5-46d5-9089-a60577876d65 failed in state FAILED: java.io.IOException: Insufficient number of network buffers: required 16, but only 1 available. The total number of network buffers is currently set to 2048 of 32768 bytes each. You can increase this number by setting the configuration keys 'taskmanager.memory.network.fraction', 'taskmanager.memory.network.min', and 'taskmanager.memory.network.max'. 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/multiple_output_pardo_test.py::MultipleOutputParDo::test_multiple_output_pardo - RuntimeError: Pipeline BeamApp-jenkins-1111035653-742e9157_3825170d-345f-4bee-8582-66f18231ed77 failed in state FAILED: java.io.IOException: Insufficient number of network buffers: required 16, but only 1 available. The total number of network buffers is currently set to 2048 of 32768 bytes each. You can increase this number by setting the configuration keys 'taskmanager.memory.network.fraction', 'taskmanager.memory.network.min', and 'taskmanager.memory.network.max'. = 3 failed, 19 passed, 6 skipped, 6705 deselected, 41 warnings in 1079.10s (0:17:59) = > Task :sdks:python:test-suites:portable:py310:flinkExamples FAILED > Task :sdks:python:test-suites:portable:py37: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:py310: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. ============================================================================== 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: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. ============================================================================== * 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 20m 23s 133 actionable tasks: 87 executed, 44 from cache, 2 up-to-date Publishing build scan... https://gradle.com/s/ekrl4wix2zpxk 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]
