You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by sr...@apache.org on 2018/08/06 14:29:36 UTC

[flink] branch master updated: [FLINK-9504][logging] Change the log-level of checkpoint duration to debug

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

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


The following commit(s) were added to refs/heads/master by this push:
     new b2a9131  [FLINK-9504][logging] Change the log-level of checkpoint duration to debug
b2a9131 is described below

commit b2a91310e1889116926026480c5e9a5e44c96e54
Author: minwenjun <mi...@didichuxing.com>
AuthorDate: Sat Jun 2 21:05:04 2018 +0800

    [FLINK-9504][logging] Change the log-level of checkpoint duration to debug
    
    This closes #6111.
---
 .../org/apache/flink/runtime/state/DefaultOperatorStateBackend.java | 4 ++--
 .../org/apache/flink/runtime/state/heap/HeapKeyedStateBackend.java  | 4 ++--
 .../flink/contrib/streaming/state/RocksDBKeyedStateBackend.java     | 6 +++---
 3 files changed, 7 insertions(+), 7 deletions(-)

diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/state/DefaultOperatorStateBackend.java b/flink-runtime/src/main/java/org/apache/flink/runtime/state/DefaultOperatorStateBackend.java
index dfff50d..d9fc41e 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/state/DefaultOperatorStateBackend.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/state/DefaultOperatorStateBackend.java
@@ -459,7 +459,7 @@ public class DefaultOperatorStateBackend implements OperatorStateBackend {
 					}
 
 					if (asynchronousSnapshots) {
-						LOG.info("DefaultOperatorStateBackend snapshot ({}, asynchronous part) in thread {} took {} ms.",
+						LOG.debug("DefaultOperatorStateBackend snapshot ({}, asynchronous part) in thread {} took {} ms.",
 							streamFactory, Thread.currentThread(), (System.currentTimeMillis() - asyncStartTime));
 					}
 
@@ -474,7 +474,7 @@ public class DefaultOperatorStateBackend implements OperatorStateBackend {
 			task.run();
 		}
 
-		LOG.info("DefaultOperatorStateBackend snapshot ({}, synchronous part) in thread {} took {} ms.",
+		LOG.debug("DefaultOperatorStateBackend snapshot ({}, synchronous part) in thread {} took {} ms.",
 				streamFactory, Thread.currentThread(), (System.currentTimeMillis() - syncStartTime));
 
 		return task;
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/state/heap/HeapKeyedStateBackend.java b/flink-runtime/src/main/java/org/apache/flink/runtime/state/heap/HeapKeyedStateBackend.java
index 6d2bfef..bc1e0f5 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/state/heap/HeapKeyedStateBackend.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/state/heap/HeapKeyedStateBackend.java
@@ -643,7 +643,7 @@ public class HeapKeyedStateBackend<K> extends AbstractKeyedStateBackend<K> {
 
 		@Override
 		public void logOperationCompleted(CheckpointStreamFactory streamFactory, long startTime) {
-			LOG.info("Heap backend snapshot ({}, asynchronous part) in thread {} took {} ms.",
+			LOG.debug("Heap backend snapshot ({}, asynchronous part) in thread {} took {} ms.",
 				streamFactory, Thread.currentThread(), (System.currentTimeMillis() - startTime));
 		}
 
@@ -838,7 +838,7 @@ public class HeapKeyedStateBackend<K> extends AbstractKeyedStateBackend<K> {
 
 			finalizeSnapshotBeforeReturnHook(task);
 
-			LOG.info("Heap backend snapshot (" + primaryStreamFactory + ", synchronous part) in thread " +
+			LOG.debug("Heap backend snapshot (" + primaryStreamFactory + ", synchronous part) in thread " +
 				Thread.currentThread() + " took " + (System.currentTimeMillis() - syncStartTime) + " ms.");
 
 			return task;
diff --git a/flink-state-backends/flink-statebackend-rocksdb/src/main/java/org/apache/flink/contrib/streaming/state/RocksDBKeyedStateBackend.java b/flink-state-backends/flink-statebackend-rocksdb/src/main/java/org/apache/flink/contrib/streaming/state/RocksDBKeyedStateBackend.java
index f7af354..bd0ddf2 100644
--- a/flink-state-backends/flink-statebackend-rocksdb/src/main/java/org/apache/flink/contrib/streaming/state/RocksDBKeyedStateBackend.java
+++ b/flink-state-backends/flink-statebackend-rocksdb/src/main/java/org/apache/flink/contrib/streaming/state/RocksDBKeyedStateBackend.java
@@ -1918,14 +1918,14 @@ public class RocksDBKeyedStateBackend<K> extends AbstractKeyedStateBackend<K> {
 
 						snapshotOperation.writeDBSnapshot();
 
-						LOG.info("Asynchronous RocksDB snapshot ({}, asynchronous part) in thread {} took {} ms.",
+						LOG.debug("Asynchronous RocksDB snapshot ({}, asynchronous part) in thread {} took {} ms.",
 							primaryStreamFactory, Thread.currentThread(), (System.currentTimeMillis() - startTime));
 
 						return snapshotOperation.getSnapshotResultStateHandle();
 					}
 				};
 
-			LOG.info("Asynchronous RocksDB snapshot ({}, synchronous part) in thread {} took {} ms.",
+			LOG.debug("Asynchronous RocksDB snapshot ({}, synchronous part) in thread {} took {} ms.",
 				primaryStreamFactory, Thread.currentThread(), (System.currentTimeMillis() - startTime));
 			return AsyncStoppableTaskWithCallback.from(ioCallable);
 		}
@@ -2363,7 +2363,7 @@ public class RocksDBKeyedStateBackend<K> extends AbstractKeyedStateBackend<K> {
 
 			writeDBSnapshot();
 
-			LOG.info("Asynchronous RocksDB snapshot ({}, asynchronous part) in thread {} took {} ms.",
+			LOG.debug("Asynchronous RocksDB snapshot ({}, asynchronous part) in thread {} took {} ms.",
 				checkpointStreamSupplier, Thread.currentThread(), (System.currentTimeMillis() - startTime));
 
 			return getSnapshotResultStateHandle();