You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by ga...@apache.org on 2022/01/07 06:23:42 UTC

[flink-benchmarks] branch master updated: [FLINK-25556] Disabled the waiting for final checkpoint for all benchmarks.

This is an automated email from the ASF dual-hosted git repository.

gaoyunhaii pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink-benchmarks.git


The following commit(s) were added to refs/heads/master by this push:
     new 312eef1  [FLINK-25556] Disabled the waiting for final checkpoint for all benchmarks.
312eef1 is described below

commit 312eef146cc3f736f49a505612fd10a4816aea15
Author: Anton Kalashnikov <ka...@yandex.ru>
AuthorDate: Thu Jan 6 13:13:16 2022 +0100

    [FLINK-25556] Disabled the waiting for final checkpoint for all benchmarks.
    
    This closes #42.
---
 src/main/java/org/apache/flink/benchmark/FlinkEnvironmentContext.java | 4 ++++
 1 file changed, 4 insertions(+)

diff --git a/src/main/java/org/apache/flink/benchmark/FlinkEnvironmentContext.java b/src/main/java/org/apache/flink/benchmark/FlinkEnvironmentContext.java
index 4935e68..6f4cd62 100644
--- a/src/main/java/org/apache/flink/benchmark/FlinkEnvironmentContext.java
+++ b/src/main/java/org/apache/flink/benchmark/FlinkEnvironmentContext.java
@@ -26,6 +26,7 @@ import org.apache.flink.configuration.RestOptions;
 import org.apache.flink.runtime.minicluster.MiniCluster;
 import org.apache.flink.runtime.minicluster.MiniClusterConfiguration;
 import org.apache.flink.runtime.state.memory.MemoryStateBackend;
+import org.apache.flink.streaming.api.environment.ExecutionCheckpointingOptions;
 import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment;
 import org.apache.flink.test.util.MiniClusterPipelineExecutorServiceLoader;
 
@@ -103,6 +104,9 @@ public class FlinkEnvironmentContext {
                 NettyShuffleEnvironmentOptions.NETWORK_NUM_BUFFERS, NUM_NETWORK_BUFFERS);
         configuration.set(DeploymentOptions.TARGET, MiniClusterPipelineExecutorServiceLoader.NAME);
         configuration.set(DeploymentOptions.ATTACHED, true);
+        // It doesn't make sense to wait for the final checkpoint in benchmarks since it only prolongs
+        // the test but doesn't give any advantages.
+        configuration.set(ExecutionCheckpointingOptions.ENABLE_CHECKPOINTS_AFTER_TASKS_FINISH, false);
         return configuration;
     }
 }