You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by ma...@apache.org on 2023/02/13 09:06:59 UTC

[iotdb] branch IOTDB-5517 updated (a2ffa7b9f9 -> 6849a76a68)

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

marklau99 pushed a change to branch IOTDB-5517
in repository https://gitbox.apache.org/repos/asf/iotdb.git


    from a2ffa7b9f9 fix bug in switching os
     new 715c1a0192 edit metrics computation
     new 8193bef6b1 Merge branch 'IOTDB-5517' of https://github.com/apache/iotdb into IOTDB-5517
     new ec6b14936f finish the part of process io metrics
     new 6849a76a68 update dashboard

The 4 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .../Apache-IoTDB-DataNode-Dashboard.json           | 7807 +++++++++++---------
 .../iotdb/commons/service/metric/enums/Metric.java |    2 +-
 .../iotdb/db/service/metrics/DiskMetrics.java      |  173 +-
 .../metrics/io/AbstractDiskMetricsManager.java     |   56 +-
 .../metrics/io/LinuxDiskMetricsManager.java        |  201 +-
 .../service/metrics/io/MacDiskMetricsManager.java  |   24 +-
 .../metrics/io/WindowsDiskMetricsManager.java      |   36 +-
 7 files changed, 4525 insertions(+), 3774 deletions(-)


[iotdb] 01/04: edit metrics computation

Posted by ma...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

marklau99 pushed a commit to branch IOTDB-5517
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit 715c1a01922e58d4d66644d6d9030a6bb0fce015
Author: liuxuxin <li...@outlook.com>
AuthorDate: Mon Feb 13 15:04:22 2023 +0800

    edit metrics computation
---
 .../iotdb/commons/service/metric/enums/Metric.java |  1 +
 .../iotdb/db/service/metrics/DiskMetrics.java      | 28 ++++++++--------
 .../metrics/io/LinuxDiskMetricsManager.java        | 37 ++++++++++++++++------
 3 files changed, 43 insertions(+), 23 deletions(-)

diff --git a/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java b/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java
index acff8839f6..18cad095b0 100644
--- a/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java
+++ b/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java
@@ -29,6 +29,7 @@ public enum Metric {
   DISK_IO_SIZE,
   DISK_IO_OPS,
   DISK_IO_TIME,
+  DISK_IO_AVG_TIME,
   DISK_IO_SECTOR_NUM,
   PROCESS_IO_SIZE,
   PROCESS_IO_OPS,
diff --git a/server/src/main/java/org/apache/iotdb/db/service/metrics/DiskMetrics.java b/server/src/main/java/org/apache/iotdb/db/service/metrics/DiskMetrics.java
index 3ac3f087ec..c09b9b8542 100644
--- a/server/src/main/java/org/apache/iotdb/db/service/metrics/DiskMetrics.java
+++ b/server/src/main/java/org/apache/iotdb/db/service/metrics/DiskMetrics.java
@@ -43,7 +43,7 @@ public class DiskMetrics implements IMetricSet {
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getReadDataSizeForDisk().getOrDefault(diskID, 0L),
-          Tag.NAME.toString(),
+          Tag.TYPE.toString(),
           "read",
           Tag.NAME.toString(),
           diskID);
@@ -52,7 +52,7 @@ public class DiskMetrics implements IMetricSet {
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getWriteDataSizeForDisk().getOrDefault(diskID, 0L),
-          Tag.NAME.toString(),
+          Tag.TYPE.toString(),
           "write",
           Tag.NAME.toString(),
           diskID);
@@ -61,7 +61,7 @@ public class DiskMetrics implements IMetricSet {
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getReadOperationCountForDisk().getOrDefault(diskID, 0),
-          Tag.NAME.toString(),
+          Tag.TYPE.toString(),
           "read",
           Tag.NAME.toString(),
           diskID);
@@ -70,7 +70,7 @@ public class DiskMetrics implements IMetricSet {
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getWriteOperationCountForDisk().getOrDefault(diskID, 0),
-          Tag.NAME.toString(),
+          Tag.TYPE.toString(),
           "write",
           Tag.NAME.toString(),
           diskID);
@@ -79,7 +79,7 @@ public class DiskMetrics implements IMetricSet {
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getReadCostTimeForDisk().getOrDefault(diskID, 0L),
-          Tag.NAME.toString(),
+          Tag.TYPE.toString(),
           "read",
           Tag.NAME.toString(),
           diskID);
@@ -88,26 +88,26 @@ public class DiskMetrics implements IMetricSet {
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getWriteCostTimeForDisk().getOrDefault(diskID, 0L),
-          Tag.NAME.toString(),
+          Tag.TYPE.toString(),
           "write",
           Tag.NAME.toString(),
           diskID);
       metricService.createAutoGauge(
-          Metric.DISK_IO_TIME.toString(),
+          Metric.DISK_IO_AVG_TIME.toString(),
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getAvgReadCostTimeOfEachOpsForDisk().getOrDefault(diskID, 0.0).longValue(),
-          Tag.NAME.toString(),
-          "avg_read",
+          Tag.TYPE.toString(),
+          "read",
           Tag.NAME.toString(),
           diskID);
       metricService.createAutoGauge(
-          Metric.DISK_IO_TIME.toString(),
+          Metric.DISK_IO_AVG_TIME.toString(),
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getAvgWriteCostTimeOfEachOpsForDisk().getOrDefault(diskID, 0.0).longValue(),
-          Tag.NAME.toString(),
-          "avg_write",
+          Tag.TYPE.toString(),
+          "write",
           Tag.NAME.toString(),
           diskID);
       metricService.createAutoGauge(
@@ -115,7 +115,7 @@ public class DiskMetrics implements IMetricSet {
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getAvgSectorCountOfEachReadForDisk().getOrDefault(diskID, 0.0).longValue(),
-          Tag.NAME.toString(),
+          Tag.TYPE.toString(),
           "read",
           Tag.NAME.toString(),
           diskID);
@@ -124,7 +124,7 @@ public class DiskMetrics implements IMetricSet {
           MetricLevel.IMPORTANT,
           diskMetricsManager,
           x -> x.getAvgSectorCountOfEachWriteForDisk().getOrDefault(diskID, 0.0).longValue(),
-          Tag.NAME.toString(),
+          Tag.TYPE.toString(),
           "write",
           Tag.NAME.toString(),
           diskID);
diff --git a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/LinuxDiskMetricsManager.java b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/LinuxDiskMetricsManager.java
index 14e4a27600..f724f801dc 100644
--- a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/LinuxDiskMetricsManager.java
+++ b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/LinuxDiskMetricsManager.java
@@ -45,9 +45,10 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
   private final int DISK_SECTOR_WRITE_COUNT_OFFSET = 10;
   private final int DISK_WRITE_TIME_COST_OFFSET = 11;
   private final int DISK_IO_TOTAL_TIME_OFFSET = 13;
-  private final long UPDATE_INTERVAL = 10000L;
+  private final long UPDATE_SMALLEST_INTERVAL = 10000L;
   private Set<String> diskIDSet;
   private long lastUpdateTime = 0L;
+  private long updateInterval = 1L;
   private String[] dataNodeProcessId;
   private String[] configNodeProcessId;
   private final Map<String, Integer> lastReadOperationCountForDisk = new HashMap<>();
@@ -71,7 +72,7 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
     Map<String, Long> readDataMap = new HashMap<>();
     for (Map.Entry<String, Long> entry : incrementReadSectorCountForDisk.entrySet()) {
       // the data size in each sector is 512 byte
-      readDataMap.put(entry.getKey(), entry.getValue() * 512L / 1024L);
+      readDataMap.put(entry.getKey(), entry.getValue() * 512L / 1024L / updateInterval * 1000L);
     }
     return readDataMap;
   }
@@ -82,7 +83,7 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
     Map<String, Long> writeDataMap = new HashMap<>();
     for (Map.Entry<String, Long> entry : incrementWriteSectorCountForDisk.entrySet()) {
       // the data size in each sector is 512 byte
-      writeDataMap.put(entry.getKey(), entry.getValue() * 512L / 1024L);
+      writeDataMap.put(entry.getKey(), entry.getValue() * 512L / 1024L / updateInterval * 1000L);
     }
     return writeDataMap;
   }
@@ -90,22 +91,38 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
   @Override
   public Map<String, Integer> getReadOperationCountForDisk() {
     checkUpdate();
-    return incrementReadOperationCountForDisk;
+    Map<String, Integer> incrementMapPerSecond = new HashMap<>();
+    for (Map.Entry<String, Integer> entry : incrementReadOperationCountForDisk.entrySet()) {
+      incrementMapPerSecond.put(entry.getKey(), (int) (entry.getValue() / updateInterval * 1000L));
+    }
+    return incrementMapPerSecond;
   }
 
   @Override
   public Map<String, Integer> getWriteOperationCountForDisk() {
-    return incrementWriteOperationCountForDisk;
+    Map<String, Integer> incrementMapPerSecond = new HashMap<>();
+    for (Map.Entry<String, Integer> entry : incrementWriteOperationCountForDisk.entrySet()) {
+      incrementMapPerSecond.put(entry.getKey(), (int) (entry.getValue() / updateInterval * 1000L));
+    }
+    return incrementMapPerSecond;
   }
 
   @Override
   public Map<String, Long> getReadCostTimeForDisk() {
-    return incrementReadTimeCostForDisk;
+    Map<String, Long> incrementMapPerSecond = new HashMap<>();
+    for (Map.Entry<String, Long> entry : incrementReadTimeCostForDisk.entrySet()) {
+      incrementMapPerSecond.put(entry.getKey(), entry.getValue() / updateInterval * 1000L);
+    }
+    return incrementMapPerSecond;
   }
 
   @Override
   public Map<String, Long> getWriteCostTimeForDisk() {
-    return incrementWriteTimeCostForDisk;
+    Map<String, Long> incrementMapPerSecond = new HashMap<>();
+    for (Map.Entry<String, Long> entry : incrementWriteTimeCostForDisk.entrySet()) {
+      incrementMapPerSecond.put(entry.getKey(), entry.getValue() / updateInterval * 1000L);
+    }
+    return incrementMapPerSecond;
   }
 
   @Override
@@ -213,7 +230,9 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
   }
 
   private void updateDiskInfo() {
-    lastUpdateTime = System.currentTimeMillis();
+    long currentTime = System.currentTimeMillis();
+    updateInterval = currentTime - lastUpdateTime;
+    lastUpdateTime = currentTime;
     File diskStatsFile = new File(DISK_STATS_FILE_PATH);
     if (!diskStatsFile.exists()) {
       return;
@@ -293,7 +312,7 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
   }
 
   private void checkUpdate() {
-    if (System.currentTimeMillis() - lastUpdateTime > UPDATE_INTERVAL) {
+    if (System.currentTimeMillis() - lastUpdateTime > UPDATE_SMALLEST_INTERVAL) {
       updateDiskInfo();
     }
   }


[iotdb] 03/04: finish the part of process io metrics

Posted by ma...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

marklau99 pushed a commit to branch IOTDB-5517
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit ec6b14936f741c24fb516f843c0869c080d4f29e
Author: liuxuxin <li...@outlook.com>
AuthorDate: Mon Feb 13 17:06:10 2023 +0800

    finish the part of process io metrics
---
 .../iotdb/commons/service/metric/enums/Metric.java |   1 -
 .../iotdb/db/service/metrics/DiskMetrics.java      | 145 +++++++++---------
 .../metrics/io/AbstractDiskMetricsManager.java     |  56 +++++--
 .../metrics/io/LinuxDiskMetricsManager.java        | 166 +++++++++++++++++----
 .../service/metrics/io/MacDiskMetricsManager.java  |  24 +--
 .../metrics/io/WindowsDiskMetricsManager.java      |  36 +++--
 6 files changed, 288 insertions(+), 140 deletions(-)

diff --git a/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java b/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java
index 18cad095b0..92ea5cb987 100644
--- a/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java
+++ b/node-commons/src/main/java/org/apache/iotdb/commons/service/metric/enums/Metric.java
@@ -33,7 +33,6 @@ public enum Metric {
   DISK_IO_SECTOR_NUM,
   PROCESS_IO_SIZE,
   PROCESS_IO_OPS,
-  PROCESS_IO_TIME,
   MEM,
   CACHE,
   CACHE_HIT,
diff --git a/server/src/main/java/org/apache/iotdb/db/service/metrics/DiskMetrics.java b/server/src/main/java/org/apache/iotdb/db/service/metrics/DiskMetrics.java
index c09b9b8542..a152c834ae 100644
--- a/server/src/main/java/org/apache/iotdb/db/service/metrics/DiskMetrics.java
+++ b/server/src/main/java/org/apache/iotdb/db/service/metrics/DiskMetrics.java
@@ -23,6 +23,8 @@ import org.apache.iotdb.commons.service.metric.enums.Metric;
 import org.apache.iotdb.commons.service.metric.enums.Tag;
 import org.apache.iotdb.db.service.metrics.io.AbstractDiskMetricsManager;
 import org.apache.iotdb.metrics.AbstractMetricService;
+import org.apache.iotdb.metrics.config.MetricConfig;
+import org.apache.iotdb.metrics.config.MetricConfigDescriptor;
 import org.apache.iotdb.metrics.metricsets.IMetricSet;
 import org.apache.iotdb.metrics.utils.MetricLevel;
 import org.apache.iotdb.metrics.utils.MetricType;
@@ -32,6 +34,7 @@ import java.util.Set;
 public class DiskMetrics implements IMetricSet {
   private final AbstractDiskMetricsManager diskMetricsManager =
       AbstractDiskMetricsManager.getDiskMetricsManager();
+  private final MetricConfig metricConfig = MetricConfigDescriptor.getInstance().getMetricConfig();
 
   @Override
   public void bindTo(AbstractMetricService metricService) {
@@ -74,6 +77,24 @@ public class DiskMetrics implements IMetricSet {
           "write",
           Tag.NAME.toString(),
           diskID);
+      metricService.createAutoGauge(
+          Metric.DISK_IO_OPS.toString(),
+          MetricLevel.IMPORTANT,
+          diskMetricsManager,
+          x -> x.getMergedReadOperationForDisk().getOrDefault(diskID, 0L),
+          Tag.TYPE.toString(),
+          "merged_write",
+          Tag.NAME.toString(),
+          diskID);
+      metricService.createAutoGauge(
+          Metric.DISK_IO_OPS.toString(),
+          MetricLevel.IMPORTANT,
+          diskMetricsManager,
+          x -> x.getMergedWriteOperationForDisk().getOrDefault(diskID, 0L),
+          Tag.TYPE.toString(),
+          "merged_read",
+          Tag.NAME.toString(),
+          diskID);
       metricService.createAutoGauge(
           Metric.DISK_IO_TIME.toString(),
           MetricLevel.IMPORTANT,
@@ -131,78 +152,60 @@ public class DiskMetrics implements IMetricSet {
     }
 
     // metrics for datanode and config node
-    metricService.createAutoGauge(
-        Metric.PROCESS_IO_SIZE.toString(),
-        MetricLevel.IMPORTANT,
-        diskMetricsManager,
-        AbstractDiskMetricsManager::getReadDataSizeForDataNode,
-        Tag.NAME.toString(),
-        "datanode",
-        Tag.NAME.toString(),
-        "read");
-    metricService.createAutoGauge(
-        Metric.PROCESS_IO_SIZE.toString(),
-        MetricLevel.IMPORTANT,
-        diskMetricsManager,
-        AbstractDiskMetricsManager::getWriteDataSizeForDataNode,
-        Tag.NAME.toString(),
-        "datanode",
-        Tag.NAME.toString(),
-        "write");
     metricService.createAutoGauge(
         Metric.PROCESS_IO_OPS.toString(),
         MetricLevel.IMPORTANT,
         diskMetricsManager,
-        AbstractDiskMetricsManager::getReadOpsCountForDataNode,
-        Tag.NAME.toString(),
-        "datanode",
+        AbstractDiskMetricsManager::getReadOpsCountForProcess,
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
         "read");
     metricService.createAutoGauge(
         Metric.PROCESS_IO_OPS.toString(),
         MetricLevel.IMPORTANT,
         diskMetricsManager,
-        AbstractDiskMetricsManager::getWriteOpsCountForDataNode,
-        Tag.NAME.toString(),
-        "datanode",
+        AbstractDiskMetricsManager::getWriteOpsCountForProcess,
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
         "write");
     metricService.createAutoGauge(
-        Metric.PROCESS_IO_TIME.toString(),
+        Metric.PROCESS_IO_SIZE.toString(),
         MetricLevel.IMPORTANT,
         diskMetricsManager,
-        AbstractDiskMetricsManager::getReadCostTimeForDataNode,
-        Tag.NAME.toString(),
-        "datanode",
+        AbstractDiskMetricsManager::getActualReadDataSizeForProcess,
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
-        "read");
+        "actual_read");
     metricService.createAutoGauge(
-        Metric.PROCESS_IO_TIME.toString(),
+        Metric.PROCESS_IO_SIZE.toString(),
         MetricLevel.IMPORTANT,
         diskMetricsManager,
-        AbstractDiskMetricsManager::getWriteCostTimeForDataNode,
+        AbstractDiskMetricsManager::getActualWriteDataSizeForProcess,
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
-        "datanode",
-        Tag.NAME.toString(),
-        "write");
+        "actual_write");
     metricService.createAutoGauge(
-        Metric.PROCESS_IO_TIME.toString(),
+        Metric.PROCESS_IO_SIZE.toString(),
         MetricLevel.IMPORTANT,
         diskMetricsManager,
-        AbstractDiskMetricsManager::getAvgReadCostTimeOfEachOpsForDataNode,
-        Tag.NAME.toString(),
-        "datanode",
+        AbstractDiskMetricsManager::getAttemptReadSizeForProcess,
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
-        "avg_read");
+        "attempt_read");
     metricService.createAutoGauge(
-        Metric.PROCESS_IO_TIME.toString(),
+        Metric.PROCESS_IO_SIZE.toString(),
         MetricLevel.IMPORTANT,
         diskMetricsManager,
-        AbstractDiskMetricsManager::getAvgWriteCostTimeOfEachOpsForDataNode,
-        Tag.NAME.toString(),
-        "datanode",
+        AbstractDiskMetricsManager::getAttemptWriteSizeForProcess,
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
-        "avg_write");
+        "attempt_write");
   }
 
   @Override
@@ -286,58 +289,44 @@ public class DiskMetrics implements IMetricSet {
     metricService.remove(
         MetricType.AUTO_GAUGE,
         Metric.PROCESS_IO_SIZE.toString(),
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
-        "datanode",
-        Tag.NAME.toString(),
-        "read");
+        "actual_read");
     metricService.remove(
         MetricType.AUTO_GAUGE,
         Metric.PROCESS_IO_SIZE.toString(),
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
-        "datanode",
-        Tag.NAME.toString(),
-        "write");
+        "actual_write");
     metricService.remove(
         MetricType.AUTO_GAUGE,
-        Metric.PROCESS_IO_OPS.toString(),
-        Tag.NAME.toString(),
-        "datanode",
+        Metric.PROCESS_IO_SIZE.toString(),
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
-        "read");
+        "attempt_read");
     metricService.remove(
         MetricType.AUTO_GAUGE,
-        Metric.PROCESS_IO_OPS.toString(),
-        Tag.NAME.toString(),
-        "datanode",
+        Metric.PROCESS_IO_SIZE.toString(),
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
-        "write");
+        "attempt_write");
     metricService.remove(
         MetricType.AUTO_GAUGE,
-        Metric.PROCESS_IO_TIME.toString(),
-        Tag.NAME.toString(),
-        "datanode",
+        Metric.PROCESS_IO_OPS.toString(),
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
         "read");
     metricService.remove(
         MetricType.AUTO_GAUGE,
-        Metric.PROCESS_IO_TIME.toString(),
-        Tag.NAME.toString(),
-        "datanode",
+        Metric.PROCESS_IO_OPS.toString(),
+        Tag.FROM.toString(),
+        diskMetricsManager.getProcessName(),
         Tag.NAME.toString(),
         "write");
-    metricService.remove(
-        MetricType.AUTO_GAUGE,
-        Metric.PROCESS_IO_TIME.toString(),
-        Tag.NAME.toString(),
-        "datanode",
-        Tag.NAME.toString(),
-        "avg_read");
-    metricService.remove(
-        MetricType.AUTO_GAUGE,
-        Metric.PROCESS_IO_TIME.toString(),
-        Tag.NAME.toString(),
-        "datanode",
-        Tag.NAME.toString(),
-        "avg_write");
   }
 }
diff --git a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/AbstractDiskMetricsManager.java b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/AbstractDiskMetricsManager.java
index d15ca7f881..b8e270e501 100644
--- a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/AbstractDiskMetricsManager.java
+++ b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/AbstractDiskMetricsManager.java
@@ -19,10 +19,46 @@
 
 package org.apache.iotdb.db.service.metrics.io;
 
+import org.apache.iotdb.metrics.config.MetricConfigDescriptor;
+
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import java.io.BufferedReader;
+import java.io.IOException;
+import java.io.InputStreamReader;
 import java.util.Map;
 import java.util.Set;
 
 public abstract class AbstractDiskMetricsManager {
+  private final Logger log = LoggerFactory.getLogger(AbstractDiskMetricsManager.class);
+  String processName;
+
+  protected AbstractDiskMetricsManager() {
+    try {
+      Process process = Runtime.getRuntime().exec("jps");
+      String pid = MetricConfigDescriptor.getInstance().getMetricConfig().getPid();
+      // In case of we cannot get the process name,
+      // process name is pid by default
+      processName = pid;
+      try (BufferedReader input =
+          new BufferedReader(new InputStreamReader(process.getInputStream()))) {
+        String line;
+        while ((line = input.readLine()) != null) {
+          if (line.startsWith(pid + " ")) {
+            processName = line.split("\\s")[1];
+            break;
+          }
+        }
+      }
+    } catch (IOException e) {
+      log.warn("Failed to get the process name", e);
+    }
+  }
+
+  public String getProcessName() {
+    return processName;
+  }
 
   public abstract Map<String, Long> getReadDataSizeForDisk();
 
@@ -32,6 +68,10 @@ public abstract class AbstractDiskMetricsManager {
 
   public abstract Map<String, Integer> getWriteOperationCountForDisk();
 
+  public abstract Map<String, Long> getMergedWriteOperationForDisk();
+
+  public abstract Map<String, Long> getMergedReadOperationForDisk();
+
   public abstract Map<String, Long> getReadCostTimeForDisk();
 
   public abstract Map<String, Long> getWriteCostTimeForDisk();
@@ -44,21 +84,17 @@ public abstract class AbstractDiskMetricsManager {
 
   public abstract Map<String, Double> getAvgSectorCountOfEachWriteForDisk();
 
-  public abstract long getReadDataSizeForDataNode();
-
-  public abstract long getWriteDataSizeForDataNode();
-
-  public abstract long getReadOpsCountForDataNode();
+  public abstract long getActualReadDataSizeForProcess();
 
-  public abstract long getWriteOpsCountForDataNode();
+  public abstract long getActualWriteDataSizeForProcess();
 
-  public abstract long getReadCostTimeForDataNode();
+  public abstract long getReadOpsCountForProcess();
 
-  public abstract long getWriteCostTimeForDataNode();
+  public abstract long getWriteOpsCountForProcess();
 
-  public abstract long getAvgReadCostTimeOfEachOpsForDataNode();
+  public abstract long getAttemptReadSizeForProcess();
 
-  public abstract long getAvgWriteCostTimeOfEachOpsForDataNode();
+  public abstract long getAttemptWriteSizeForProcess();
 
   public abstract Set<String> getDiskIDs();
 
diff --git a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/LinuxDiskMetricsManager.java b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/LinuxDiskMetricsManager.java
index f724f801dc..8c919ec968 100644
--- a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/LinuxDiskMetricsManager.java
+++ b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/LinuxDiskMetricsManager.java
@@ -19,6 +19,11 @@
 
 package org.apache.iotdb.db.service.metrics.io;
 
+import org.apache.iotdb.metrics.config.MetricConfigDescriptor;
+
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
 import java.io.File;
 import java.io.IOException;
 import java.nio.file.Files;
@@ -33,8 +38,10 @@ import java.util.Set;
 import java.util.stream.Collectors;
 
 public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
+  private final Logger log = LoggerFactory.getLogger(AbstractDiskMetricsManager.class);
   private final String DISK_STATS_FILE_PATH = "/proc/diskstats";
   private final String DISK_ID_PATH = "/sys/block";
+  private final String PROCESS_IO_STAT_PATH;
   private final int DISK_ID_OFFSET = 3;
   private final int DISK_READ_COUNT_OFFSET = 4;
   private final int DISK_MERGED_READ_COUNT_OFFSET = 5;
@@ -49,12 +56,14 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
   private Set<String> diskIDSet;
   private long lastUpdateTime = 0L;
   private long updateInterval = 1L;
-  private String[] dataNodeProcessId;
-  private String[] configNodeProcessId;
+
+  // Disk IO status structure
   private final Map<String, Integer> lastReadOperationCountForDisk = new HashMap<>();
   private final Map<String, Integer> lastWriteOperationCountForDisk = new HashMap<>();
   private final Map<String, Long> lastReadTimeCostForDisk = new HashMap<>();
   private final Map<String, Long> lastWriteTimeCostForDisk = new HashMap<>();
+  private final Map<String, Long> lastMergedReadCountForDisk = new HashMap<>();
+  private final Map<String, Long> lastMergedWriteCountForDisk = new HashMap<>();
   private final Map<String, Long> lastReadSectorCountForDisk = new HashMap<>();
   private final Map<String, Long> lastWriteSectorCountForDisk = new HashMap<>();
   private final Map<String, Integer> incrementReadOperationCountForDisk = new HashMap<>();
@@ -63,8 +72,29 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
   private final Map<String, Long> incrementWriteTimeCostForDisk = new HashMap<>();
   private final Map<String, Long> incrementReadSectorCountForDisk = new HashMap<>();
   private final Map<String, Long> incrementWriteSectorCountForDisk = new HashMap<>();
-
-  public LinuxDiskMetricsManager() {}
+  private final Map<String, Long> incrementMergedReadCountForDisk = new HashMap<>();
+  private final Map<String, Long> incrementMergedWriteCountForDisk = new HashMap<>();
+
+  // Process IO status structure
+  private long lastReallyReadSizeForProcess = 0L;
+  private long lastReallyWriteSizeForProcess = 0L;
+  private long lastAttemptReadSizeForProcess = 0L;
+  private long lastAttemptWriteSizeForProcess = 0L;
+  private long lastReadOpsCountForProcess = 0L;
+  private long lastWriteOpsCountForProcess = 0L;
+  private long incrementReallyReadSizeForProcess = 0L;
+  private long incrementReallyWriteSizeForProcess = 0L;
+  private long incrementAttemptReadSizeForProcess = 0L;
+  private long incrementAttemptWriteSizeForProcess = 0L;
+  private long incrementReadOpsCountForProcess = 0L;
+  private long incrementWriteOpsCountForProcess = 0L;
+
+  public LinuxDiskMetricsManager() {
+    super();
+    PROCESS_IO_STAT_PATH =
+        String.format(
+            "/proc/%s/io", MetricConfigDescriptor.getInstance().getMetricConfig().getPid());
+  }
 
   @Override
   public Map<String, Long> getReadDataSizeForDisk() {
@@ -175,42 +205,50 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
   }
 
   @Override
-  public long getReadDataSizeForDataNode() {
-    return 0;
+  public Map<String, Long> getMergedWriteOperationForDisk() {
+    Map<String, Long> incrementMapPerMinute = new HashMap<>();
+    for (Map.Entry<String, Long> entry : incrementMergedWriteCountForDisk.entrySet()) {
+      incrementMapPerMinute.put(entry.getKey(), entry.getValue() / updateInterval * 1000L);
+    }
+    return incrementMapPerMinute;
   }
 
   @Override
-  public long getWriteDataSizeForDataNode() {
-    return 0;
+  public Map<String, Long> getMergedReadOperationForDisk() {
+    Map<String, Long> incrementMapPerMinute = new HashMap<>();
+    for (Map.Entry<String, Long> entry : incrementMergedReadCountForDisk.entrySet()) {
+      incrementMapPerMinute.put(entry.getKey(), entry.getValue() / updateInterval * 1000L);
+    }
+    return incrementMapPerMinute;
   }
 
   @Override
-  public long getReadOpsCountForDataNode() {
-    return 0;
+  public long getActualReadDataSizeForProcess() {
+    return incrementReallyReadSizeForProcess / updateInterval * 1000L / 1024L;
   }
 
   @Override
-  public long getWriteOpsCountForDataNode() {
-    return 0;
+  public long getActualWriteDataSizeForProcess() {
+    return incrementReallyWriteSizeForProcess / updateInterval * 1000L / 1024L;
   }
 
   @Override
-  public long getReadCostTimeForDataNode() {
-    return 0;
+  public long getReadOpsCountForProcess() {
+    return incrementReadOpsCountForProcess / updateInterval * 1000L;
   }
 
   @Override
-  public long getWriteCostTimeForDataNode() {
-    return 0;
+  public long getWriteOpsCountForProcess() {
+    return incrementWriteOpsCountForProcess / updateInterval * 1000L;
   }
 
   @Override
-  public long getAvgReadCostTimeOfEachOpsForDataNode() {
+  public long getAttemptReadSizeForProcess() {
     return 0;
   }
 
   @Override
-  public long getAvgWriteCostTimeOfEachOpsForDataNode() {
+  public long getAttemptWriteSizeForProcess() {
     return 0;
   }
 
@@ -229,14 +267,21 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
     return diskIDSet;
   }
 
-  private void updateDiskInfo() {
+  private void updateInfo() {
     long currentTime = System.currentTimeMillis();
     updateInterval = currentTime - lastUpdateTime;
     lastUpdateTime = currentTime;
+    updateDiskInfo();
+    updateProcessInfo();
+  }
+
+  private void updateDiskInfo() {
     File diskStatsFile = new File(DISK_STATS_FILE_PATH);
     if (!diskStatsFile.exists()) {
+      log.warn("Cannot find disk io status file {}", DISK_STATS_FILE_PATH);
       return;
     }
+
     try (Scanner diskStatsScanner = new Scanner(Files.newInputStream(diskStatsFile.toPath()))) {
       while (diskStatsScanner.hasNextLine()) {
         String[] diskInfo = diskStatsScanner.nextLine().split("\\s+");
@@ -246,16 +291,16 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
         }
         int readOperationCount = Integer.parseInt(diskInfo[DISK_READ_COUNT_OFFSET]);
         int writeOperationCount = Integer.parseInt(diskInfo[DISK_WRITE_COUNT_OFFSET]);
-        int mergedReadOperationCount = Integer.parseInt(diskInfo[DISK_MERGED_READ_COUNT_OFFSET]);
-        int mergedWriteOperationCount = Integer.parseInt(diskInfo[DISK_MERGED_WRITE_COUNT_OFFSET]);
+        long mergedReadOperationCount = Long.parseLong(diskInfo[DISK_MERGED_READ_COUNT_OFFSET]);
+        long mergedWriteOperationCount = Long.parseLong(diskInfo[DISK_MERGED_WRITE_COUNT_OFFSET]);
         long sectorReadCount = Long.parseLong(diskInfo[DISK_SECTOR_READ_COUNT_OFFSET]);
         long sectorWriteCount = Long.parseLong(diskInfo[DISK_SECTOR_WRITE_COUNT_OFFSET]);
         long readTimeCost = Long.parseLong(diskInfo[DISK_READ_TIME_COST_OFFSET]);
         long writeTimeCost = Long.parseLong(diskInfo[DISK_WRITE_TIME_COST_OFFSET]);
-
+        long lastMergedReadCount = lastMergedReadCountForDisk.getOrDefault(diskId, 0L);
+        long lastMergedWriteCount = lastMergedReadCountForDisk.getOrDefault(diskId, 0L);
         int lastReadOperationCount = lastReadOperationCountForDisk.getOrDefault(diskId, 0);
         int lastWriteOperationCount = lastWriteOperationCountForDisk.getOrDefault(diskId, 0);
-        //        int lastMergedReadOperationCount = lastM
         long lastSectorReadCount = lastReadSectorCountForDisk.getOrDefault(diskId, 0L);
         long lastSectorWriteCount = lastWriteSectorCountForDisk.getOrDefault(diskId, 0L);
         long lastReadTime = lastReadTimeCostForDisk.getOrDefault(diskId, 0L);
@@ -299,21 +344,92 @@ public class LinuxDiskMetricsManager extends AbstractDiskMetricsManager {
           incrementWriteTimeCostForDisk.put(diskId, 0L);
         }
 
+        if (lastMergedReadCount != 0) {
+          incrementMergedReadCountForDisk.put(
+              diskId, mergedReadOperationCount - lastMergedReadCount);
+        } else {
+          incrementMergedReadCountForDisk.put(diskId, 0L);
+        }
+
+        if (lastMergedWriteCount != 0) {
+          incrementMergedWriteCountForDisk.put(
+              diskId, mergedWriteOperationCount - lastMergedWriteCount);
+        } else {
+          incrementMergedWriteCountForDisk.put(diskId, 0L);
+        }
+
         lastReadOperationCountForDisk.put(diskId, readOperationCount);
         lastWriteOperationCountForDisk.put(diskId, writeOperationCount);
         lastReadSectorCountForDisk.put(diskId, sectorReadCount);
         lastWriteSectorCountForDisk.put(diskId, sectorWriteCount);
         lastReadTimeCostForDisk.put(diskId, readTimeCost);
         lastWriteTimeCostForDisk.put(diskId, writeTimeCost);
+        lastMergedReadCountForDisk.put(diskId, mergedReadOperationCount);
+        lastMergedWriteCountForDisk.put(diskId, mergedWriteOperationCount);
+      }
+    } catch (IOException e) {
+      log.error("Meets error while updating disk io info", e);
+    }
+  }
+
+  private void updateProcessInfo() {
+    File processStatInfoFile = new File(PROCESS_IO_STAT_PATH);
+    if (!processStatInfoFile.exists()) {
+      log.warn("Cannot find process io status file {}", PROCESS_IO_STAT_PATH);
+    }
+
+    try (Scanner processStatsScanner =
+        new Scanner(Files.newInputStream(processStatInfoFile.toPath()))) {
+      while (processStatsScanner.hasNextLine()) {
+        String infoLine = processStatsScanner.nextLine();
+        if (infoLine.startsWith("syscr")) {
+          long currentReadOpsCount = Long.parseLong(infoLine.split(":\\s")[1]);
+          if (lastReadOpsCountForProcess != 0) {
+            incrementReadOpsCountForProcess = currentReadOpsCount - lastReadOpsCountForProcess;
+          }
+          lastReadOpsCountForProcess = currentReadOpsCount;
+        } else if (infoLine.startsWith("syscw")) {
+          long currentWriteOpsCount = Long.parseLong(infoLine.split(":\\s")[1]);
+          if (lastWriteOpsCountForProcess != 0) {
+            incrementWriteOpsCountForProcess = currentWriteOpsCount - lastWriteOpsCountForProcess;
+          }
+          lastWriteOpsCountForProcess = currentWriteOpsCount;
+        } else if (infoLine.startsWith("read_bytes")) {
+          long currentReadSize = Long.parseLong(infoLine.split(":\\s")[1]);
+          if (lastReallyReadSizeForProcess != 0) {
+            incrementReallyReadSizeForProcess = currentReadSize - lastReallyReadSizeForProcess;
+          }
+          lastReallyReadSizeForProcess = currentReadSize;
+        } else if (infoLine.startsWith("write_bytes")) {
+          long currentWriteSize = Long.parseLong(infoLine.split(":\\s")[1]);
+          if (lastReallyWriteSizeForProcess != 0) {
+            incrementReallyWriteSizeForProcess = currentWriteSize - lastReallyWriteSizeForProcess;
+          }
+          lastReallyWriteSizeForProcess = currentWriteSize;
+        } else if (infoLine.startsWith("rchar")) {
+          long currentAttemptReadSize = Long.parseLong(infoLine.split(":\\s")[1]);
+          if (lastAttemptReadSizeForProcess != 0) {
+            incrementAttemptReadSizeForProcess =
+                currentAttemptReadSize - lastAttemptReadSizeForProcess;
+          }
+          lastAttemptReadSizeForProcess = currentAttemptReadSize;
+        } else if (infoLine.startsWith("wchar")) {
+          long currentAttemptWriteSize = Long.parseLong(infoLine.split(":\\s")[1]);
+          if (lastAttemptWriteSizeForProcess != 0) {
+            incrementAttemptWriteSizeForProcess =
+                currentAttemptWriteSize - lastAttemptWriteSizeForProcess;
+          }
+          lastAttemptWriteSizeForProcess = currentAttemptWriteSize;
+        }
       }
     } catch (IOException e) {
-      throw new RuntimeException(e);
+      log.error("Meets error while updating process io info", e);
     }
   }
 
   private void checkUpdate() {
     if (System.currentTimeMillis() - lastUpdateTime > UPDATE_SMALLEST_INTERVAL) {
-      updateDiskInfo();
+      updateInfo();
     }
   }
 }
diff --git a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/MacDiskMetricsManager.java b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/MacDiskMetricsManager.java
index a1ebb3444a..18c4ea95fc 100644
--- a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/MacDiskMetricsManager.java
+++ b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/MacDiskMetricsManager.java
@@ -26,6 +26,10 @@ import java.util.Set;
 /** Disk Metrics Manager for macOS, not implemented yet. */
 public class MacDiskMetricsManager extends AbstractDiskMetricsManager {
 
+  public MacDiskMetricsManager() {
+    super();
+  }
+
   @Override
   public Map<String, Long> getReadDataSizeForDisk() {
     return Collections.emptyMap();
@@ -77,42 +81,42 @@ public class MacDiskMetricsManager extends AbstractDiskMetricsManager {
   }
 
   @Override
-  public long getReadDataSizeForDataNode() {
-    return 0;
+  public Map<String, Long> getMergedWriteOperationForDisk() {
+    return Collections.emptyMap();
   }
 
   @Override
-  public long getWriteDataSizeForDataNode() {
-    return 0;
+  public Map<String, Long> getMergedReadOperationForDisk() {
+    return Collections.emptyMap();
   }
 
   @Override
-  public long getReadOpsCountForDataNode() {
+  public long getActualReadDataSizeForProcess() {
     return 0;
   }
 
   @Override
-  public long getWriteOpsCountForDataNode() {
+  public long getActualWriteDataSizeForProcess() {
     return 0;
   }
 
   @Override
-  public long getReadCostTimeForDataNode() {
+  public long getReadOpsCountForProcess() {
     return 0;
   }
 
   @Override
-  public long getWriteCostTimeForDataNode() {
+  public long getWriteOpsCountForProcess() {
     return 0;
   }
 
   @Override
-  public long getAvgReadCostTimeOfEachOpsForDataNode() {
+  public long getAttemptReadSizeForProcess() {
     return 0;
   }
 
   @Override
-  public long getAvgWriteCostTimeOfEachOpsForDataNode() {
+  public long getAttemptWriteSizeForProcess() {
     return 0;
   }
 
diff --git a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/WindowsDiskMetricsManager.java b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/WindowsDiskMetricsManager.java
index aeb4104094..48c9c2b603 100644
--- a/server/src/main/java/org/apache/iotdb/db/service/metrics/io/WindowsDiskMetricsManager.java
+++ b/server/src/main/java/org/apache/iotdb/db/service/metrics/io/WindowsDiskMetricsManager.java
@@ -26,6 +26,10 @@ import java.util.Set;
 /** Disk Metrics Manager for Windows system, not implemented yet. */
 public class WindowsDiskMetricsManager extends AbstractDiskMetricsManager {
 
+  public WindowsDiskMetricsManager() {
+    super();
+  }
+
   @Override
   public Map<String, Long> getReadDataSizeForDisk() {
     return Collections.emptyMap();
@@ -47,72 +51,72 @@ public class WindowsDiskMetricsManager extends AbstractDiskMetricsManager {
   }
 
   @Override
-  public Map<String, Long> getReadCostTimeForDisk() {
+  public Map<String, Long> getMergedWriteOperationForDisk() {
     return Collections.emptyMap();
   }
 
   @Override
-  public Map<String, Long> getWriteCostTimeForDisk() {
+  public Map<String, Long> getMergedReadOperationForDisk() {
     return Collections.emptyMap();
   }
 
   @Override
-  public Map<String, Double> getAvgReadCostTimeOfEachOpsForDisk() {
+  public Map<String, Long> getReadCostTimeForDisk() {
     return Collections.emptyMap();
   }
 
   @Override
-  public Map<String, Double> getAvgWriteCostTimeOfEachOpsForDisk() {
+  public Map<String, Long> getWriteCostTimeForDisk() {
     return Collections.emptyMap();
   }
 
   @Override
-  public Map<String, Double> getAvgSectorCountOfEachReadForDisk() {
+  public Map<String, Double> getAvgReadCostTimeOfEachOpsForDisk() {
     return Collections.emptyMap();
   }
 
   @Override
-  public Map<String, Double> getAvgSectorCountOfEachWriteForDisk() {
+  public Map<String, Double> getAvgWriteCostTimeOfEachOpsForDisk() {
     return Collections.emptyMap();
   }
 
   @Override
-  public long getReadDataSizeForDataNode() {
-    return 0;
+  public Map<String, Double> getAvgSectorCountOfEachReadForDisk() {
+    return Collections.emptyMap();
   }
 
   @Override
-  public long getWriteDataSizeForDataNode() {
-    return 0;
+  public Map<String, Double> getAvgSectorCountOfEachWriteForDisk() {
+    return Collections.emptyMap();
   }
 
   @Override
-  public long getReadOpsCountForDataNode() {
+  public long getActualReadDataSizeForProcess() {
     return 0;
   }
 
   @Override
-  public long getWriteOpsCountForDataNode() {
+  public long getActualWriteDataSizeForProcess() {
     return 0;
   }
 
   @Override
-  public long getReadCostTimeForDataNode() {
+  public long getReadOpsCountForProcess() {
     return 0;
   }
 
   @Override
-  public long getWriteCostTimeForDataNode() {
+  public long getWriteOpsCountForProcess() {
     return 0;
   }
 
   @Override
-  public long getAvgReadCostTimeOfEachOpsForDataNode() {
+  public long getAttemptReadSizeForProcess() {
     return 0;
   }
 
   @Override
-  public long getAvgWriteCostTimeOfEachOpsForDataNode() {
+  public long getAttemptWriteSizeForProcess() {
     return 0;
   }
 


[iotdb] 04/04: update dashboard

Posted by ma...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

marklau99 pushed a commit to branch IOTDB-5517
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit 6849a76a6857c6c2ba078a870913e74be902f5e1
Author: liuxuxin <li...@outlook.com>
AuthorDate: Mon Feb 13 17:06:24 2023 +0800

    update dashboard
---
 .../Apache-IoTDB-DataNode-Dashboard.json           | 7807 +++++++++++---------
 1 file changed, 4195 insertions(+), 3612 deletions(-)

diff --git a/docs/UserGuide/Monitor-Alert/Apache-IoTDB-DataNode-Dashboard.json b/docs/UserGuide/Monitor-Alert/Apache-IoTDB-DataNode-Dashboard.json
index 33227c3010..8a3a482940 100644
--- a/docs/UserGuide/Monitor-Alert/Apache-IoTDB-DataNode-Dashboard.json
+++ b/docs/UserGuide/Monitor-Alert/Apache-IoTDB-DataNode-Dashboard.json
@@ -15,7 +15,7 @@
       "type": "grafana",
       "id": "grafana",
       "name": "Grafana",
-      "version": "8.4.2"
+      "version": "8.3.3"
     },
     {
       "type": "datasource",
@@ -63,7 +63,7 @@
   "fiscalYearStartMonth": 0,
   "graphTooltip": 1,
   "id": null,
-  "iteration": 1675940765296,
+  "iteration": 1676279020733,
   "links": [],
   "liveNow": false,
   "panels": [
@@ -135,7 +135,7 @@
             "h": 8,
             "w": 8,
             "x": 0,
-            "y": 1
+            "y": 9
           },
           "id": 2,
           "options": {
@@ -222,7 +222,7 @@
             "h": 8,
             "w": 8,
             "x": 8,
-            "y": 1
+            "y": 9
           },
           "id": 3,
           "options": {
@@ -310,7 +310,7 @@
             "h": 8,
             "w": 8,
             "x": 16,
-            "y": 1
+            "y": 9
           },
           "id": 4,
           "options": {
@@ -425,7 +425,7 @@
             "h": 8,
             "w": 8,
             "x": 0,
-            "y": 2
+            "y": 10
           },
           "id": 6,
           "options": {
@@ -512,7 +512,7 @@
             "h": 8,
             "w": 8,
             "x": 8,
-            "y": 2
+            "y": 10
           },
           "id": 55,
           "options": {
@@ -599,7 +599,7 @@
             "h": 8,
             "w": 8,
             "x": 16,
-            "y": 2
+            "y": 10
           },
           "id": 56,
           "options": {
@@ -686,7 +686,7 @@
             "h": 8,
             "w": 8,
             "x": 0,
-            "y": 10
+            "y": 18
           },
           "id": 9,
           "options": {
@@ -774,7 +774,7 @@
             "h": 8,
             "w": 8,
             "x": 8,
-            "y": 10
+            "y": 18
           },
           "id": 10,
           "options": {
@@ -864,7 +864,7 @@
             "h": 8,
             "w": 8,
             "x": 16,
-            "y": 10
+            "y": 18
           },
           "id": 11,
           "options": {
@@ -964,7 +964,7 @@
             "h": 8,
             "w": 8,
             "x": 0,
-            "y": 18
+            "y": 26
           },
           "id": 12,
           "options": {
@@ -1052,7 +1052,7 @@
             "h": 8,
             "w": 8,
             "x": 8,
-            "y": 18
+            "y": 26
           },
           "id": 13,
           "options": {
@@ -1099,7 +1099,7 @@
       "type": "row"
     },
     {
-      "collapsed": false,
+      "collapsed": true,
       "datasource": {
         "type": "prometheus",
         "uid": "${DS_PROMETHEUS}"
@@ -1111,707 +1111,1381 @@
         "y": 2
       },
       "id": 14,
-      "panels": [],
-      "targets": [
+      "panels": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "refId": "A"
-        }
-      ],
-      "title": "Engine",
-      "type": "row"
-    },
-    {
-      "datasource": {
-        "type": "prometheus",
-        "uid": "${DS_PROMETHEUS}"
-      },
-      "fieldConfig": {
-        "defaults": {
-          "color": {
-            "mode": "palette-classic"
-          },
-          "custom": {
-            "axisLabel": "",
-            "axisPlacement": "auto",
-            "barAlignment": 0,
-            "drawStyle": "line",
-            "fillOpacity": 0,
-            "gradientMode": "none",
-            "hideFrom": {
-              "legend": false,
-              "tooltip": false,
-              "viz": false
-            },
-            "lineInterpolation": "linear",
-            "lineWidth": 1,
-            "pointSize": 5,
-            "scaleDistribution": {
-              "type": "linear"
-            },
-            "showPoints": "auto",
-            "spanNulls": false,
-            "stacking": {
-              "group": "A",
-              "mode": "none"
-            },
-            "thresholdsStyle": {
-              "mode": "off"
-            }
-          },
-          "mappings": [],
-          "thresholds": {
-            "mode": "absolute",
-            "steps": [
-              {
-                "color": "green",
-                "value": null
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
               }
-            ]
-          }
-        },
-        "overrides": []
-      },
-      "gridPos": {
-        "h": 8,
-        "w": 12,
-        "x": 0,
-        "y": 3
-      },
-      "id": 15,
-      "options": {
-        "legend": {
-          "calcs": [],
-          "displayMode": "list",
-          "placement": "bottom",
-          "showLegend": true
-        },
-        "tooltip": {
-          "mode": "multi",
-          "sort": "desc"
-        }
-      },
-      "targets": [
-        {
-          "datasource": {
-            "type": "prometheus",
-            "uid": "${DS_PROMETHEUS}"
+            },
+            "overrides": []
           },
-          "editorMode": "code",
-          "exemplar": true,
-          "expr": "queue{instance=~\"$instance\"}",
-          "interval": "",
-          "legendFormat": "{{name}}-{{status}}",
-          "range": true,
-          "refId": "A"
-        }
-      ],
-      "title": "Task Number",
-      "type": "timeseries"
-    },
-    {
-      "datasource": {
-        "type": "prometheus",
-        "uid": "${DS_PROMETHEUS}"
-      },
-      "fieldConfig": {
-        "defaults": {
-          "color": {
-            "mode": "palette-classic"
+          "gridPos": {
+            "h": 8,
+            "w": 12,
+            "x": 0,
+            "y": 11
           },
-          "custom": {
-            "axisLabel": "",
-            "axisPlacement": "auto",
-            "barAlignment": 0,
-            "drawStyle": "line",
-            "fillOpacity": 0,
-            "gradientMode": "none",
-            "hideFrom": {
-              "legend": false,
-              "tooltip": false,
-              "viz": false
-            },
-            "lineInterpolation": "linear",
-            "lineWidth": 1,
-            "pointSize": 5,
-            "scaleDistribution": {
-              "type": "linear"
-            },
-            "showPoints": "auto",
-            "spanNulls": false,
-            "stacking": {
-              "group": "A",
-              "mode": "none"
+          "id": 15,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom",
+              "showLegend": true
             },
-            "thresholdsStyle": {
-              "mode": "off"
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
             }
           },
-          "mappings": [],
-          "thresholds": {
-            "mode": "absolute",
-            "steps": [
-              {
-                "color": "green",
-                "value": null
-              }
-            ]
-          },
-          "unit": "s"
-        },
-        "overrides": []
-      },
-      "gridPos": {
-        "h": 8,
-        "w": 12,
-        "x": 12,
-        "y": 3
-      },
-      "id": 16,
-      "options": {
-        "legend": {
-          "calcs": [],
-          "displayMode": "list",
-          "placement": "bottom",
-          "showLegend": true
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "exemplar": true,
+              "expr": "queue{instance=~\"$instance\"}",
+              "interval": "",
+              "legendFormat": "{{name}}-{{status}}",
+              "range": true,
+              "refId": "A"
+            }
+          ],
+          "title": "Task Number",
+          "type": "timeseries"
         },
-        "tooltip": {
-          "mode": "multi",
-          "sort": "desc"
-        }
-      },
-      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "editorMode": "code",
-          "exemplar": true,
-          "expr": "rate(cost_task_seconds_sum{instance=~\"$instance\"}[1m])/rate(cost_task_seconds_count{instance=~\"$instance\"}[1m])",
-          "interval": "",
-          "legendFormat": "{{name}}",
-          "range": true,
-          "refId": "A"
-        }
-      ],
-      "title": "The Time Consumed of Task",
-      "type": "timeseries"
-    },
-    {
-      "datasource": {
-        "type": "prometheus",
-        "uid": "${DS_PROMETHEUS}"
-      },
-      "fieldConfig": {
-        "defaults": {
-          "color": {
-            "mode": "palette-classic"
-          },
-          "custom": {
-            "axisLabel": "",
-            "axisPlacement": "auto",
-            "barAlignment": 0,
-            "drawStyle": "line",
-            "fillOpacity": 0,
-            "gradientMode": "none",
-            "hideFrom": {
-              "legend": false,
-              "tooltip": false,
-              "viz": false
-            },
-            "lineInterpolation": "linear",
-            "lineWidth": 1,
-            "pointSize": 5,
-            "scaleDistribution": {
-              "type": "linear"
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "s"
             },
-            "showPoints": "auto",
-            "spanNulls": false,
-            "stacking": {
-              "group": "A",
-              "mode": "none"
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 12,
+            "x": 12,
+            "y": 11
+          },
+          "id": 16,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom",
+              "showLegend": true
             },
-            "thresholdsStyle": {
-              "mode": "off"
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
             }
           },
-          "mappings": [],
-          "thresholds": {
-            "mode": "absolute",
-            "steps": [
-              {
-                "color": "green",
-                "value": null
-              }
-            ]
-          },
-          "unit": "bytes"
-        },
-        "overrides": []
-      },
-      "gridPos": {
-        "h": 8,
-        "w": 8,
-        "x": 0,
-        "y": 11
-      },
-      "id": 17,
-      "options": {
-        "legend": {
-          "calcs": [],
-          "displayMode": "list",
-          "placement": "bottom",
-          "showLegend": true
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "exemplar": true,
+              "expr": "rate(cost_task_seconds_sum{instance=~\"$instance\"}[1m])/rate(cost_task_seconds_count{instance=~\"$instance\"}[1m])",
+              "interval": "",
+              "legendFormat": "{{name}}",
+              "range": true,
+              "refId": "A"
+            }
+          ],
+          "title": "The Time Consumed of Task",
+          "type": "timeseries"
         },
-        "tooltip": {
-          "mode": "multi",
-          "sort": "desc"
-        }
-      },
-      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "editorMode": "code",
-          "exemplar": true,
-          "expr": "sum(rate(data_written_total{instance=~\"$instance\"}[1m]))*60",
-          "interval": "",
-          "legendFormat": "Write",
-          "range": true,
-          "refId": "A"
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "bytes"
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 8,
+            "x": 0,
+            "y": 19
+          },
+          "id": 17,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom",
+              "showLegend": true
+            },
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
+            }
+          },
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "exemplar": true,
+              "expr": "sum(rate(data_written_total{instance=~\"$instance\"}[1m]))*60",
+              "interval": "",
+              "legendFormat": "Write",
+              "range": true,
+              "refId": "A"
+            },
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "expr": "sum(rate(data_read_total{instance=~\"$instance\"}[1m]))*60",
+              "hide": false,
+              "legendFormat": "Read",
+              "range": true,
+              "refId": "B"
+            }
+          ],
+          "title": "Compaction Read And Write Per Minute",
+          "type": "timeseries"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "editorMode": "code",
-          "expr": "sum(rate(data_read_total{instance=~\"$instance\"}[1m]))*60",
-          "hide": false,
-          "legendFormat": "Read",
-          "range": true,
-          "refId": "B"
-        }
-      ],
-      "title": "Compaction Read And Write Per Minute",
-      "type": "timeseries"
-    },
-    {
-      "datasource": {
-        "type": "prometheus",
-        "uid": "${DS_PROMETHEUS}"
-      },
-      "fieldConfig": {
-        "defaults": {
-          "color": {
-            "mode": "palette-classic"
-          },
-          "custom": {
-            "axisLabel": "",
-            "axisPlacement": "auto",
-            "barAlignment": 0,
-            "drawStyle": "line",
-            "fillOpacity": 0,
-            "gradientMode": "none",
-            "hideFrom": {
-              "legend": false,
-              "tooltip": false,
-              "viz": false
-            },
-            "lineInterpolation": "linear",
-            "lineWidth": 1,
-            "pointSize": 5,
-            "scaleDistribution": {
-              "type": "linear"
-            },
-            "showPoints": "auto",
-            "spanNulls": false,
-            "stacking": {
-              "group": "A",
-              "mode": "none"
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "none"
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 8,
+            "x": 8,
+            "y": 19
+          },
+          "id": 18,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom",
+              "showLegend": true
+            },
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
+            }
+          },
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "exemplar": true,
+              "expr": "sum(rate(data_read_total{instance=~\"$instance\"}[1m]))*60 / sum(rate(data_written_total{instance=~\"$instance\"}[1m]))*60",
+              "interval": "",
+              "legendFormat": "Ratio",
+              "range": true,
+              "refId": "A"
+            }
+          ],
+          "title": "Compaction R/W Ratio Per Minute",
+          "type": "timeseries"
+        },
+        {
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "none"
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 8,
+            "x": 16,
+            "y": 19
+          },
+          "id": 19,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom",
+              "showLegend": true
+            },
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
+            }
+          },
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "exemplar": true,
+              "expr": "sum(rate(compaction_task_count{instance=\"$instance\", name = \"inner_seq\"}[1m]))*60",
+              "interval": "",
+              "legendFormat": "sequence",
+              "range": true,
+              "refId": "A"
+            },
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "exemplar": true,
+              "expr": "sum(rate(compaction_task_count{instance=\"$instance\", name = \"inner_unseq\"}[1m]))*60",
+              "hide": false,
+              "interval": "",
+              "legendFormat": "unsequence",
+              "range": true,
+              "refId": "B"
+            },
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "exemplar": true,
+              "expr": "sum(rate(compaction_task_count{instance=\"$instance\", name = \"cross\"}[1m]))*60",
+              "hide": false,
+              "interval": "",
+              "legendFormat": "cross",
+              "range": true,
+              "refId": "C"
+            }
+          ],
+          "title": "Compaction Number Per Minute",
+          "type": "timeseries"
+        },
+        {
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              }
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 12,
+            "x": 0,
+            "y": 27
+          },
+          "id": 169,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
+            },
+            "tooltip": {
+              "mode": "single",
+              "sort": "none"
+            }
+          },
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "sum(rate(Compacted_Chunk_Num_total{instance=~\"$instance\"}[1m]))*60",
+              "interval": "",
+              "legendFormat": "Compacted Chunk Num Per Min",
+              "refId": "A"
+            },
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "sum(rate(Deserialized_Chunk_Num_total{instance=~\"$instance\"}[1m]))*60",
+              "hide": false,
+              "interval": "",
+              "legendFormat": "Deserialized Chunk Num Per Min",
+              "refId": "B"
+            },
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "sum(rate(Directly_Flush_Chunk_Num_total{instance=~\"$instance\"}[1m]))*60",
+              "hide": false,
+              "interval": "",
+              "legendFormat": "Directly Flush Chunk Num Per Min",
+              "refId": "C"
+            },
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "sum(rate(Merged_Chunk_Num_total{instance=~\"$instance\"}[1m]))*60",
+              "hide": false,
+              "interval": "",
+              "legendFormat": "Merged Chunk Num Per Min",
+              "refId": "D"
+            }
+          ],
+          "title": "Compaction Process Chunk Status",
+          "type": "timeseries"
+        },
+        {
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              }
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 12,
+            "x": 12,
+            "y": 27
+          },
+          "id": 171,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
+            },
+            "tooltip": {
+              "mode": "single",
+              "sort": "none"
+            }
+          },
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "sum(rate(Compacted_Point_Num_total{instance=~\"$instance\"}[1m]))*60",
+              "interval": "",
+              "legendFormat": "Compacted Point Num Per Min",
+              "refId": "A"
+            }
+          ],
+          "title": "Compacted Point Num Per Minute",
+          "type": "timeseries"
+        }
+      ],
+      "targets": [
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "refId": "A"
+        }
+      ],
+      "title": "Engine",
+      "type": "row"
+    },
+    {
+      "collapsed": true,
+      "gridPos": {
+        "h": 1,
+        "w": 24,
+        "x": 0,
+        "y": 3
+      },
+      "id": 58,
+      "panels": [
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "s"
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 6,
+            "x": 0,
+            "y": 4
+          },
+          "id": 80,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
+            },
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
+            }
+          },
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "rate(query_plan_cost_seconds_sum{instance=~\"$instance\"}[1m]) / rate(query_plan_cost_seconds_count{instance=~\"$instance\"}[1m])",
+              "interval": "",
+              "legendFormat": "{{stage}}",
+              "refId": "A"
+            }
+          ],
+          "title": "The time consumed of query plan stages(avg)",
+          "type": "timeseries"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "s"
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 6,
+            "x": 6,
+            "y": 4
+          },
+          "id": 60,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
+            },
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
+            }
+          },
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "query_plan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
+              "interval": "",
+              "legendFormat": "{{stage}}",
+              "refId": "A"
+            }
+          ],
+          "title": "The time consumed of query plan stages(50%)",
+          "type": "timeseries"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "s"
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 6,
+            "x": 12,
+            "y": 4
+          },
+          "id": 61,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
             },
-            "thresholdsStyle": {
-              "mode": "off"
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
             }
           },
-          "mappings": [],
-          "thresholds": {
-            "mode": "absolute",
-            "steps": [
-              {
-                "color": "green",
-                "value": null
-              }
-            ]
-          },
-          "unit": "none"
-        },
-        "overrides": []
-      },
-      "gridPos": {
-        "h": 8,
-        "w": 8,
-        "x": 8,
-        "y": 11
-      },
-      "id": 18,
-      "options": {
-        "legend": {
-          "calcs": [],
-          "displayMode": "list",
-          "placement": "bottom",
-          "showLegend": true
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "query_plan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
+              "interval": "",
+              "legendFormat": "{{stage}}",
+              "refId": "A"
+            }
+          ],
+          "title": "The time consumed of query plan stages(75%)",
+          "type": "timeseries"
         },
-        "tooltip": {
-          "mode": "multi",
-          "sort": "desc"
-        }
-      },
-      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "editorMode": "code",
-          "exemplar": true,
-          "expr": "sum(rate(data_read_total{instance=~\"$instance\"}[1m]))*60 / sum(rate(data_written_total{instance=~\"$instance\"}[1m]))*60",
-          "interval": "",
-          "legendFormat": "Ratio",
-          "range": true,
-          "refId": "A"
-        }
-      ],
-      "title": "Compaction R/W Ratio Per Minute",
-      "type": "timeseries"
-    },
-    {
-      "fieldConfig": {
-        "defaults": {
-          "color": {
-            "mode": "palette-classic"
-          },
-          "custom": {
-            "axisLabel": "",
-            "axisPlacement": "auto",
-            "barAlignment": 0,
-            "drawStyle": "line",
-            "fillOpacity": 0,
-            "gradientMode": "none",
-            "hideFrom": {
-              "legend": false,
-              "tooltip": false,
-              "viz": false
-            },
-            "lineInterpolation": "linear",
-            "lineWidth": 1,
-            "pointSize": 5,
-            "scaleDistribution": {
-              "type": "linear"
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "s"
             },
-            "showPoints": "auto",
-            "spanNulls": false,
-            "stacking": {
-              "group": "A",
-              "mode": "none"
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 6,
+            "x": 18,
+            "y": 4
+          },
+          "id": 62,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
             },
-            "thresholdsStyle": {
-              "mode": "off"
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
             }
           },
-          "mappings": [],
-          "thresholds": {
-            "mode": "absolute",
-            "steps": [
-              {
-                "color": "green",
-                "value": null
-              }
-            ]
-          },
-          "unit": "none"
-        },
-        "overrides": []
-      },
-      "gridPos": {
-        "h": 8,
-        "w": 8,
-        "x": 16,
-        "y": 11
-      },
-      "id": 19,
-      "options": {
-        "legend": {
-          "calcs": [],
-          "displayMode": "list",
-          "placement": "bottom",
-          "showLegend": true
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "query_plan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
+              "interval": "",
+              "legendFormat": "{{stage}}",
+              "refId": "A"
+            }
+          ],
+          "title": "The time consumed of query plan stages(100%)",
+          "type": "timeseries"
         },
-        "tooltip": {
-          "mode": "multi",
-          "sort": "desc"
-        }
-      },
-      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "editorMode": "code",
-          "exemplar": true,
-          "expr": "sum(rate(compaction_task_count{instance=\"$instance\", name = \"inner_seq\"}[1m]))*60",
-          "interval": "",
-          "legendFormat": "sequence",
-          "range": true,
-          "refId": "A"
-        },
-        {
-          "datasource": {
-            "type": "prometheus",
-            "uid": "${DS_PROMETHEUS}"
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "s"
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 6,
+            "x": 0,
+            "y": 12
+          },
+          "id": 63,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
+            },
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
+            }
           },
-          "editorMode": "code",
-          "exemplar": true,
-          "expr": "sum(rate(compaction_task_count{instance=\"$instance\", name = \"inner_unseq\"}[1m]))*60",
-          "hide": false,
-          "interval": "",
-          "legendFormat": "unsequence",
-          "range": true,
-          "refId": "B"
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "rate(dispatcher_seconds_sum{instance=~\"$instance\"}[1m]) / rate(dispatcher_seconds_count{instance=~\"$instance\"}[1m])",
+              "interval": "",
+              "legendFormat": "{{stage}}",
+              "refId": "A"
+            }
+          ],
+          "title": "The time consumed of plan dispatch stages(avg)",
+          "type": "timeseries"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "editorMode": "code",
-          "exemplar": true,
-          "expr": "sum(rate(compaction_task_count{instance=\"$instance\", name = \"cross\"}[1m]))*60",
-          "hide": false,
-          "interval": "",
-          "legendFormat": "cross",
-          "range": true,
-          "refId": "C"
-        }
-      ],
-      "title": "Compaction Number Per Minute",
-      "type": "timeseries"
-    },
-    {
-      "fieldConfig": {
-        "defaults": {
-          "color": {
-            "mode": "palette-classic"
-          },
-          "custom": {
-            "axisLabel": "",
-            "axisPlacement": "auto",
-            "barAlignment": 0,
-            "drawStyle": "line",
-            "fillOpacity": 0,
-            "gradientMode": "none",
-            "hideFrom": {
-              "legend": false,
-              "tooltip": false,
-              "viz": false
-            },
-            "lineInterpolation": "linear",
-            "lineWidth": 1,
-            "pointSize": 5,
-            "scaleDistribution": {
-              "type": "linear"
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "s"
             },
-            "showPoints": "auto",
-            "spanNulls": false,
-            "stacking": {
-              "group": "A",
-              "mode": "none"
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 6,
+            "x": 6,
+            "y": 12
+          },
+          "id": 81,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
             },
-            "thresholdsStyle": {
-              "mode": "off"
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
             }
           },
-          "mappings": [],
-          "thresholds": {
-            "mode": "absolute",
-            "steps": [
-              {
-                "color": "green",
-                "value": null
-              }
-            ]
-          }
-        },
-        "overrides": []
-      },
-      "gridPos": {
-        "h": 8,
-        "w": 12,
-        "x": 0,
-        "y": 19
-      },
-      "id": 169,
-      "options": {
-        "legend": {
-          "calcs": [],
-          "displayMode": "list",
-          "placement": "bottom"
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "dispatcher_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
+              "interval": "",
+              "legendFormat": "{{stage}}",
+              "refId": "A"
+            }
+          ],
+          "title": "The time consumed of plan dispatch stages(50%)",
+          "type": "timeseries"
         },
-        "tooltip": {
-          "mode": "single",
-          "sort": "none"
-        }
-      },
-      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "exemplar": true,
-          "expr": "sum(rate(Compacted_Chunk_Num_total{instance=~\"$instance\"}[1m]))*60",
-          "interval": "",
-          "legendFormat": "Compacted Chunk Num Per Min",
-          "refId": "A"
-        },
-        {
-          "datasource": {
-            "type": "prometheus",
-            "uid": "${DS_PROMETHEUS}"
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "s"
+            },
+            "overrides": []
+          },
+          "gridPos": {
+            "h": 8,
+            "w": 6,
+            "x": 12,
+            "y": 12
+          },
+          "id": 64,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
+            },
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
+            }
           },
-          "exemplar": true,
-          "expr": "sum(rate(Deserialized_Chunk_Num_total{instance=~\"$instance\"}[1m]))*60",
-          "hide": false,
-          "interval": "",
-          "legendFormat": "Deserialized Chunk Num Per Min",
-          "refId": "B"
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "dispatcher_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
+              "interval": "",
+              "legendFormat": "{{stage}}",
+              "refId": "A"
+            }
+          ],
+          "title": "The time consumed of plan dispatch stages(75%)",
+          "type": "timeseries"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "exemplar": true,
-          "expr": "sum(rate(Directly_Flush_Chunk_Num_total{instance=~\"$instance\"}[1m]))*60",
-          "hide": false,
-          "interval": "",
-          "legendFormat": "Directly Flush Chunk Num Per Min",
-          "refId": "C"
-        },
-        {
-          "datasource": {
-            "type": "prometheus",
-            "uid": "${DS_PROMETHEUS}"
+          "fieldConfig": {
+            "defaults": {
+              "color": {
+                "mode": "palette-classic"
+              },
+              "custom": {
+                "axisLabel": "",
+                "axisPlacement": "auto",
+                "barAlignment": 0,
+                "drawStyle": "line",
+                "fillOpacity": 0,
+                "gradientMode": "none",
+                "hideFrom": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": false
+                },
+                "lineInterpolation": "linear",
+                "lineWidth": 1,
+                "pointSize": 5,
+                "scaleDistribution": {
+                  "type": "linear"
+                },
+                "showPoints": "auto",
+                "spanNulls": false,
+                "stacking": {
+                  "group": "A",
+                  "mode": "none"
+                },
+                "thresholdsStyle": {
+                  "mode": "off"
+                }
+              },
+              "mappings": [],
+              "thresholds": {
+                "mode": "absolute",
+                "steps": [
+                  {
+                    "color": "green"
+                  }
+                ]
+              },
+              "unit": "s"
+            },
+            "overrides": []
           },
-          "exemplar": true,
-          "expr": "sum(rate(Merged_Chunk_Num_total{instance=~\"$instance\"}[1m]))*60",
-          "hide": false,
-          "interval": "",
-          "legendFormat": "Merged Chunk Num Per Min",
-          "refId": "D"
-        }
-      ],
-      "title": "Compaction Process Chunk Status",
-      "type": "timeseries"
-    },
-    {
-      "fieldConfig": {
-        "defaults": {
-          "color": {
-            "mode": "palette-classic"
+          "gridPos": {
+            "h": 8,
+            "w": 6,
+            "x": 18,
+            "y": 12
           },
-          "custom": {
-            "axisLabel": "",
-            "axisPlacement": "auto",
-            "barAlignment": 0,
-            "drawStyle": "line",
-            "fillOpacity": 0,
-            "gradientMode": "none",
-            "hideFrom": {
-              "legend": false,
-              "tooltip": false,
-              "viz": false
-            },
-            "lineInterpolation": "linear",
-            "lineWidth": 1,
-            "pointSize": 5,
-            "scaleDistribution": {
-              "type": "linear"
-            },
-            "showPoints": "auto",
-            "spanNulls": false,
-            "stacking": {
-              "group": "A",
-              "mode": "none"
+          "id": 65,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom"
             },
-            "thresholdsStyle": {
-              "mode": "off"
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
             }
           },
-          "mappings": [],
-          "thresholds": {
-            "mode": "absolute",
-            "steps": [
-              {
-                "color": "green",
-                "value": null
-              }
-            ]
-          }
-        },
-        "overrides": []
-      },
-      "gridPos": {
-        "h": 8,
-        "w": 12,
-        "x": 12,
-        "y": 19
-      },
-      "id": 171,
-      "options": {
-        "legend": {
-          "calcs": [],
-          "displayMode": "list",
-          "placement": "bottom"
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "exemplar": true,
+              "expr": "dispatcher_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
+              "interval": "",
+              "legendFormat": "{{stage}}",
+              "refId": "A"
+            }
+          ],
+          "title": "The time consumed of plan dispatch stages(100%)",
+          "type": "timeseries"
         },
-        "tooltip": {
-          "mode": "single",
-          "sort": "none"
-        }
-      },
-      "targets": [
-        {
-          "datasource": {
-            "type": "prometheus",
-            "uid": "${DS_PROMETHEUS}"
-          },
-          "exemplar": true,
-          "expr": "sum(rate(Compacted_Point_Num_total{instance=~\"$instance\"}[1m]))*60",
-          "interval": "",
-          "legendFormat": "Compacted Point Num Per Min",
-          "refId": "A"
-        }
-      ],
-      "title": "Compacted Point Num Per Minute",
-      "type": "timeseries"
-    },
-    {
-      "collapsed": true,
-      "gridPos": {
-        "h": 1,
-        "w": 24,
-        "x": 0,
-        "y": 27
-      },
-      "id": 58,
-      "panels": [
         {
           "datasource": {
             "type": "prometheus",
@@ -1867,9 +2541,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 4
+            "y": 20
           },
-          "id": 80,
+          "id": 83,
           "options": {
             "legend": {
               "calcs": [],
@@ -1888,13 +2562,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(query_plan_cost_seconds_sum{instance=~\"$instance\"}[1m]) / rate(query_plan_cost_seconds_count{instance=~\"$instance\"}[1m])",
+              "expr": "rate(query_execution_seconds_sum{instance=~\"$instance\"}[1m]) / rate(query_execution_seconds_count{instance=~\"$instance\"}[1m])",
               "interval": "",
               "legendFormat": "{{stage}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query plan stages(avg)",
+          "title": "The time consumed of query execution stages(avg)",
           "type": "timeseries"
         },
         {
@@ -1952,9 +2626,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 4
+            "y": 20
           },
-          "id": 60,
+          "id": 66,
           "options": {
             "legend": {
               "calcs": [],
@@ -1973,13 +2647,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "query_plan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
+              "expr": "query_execution_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
               "interval": "",
               "legendFormat": "{{stage}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query plan stages(50%)",
+          "title": "The time consumed of query execution stages(50%)",
           "type": "timeseries"
         },
         {
@@ -2037,9 +2711,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 4
+            "y": 20
           },
-          "id": 61,
+          "id": 67,
           "options": {
             "legend": {
               "calcs": [],
@@ -2048,7 +2722,7 @@
             },
             "tooltip": {
               "mode": "multi",
-              "sort": "desc"
+              "sort": "asc"
             }
           },
           "targets": [
@@ -2058,13 +2732,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "query_plan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
+              "expr": "query_execution_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
               "interval": "",
               "legendFormat": "{{stage}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query plan stages(75%)",
+          "title": "The time consumed of query execution stages(75%)",
           "type": "timeseries"
         },
         {
@@ -2122,9 +2796,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 4
+            "y": 20
           },
-          "id": 62,
+          "id": 68,
           "options": {
             "legend": {
               "calcs": [],
@@ -2133,7 +2807,7 @@
             },
             "tooltip": {
               "mode": "multi",
-              "sort": "desc"
+              "sort": "asc"
             }
           },
           "targets": [
@@ -2143,13 +2817,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "query_plan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
+              "expr": "query_execution_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
               "interval": "",
               "legendFormat": "{{stage}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query plan stages(100%)",
+          "title": "The time consumed of query execution stages(100%)",
           "type": "timeseries"
         },
         {
@@ -2207,9 +2881,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 12
+            "y": 28
           },
-          "id": 63,
+          "id": 82,
           "options": {
             "legend": {
               "calcs": [],
@@ -2228,13 +2902,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(dispatcher_seconds_sum{instance=~\"$instance\"}[1m]) / rate(dispatcher_seconds_count{instance=~\"$instance\"}[1m])",
+              "expr": "rate(operator_execution_cost_seconds_sum{instance=~\"$instance\"}[1m]) / rate(operator_execution_cost_seconds_count{instance=~\"$instance\"}[1m])",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of plan dispatch stages(avg)",
+          "title": "The time consumed of operator execution stages(avg)",
           "type": "timeseries"
         },
         {
@@ -2292,9 +2966,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 12
+            "y": 28
           },
-          "id": 81,
+          "id": 69,
           "options": {
             "legend": {
               "calcs": [],
@@ -2303,7 +2977,7 @@
             },
             "tooltip": {
               "mode": "multi",
-              "sort": "desc"
+              "sort": "asc"
             }
           },
           "targets": [
@@ -2313,13 +2987,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "dispatcher_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
+              "expr": "operator_execution_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of plan dispatch stages(50%)",
+          "title": "The time consumed of operator execution(50%)",
           "type": "timeseries"
         },
         {
@@ -2377,9 +3051,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 12
+            "y": 28
           },
-          "id": 64,
+          "id": 70,
           "options": {
             "legend": {
               "calcs": [],
@@ -2398,13 +3072,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "dispatcher_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
+              "expr": "operator_execution_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of plan dispatch stages(75%)",
+          "title": "The time consumed of operator execution(75%)",
           "type": "timeseries"
         },
         {
@@ -2462,9 +3136,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 12
+            "y": 28
           },
-          "id": 65,
+          "id": 71,
           "options": {
             "legend": {
               "calcs": [],
@@ -2483,13 +3157,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "dispatcher_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
+              "expr": "operator_execution_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of plan dispatch stages(100%)",
+          "title": "The time consumed of operator execution(100%)",
           "type": "timeseries"
         },
         {
@@ -2547,9 +3221,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 20
+            "y": 36
           },
-          "id": 83,
+          "id": 72,
           "options": {
             "legend": {
               "calcs": [],
@@ -2568,13 +3242,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(query_execution_seconds_sum{instance=~\"$instance\"}[1m]) / rate(query_execution_seconds_count{instance=~\"$instance\"}[1m])",
+              "expr": "rate(aggregation_seconds_sum{instance=~\"$instance\"}[1m]) / rate(aggregation_seconds_count{instance=~\"$instance\"}[1m])",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query execution stages(avg)",
+          "title": "The time consumed of query aggregation(avg)",
           "type": "timeseries"
         },
         {
@@ -2632,9 +3306,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 20
+            "y": 36
           },
-          "id": 66,
+          "id": 84,
           "options": {
             "legend": {
               "calcs": [],
@@ -2653,13 +3327,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "query_execution_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
+              "expr": "aggregation_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query execution stages(50%)",
+          "title": "The time consumed of query aggregation(50%)",
           "type": "timeseries"
         },
         {
@@ -2717,9 +3391,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 20
+            "y": 36
           },
-          "id": 67,
+          "id": 73,
           "options": {
             "legend": {
               "calcs": [],
@@ -2728,7 +3402,7 @@
             },
             "tooltip": {
               "mode": "multi",
-              "sort": "asc"
+              "sort": "desc"
             }
           },
           "targets": [
@@ -2738,13 +3412,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "query_execution_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
+              "expr": "aggregation_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query execution stages(75%)",
+          "title": "The time consumed of query aggregation(75%)",
           "type": "timeseries"
         },
         {
@@ -2802,9 +3476,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 20
+            "y": 36
           },
-          "id": 68,
+          "id": 74,
           "options": {
             "legend": {
               "calcs": [],
@@ -2813,7 +3487,7 @@
             },
             "tooltip": {
               "mode": "multi",
-              "sort": "asc"
+              "sort": "desc"
             }
           },
           "targets": [
@@ -2823,13 +3497,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "query_execution_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
+              "expr": "aggregation_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query execution stages(100%)",
+          "title": "The time consumed of query aggregation(100%)",
           "type": "timeseries"
         },
         {
@@ -2887,9 +3561,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 28
+            "y": 44
           },
-          "id": 82,
+          "id": 131,
           "options": {
             "legend": {
               "calcs": [],
@@ -2908,13 +3582,14 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(operator_execution_cost_seconds_sum{instance=~\"$instance\"}[1m]) / rate(operator_execution_cost_seconds_count{instance=~\"$instance\"}[1m])",
+              "expr": "sum(rate(series_scan_cost_seconds_sum{instance=~\"$instance\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\"}[1m])) by (stage)",
+              "format": "time_series",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{stage}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of operator execution stages(avg)",
+          "title": "The time consumed of query scan(avg)",
           "type": "timeseries"
         },
         {
@@ -2972,9 +3647,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 28
+            "y": 44
           },
-          "id": 69,
+          "id": 132,
           "options": {
             "legend": {
               "calcs": [],
@@ -2983,7 +3658,7 @@
             },
             "tooltip": {
               "mode": "multi",
-              "sort": "asc"
+              "sort": "desc"
             }
           },
           "targets": [
@@ -2993,13 +3668,14 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "operator_execution_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
+              "expr": "sum(rate(series_scan_cost_seconds{instance=~\"$instance\", quantile=\"0.5\"}[1m])) by (stage)",
+              "format": "time_series",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{stage}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of operator execution(50%)",
+          "title": "The time consumed of query scan(50%)",
           "type": "timeseries"
         },
         {
@@ -3057,9 +3733,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 28
+            "y": 44
           },
-          "id": 70,
+          "id": 133,
           "options": {
             "legend": {
               "calcs": [],
@@ -3078,13 +3754,14 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "operator_execution_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
+              "expr": "sum(rate(series_scan_cost_seconds{instance=~\"$instance\", quantile=\"0.75\"}[1m])) by (stage)",
+              "format": "time_series",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{stage}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of operator execution(75%)",
+          "title": "The time consumed of query scan(75%)",
           "type": "timeseries"
         },
         {
@@ -3092,6 +3769,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -3142,9 +3820,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 28
+            "y": 44
           },
-          "id": 71,
+          "id": 134,
           "options": {
             "legend": {
               "calcs": [],
@@ -3163,13 +3841,14 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "operator_execution_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
+              "expr": "sum(rate(series_scan_cost_seconds{instance=~\"$instance\", quantile=\"1.0\"}[1m])) by (stage)",
+              "format": "time_series",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{stage}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of operator execution(100%)",
+          "title": "The time consumed of query scan(100%)",
           "type": "timeseries"
         },
         {
@@ -3219,7 +3898,7 @@
                   }
                 ]
               },
-              "unit": "s"
+              "unit": "none"
             },
             "overrides": []
           },
@@ -3227,9 +3906,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 36
+            "y": 52
           },
-          "id": 72,
+          "id": 76,
           "options": {
             "legend": {
               "calcs": [],
@@ -3248,13 +3927,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(aggregation_seconds_sum{instance=~\"$instance\"}[1m]) / rate(aggregation_seconds_count{instance=~\"$instance\"}[1m])",
+              "expr": "rate(query_resource_sum{instance=~\"$instance\"}[1m]) / rate(query_resource_count{instance=~\"$instance\"}[1m])",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query aggregation(avg)",
+          "title": "The usage of query resource(avg)",
           "type": "timeseries"
         },
         {
@@ -3304,7 +3983,7 @@
                   }
                 ]
               },
-              "unit": "s"
+              "unit": "none"
             },
             "overrides": []
           },
@@ -3312,9 +3991,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 36
+            "y": 52
           },
-          "id": 84,
+          "id": 128,
           "options": {
             "legend": {
               "calcs": [],
@@ -3333,13 +4012,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "aggregation_seconds{instance=~\"${instance}\", quantile=\"0.5\"}",
+              "expr": "query_resource{instance=~\"${instance}\", quantile=\"0.5\"}",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query aggregation(50%)",
+          "title": "The usage of query resource(50%)",
           "type": "timeseries"
         },
         {
@@ -3389,7 +4068,7 @@
                   }
                 ]
               },
-              "unit": "s"
+              "unit": "none"
             },
             "overrides": []
           },
@@ -3397,9 +4076,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 36
+            "y": 52
           },
-          "id": 73,
+          "id": 129,
           "options": {
             "legend": {
               "calcs": [],
@@ -3418,13 +4097,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "aggregation_seconds{instance=~\"${instance}\", quantile=\"0.75\"}",
+              "expr": "query_resource{instance=~\"${instance}\", quantile=\"0.75\"}",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query aggregation(75%)",
+          "title": "The usage of query resource(75%)",
           "type": "timeseries"
         },
         {
@@ -3474,7 +4153,7 @@
                   }
                 ]
               },
-              "unit": "s"
+              "unit": "none"
             },
             "overrides": []
           },
@@ -3482,9 +4161,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 36
+            "y": 52
           },
-          "id": 74,
+          "id": 130,
           "options": {
             "legend": {
               "calcs": [],
@@ -3503,13 +4182,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "aggregation_seconds{instance=~\"${instance}\", quantile=\"1.0\"}",
+              "expr": "query_resource{instance=~\"${instance}\", quantile=\"1.0\"}",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query aggregation(100%)",
+          "title": "The usage of query resource(100%)",
           "type": "timeseries"
         },
         {
@@ -3567,9 +4246,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 44
+            "y": 60
           },
-          "id": 131,
+          "id": 135,
           "options": {
             "legend": {
               "calcs": [],
@@ -3588,14 +4267,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "sum(rate(series_scan_cost_seconds_sum{instance=~\"$instance\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\"}[1m])) by (stage)",
-              "format": "time_series",
+              "expr": "sum(rate(data_exchange_cost_seconds_sum{instance=~\"$instance\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\"}[1m])) by (operation)",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{operation}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query scan(avg)",
+          "title": "The time consumed  of query data exchange(avg)",
           "type": "timeseries"
         },
         {
@@ -3653,9 +4331,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 44
+            "y": 60
           },
-          "id": 132,
+          "id": 136,
           "options": {
             "legend": {
               "calcs": [],
@@ -3674,14 +4352,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "sum(rate(series_scan_cost_seconds{instance=~\"$instance\", quantile=\"0.5\"}[1m])) by (stage)",
-              "format": "time_series",
+              "expr": "sum(rate(data_exchange_cost_seconds{instance=~\"$instance\", quantile=\"0.5\"}[1m])) by (operation)",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{operation}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query scan(50%)",
+          "title": "The time consumed  of query data exchange(50%)",
           "type": "timeseries"
         },
         {
@@ -3739,9 +4416,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 44
+            "y": 60
           },
-          "id": 133,
+          "id": 137,
           "options": {
             "legend": {
               "calcs": [],
@@ -3760,14 +4437,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "sum(rate(series_scan_cost_seconds{instance=~\"$instance\", quantile=\"0.75\"}[1m])) by (stage)",
-              "format": "time_series",
+              "expr": "sum(rate(data_exchange_cost_seconds{instance=~\"$instance\", quantile=\"0.75\"}[1m])) by (operation)",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{operation}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query scan(75%)",
+          "title": "The time consumed  of query data exchange(75%)",
           "type": "timeseries"
         },
         {
@@ -3775,7 +4451,6 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -3826,9 +4501,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 44
+            "y": 60
           },
-          "id": 134,
+          "id": 138,
           "options": {
             "legend": {
               "calcs": [],
@@ -3847,14 +4522,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "sum(rate(series_scan_cost_seconds{instance=~\"$instance\", quantile=\"1.0\"}[1m])) by (stage)",
-              "format": "time_series",
+              "expr": "sum(rate(data_exchange_cost_seconds{instance=~\"$instance\", quantile=\"1.0\"}[1m])) by (operation)",
               "interval": "",
-              "legendFormat": "{{stage}}",
+              "legendFormat": "{{operation}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query scan(100%)",
+          "title": "The time consumed  of query data exchange(100%)",
           "type": "timeseries"
         },
         {
@@ -3910,11 +4584,11 @@
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
+            "w": 8,
             "x": 0,
-            "y": 52
+            "y": 68
           },
-          "id": 76,
+          "id": 139,
           "options": {
             "legend": {
               "calcs": [],
@@ -3933,13 +4607,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(query_resource_sum{instance=~\"$instance\"}[1m]) / rate(query_resource_count{instance=~\"$instance\"}[1m])",
+              "expr": "rate(data_exchange_count_sum{instance=~\"$instance\"}[1m]) / rate(data_exchange_count_count{instance=~\"$instance\"}[1m])",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The usage of query resource(avg)",
+          "title": "The count of Data Exchange(avg)",
           "type": "timeseries"
         },
         {
@@ -3995,11 +4669,11 @@
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 6,
-            "y": 52
+            "w": 8,
+            "x": 8,
+            "y": 68
           },
-          "id": 128,
+          "id": 140,
           "options": {
             "legend": {
               "calcs": [],
@@ -4018,13 +4692,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "query_resource{instance=~\"${instance}\", quantile=\"0.5\"}",
+              "expr": "data_exchange_count{instance=~\"$instance\"}",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{quantile}}",
               "refId": "A"
             }
           ],
-          "title": "The usage of query resource(50%)",
+          "title": "The count of Data Exchange",
           "type": "timeseries"
         },
         {
@@ -4080,11 +4754,11 @@
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 12,
-            "y": 52
+            "w": 8,
+            "x": 16,
+            "y": 68
           },
-          "id": 129,
+          "id": 167,
           "options": {
             "legend": {
               "calcs": [],
@@ -4103,13 +4777,14 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "query_resource{instance=~\"${instance}\", quantile=\"0.75\"}",
+              "expr": "driver_scheduler{instance=~\"$instance\"}",
+              "format": "time_series",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The usage of query resource(75%)",
+          "title": "The number of query queue",
           "type": "timeseries"
         },
         {
@@ -4159,17 +4834,17 @@
                   }
                 ]
               },
-              "unit": "none"
+              "unit": "s"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
             "w": 6,
-            "x": 18,
-            "y": 52
+            "x": 0,
+            "y": 76
           },
-          "id": 130,
+          "id": 163,
           "options": {
             "legend": {
               "calcs": [],
@@ -4188,13 +4863,14 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "query_resource{instance=~\"${instance}\", quantile=\"1.0\"}",
+              "expr": "rate(driver_scheduler_seconds_sum{instance=~\"$instance\"}[1m]) / rate(driver_scheduler_seconds_count{instance=~\"$instance\"}[1m])",
+              "format": "time_series",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The usage of query resource(100%)",
+          "title": "The time consumed of query schedule time(avg)",
           "type": "timeseries"
         },
         {
@@ -4250,11 +4926,11 @@
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 0,
-            "y": 60
+            "w": 6,
+            "x": 6,
+            "y": 76
           },
-          "id": 135,
+          "id": 164,
           "options": {
             "legend": {
               "calcs": [],
@@ -4273,13 +4949,14 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "sum(rate(data_exchange_cost_seconds_sum{instance=~\"$instance\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\"}[1m])) by (operation)",
+              "expr": "driver_scheduler_seconds{instance=~\"$instance\", quantile=\"0.5\"}",
+              "format": "time_series",
               "interval": "",
-              "legendFormat": "{{operation}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of query data exchange(avg)",
+          "title": "The time consumed of query schedule time(50%)",
           "type": "timeseries"
         },
         {
@@ -4336,10 +5013,10 @@
           "gridPos": {
             "h": 8,
             "w": 6,
-            "x": 6,
-            "y": 60
+            "x": 12,
+            "y": 76
           },
-          "id": 136,
+          "id": 165,
           "options": {
             "legend": {
               "calcs": [],
@@ -4358,13 +5035,14 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "sum(rate(data_exchange_cost_seconds{instance=~\"$instance\", quantile=\"0.5\"}[1m])) by (operation)",
+              "expr": "driver_scheduler_seconds{instance=~\"$instance\", quantile=\"0.75\"}",
+              "format": "time_series",
               "interval": "",
-              "legendFormat": "{{operation}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of query data exchange(50%)",
+          "title": "The time consumed of query schedule time(75%)",
           "type": "timeseries"
         },
         {
@@ -4421,10 +5099,10 @@
           "gridPos": {
             "h": 8,
             "w": 6,
-            "x": 12,
-            "y": 60
+            "x": 18,
+            "y": 76
           },
-          "id": 137,
+          "id": 166,
           "options": {
             "legend": {
               "calcs": [],
@@ -4443,15 +5121,30 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "sum(rate(data_exchange_cost_seconds{instance=~\"$instance\", quantile=\"0.75\"}[1m])) by (operation)",
+              "expr": "driver_scheduler_seconds{instance=~\"$instance\", quantile=\"1.0\"}",
+              "format": "time_series",
               "interval": "",
-              "legendFormat": "{{operation}}",
+              "legendFormat": "{{name}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of query data exchange(75%)",
+          "title": "The time consumed of query schedule time(100%)",
           "type": "timeseries"
-        },
+        }
+      ],
+      "title": "Query Engine",
+      "type": "row"
+    },
+    {
+      "collapsed": true,
+      "gridPos": {
+        "h": 1,
+        "w": 24,
+        "x": 0,
+        "y": 4
+      },
+      "id": 100,
+      "panels": [
         {
           "datasource": {
             "type": "prometheus",
@@ -4506,10 +5199,10 @@
           "gridPos": {
             "h": 8,
             "w": 6,
-            "x": 18,
-            "y": 60
+            "x": 0,
+            "y": 5
           },
-          "id": 138,
+          "id": 75,
           "options": {
             "legend": {
               "calcs": [],
@@ -4528,13 +5221,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "sum(rate(data_exchange_cost_seconds{instance=~\"$instance\", quantile=\"1.0\"}[1m])) by (operation)",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"load_timeseries_metadata\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"load_timeseries_metadata\"}[1m])",
               "interval": "",
-              "legendFormat": "{{operation}}",
+              "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of query data exchange(100%)",
+          "title": "The time consumed of load timeseries metadata(avg)",
           "type": "timeseries"
         },
         {
@@ -4584,17 +5277,17 @@
                   }
                 ]
               },
-              "unit": "none"
+              "unit": "s"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
-            "w": 8,
-            "x": 0,
-            "y": 68
+            "w": 6,
+            "x": 6,
+            "y": 5
           },
-          "id": 139,
+          "id": 85,
           "options": {
             "legend": {
               "calcs": [],
@@ -4613,13 +5306,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(data_exchange_count_sum{instance=~\"$instance\"}[1m]) / rate(data_exchange_count_count{instance=~\"$instance\"}[1m])",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"load_timeseries_metadata\"}",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The count of Data Exchange(avg)",
+          "title": "The time consumed of load timeseries metadata(50%)",
           "type": "timeseries"
         },
         {
@@ -4669,17 +5362,17 @@
                   }
                 ]
               },
-              "unit": "none"
+              "unit": "s"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
-            "w": 8,
-            "x": 8,
-            "y": 68
+            "w": 6,
+            "x": 12,
+            "y": 5
           },
-          "id": 140,
+          "id": 77,
           "options": {
             "legend": {
               "calcs": [],
@@ -4698,13 +5391,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_count{instance=~\"$instance\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"load_timeseries_metadata\"}",
               "interval": "",
-              "legendFormat": "{{quantile}}",
+              "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The count of Data Exchange",
+          "title": "The time consumed of load timeseries metadata(75%)",
           "type": "timeseries"
         },
         {
@@ -4754,17 +5447,17 @@
                   }
                 ]
               },
-              "unit": "none"
+              "unit": "s"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
-            "w": 8,
-            "x": 16,
-            "y": 68
+            "w": 6,
+            "x": 18,
+            "y": 5
           },
-          "id": 167,
+          "id": 78,
           "options": {
             "legend": {
               "calcs": [],
@@ -4783,14 +5476,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "driver_scheduler{instance=~\"$instance\"}",
-              "format": "time_series",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"load_timeseries_metadata\"}",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The number of query queue",
+          "title": "The time consumed of load timeseries metadata(100%)",
           "type": "timeseries"
         },
         {
@@ -4848,9 +5540,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 76
+            "y": 13
           },
-          "id": 163,
+          "id": 86,
           "options": {
             "legend": {
               "calcs": [],
@@ -4869,14 +5561,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(driver_scheduler_seconds_sum{instance=~\"$instance\"}[1m]) / rate(driver_scheduler_seconds_count{instance=~\"$instance\"}[1m])",
-              "format": "time_series",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"read_timeseries_metadata\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"read_timeseries_metadata\"}[1m])",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query schedule time(avg)",
+          "title": "The time consumed of read timeseries metadata(avg)",
           "type": "timeseries"
         },
         {
@@ -4934,9 +5625,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 76
+            "y": 13
           },
-          "id": 164,
+          "id": 87,
           "options": {
             "legend": {
               "calcs": [],
@@ -4955,14 +5646,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "driver_scheduler_seconds{instance=~\"$instance\", quantile=\"0.5\"}",
-              "format": "time_series",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"read_timeseries_metadata\"}",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query schedule time(50%)",
+          "title": "The time consumed of read timeseries metadata(50%)",
           "type": "timeseries"
         },
         {
@@ -5020,9 +5710,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 76
+            "y": 13
           },
-          "id": 165,
+          "id": 88,
           "options": {
             "legend": {
               "calcs": [],
@@ -5041,14 +5731,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "driver_scheduler_seconds{instance=~\"$instance\", quantile=\"0.75\"}",
-              "format": "time_series",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"read_timeseries_metadata\"}",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query schedule time(75%)",
+          "title": "The time consumed of read timeseries metadata(75%)",
           "type": "timeseries"
         },
         {
@@ -5106,9 +5795,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 76
+            "y": 13
           },
-          "id": 166,
+          "id": 89,
           "options": {
             "legend": {
               "calcs": [],
@@ -5127,30 +5816,15 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "driver_scheduler_seconds{instance=~\"$instance\", quantile=\"1.0\"}",
-              "format": "time_series",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"read_timeseries_metadata\"}",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of query schedule time(100%)",
+          "title": "The time consumed of read timeseries metadata(100%)",
           "type": "timeseries"
-        }
-      ],
-      "title": "Query Engine",
-      "type": "row"
-    },
-    {
-      "collapsed": true,
-      "gridPos": {
-        "h": 1,
-        "w": 24,
-        "x": 0,
-        "y": 28
-      },
-      "id": 100,
-      "panels": [
+        },
         {
           "datasource": {
             "type": "prometheus",
@@ -5206,9 +5880,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 5
+            "y": 21
           },
-          "id": 75,
+          "id": 90,
           "options": {
             "legend": {
               "calcs": [],
@@ -5227,13 +5901,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"load_timeseries_metadata\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"load_timeseries_metadata\"}[1m])",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"timeseries_metadata_modification\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"timeseries_metadata_modification\"}[1m])",
               "interval": "",
-              "legendFormat": "{{type}}_{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of load timeseries metadata(avg)",
+          "title": "The time consumed of timeseries metadata modification(avg)",
           "type": "timeseries"
         },
         {
@@ -5291,9 +5965,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 5
+            "y": 21
           },
-          "id": 85,
+          "id": 91,
           "options": {
             "legend": {
               "calcs": [],
@@ -5312,13 +5986,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"load_timeseries_metadata\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"timeseries_metadata_modification\"}",
               "interval": "",
-              "legendFormat": "{{type}}_{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of load timeseries metadata(50%)",
+          "title": "The time consumed of timeseries metadata modification(50%)",
           "type": "timeseries"
         },
         {
@@ -5376,9 +6050,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 5
+            "y": 21
           },
-          "id": 77,
+          "id": 92,
           "options": {
             "legend": {
               "calcs": [],
@@ -5397,13 +6071,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"load_timeseries_metadata\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"timeseries_metadata_modification\"}",
               "interval": "",
-              "legendFormat": "{{type}}_{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of load timeseries metadata(75%)",
+          "title": "The time consumed of timeseries metadata modification(75%)",
           "type": "timeseries"
         },
         {
@@ -5461,9 +6135,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 5
+            "y": 21
           },
-          "id": 78,
+          "id": 93,
           "options": {
             "legend": {
               "calcs": [],
@@ -5482,13 +6156,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"load_timeseries_metadata\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"timeseries_metadata_modification\"}",
               "interval": "",
-              "legendFormat": "{{type}}_{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of load timeseries metadata(100%)",
+          "title": "The time consumed of timeseries metadata modification(100%)",
           "type": "timeseries"
         },
         {
@@ -5546,9 +6220,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 13
+            "y": 29
           },
-          "id": 86,
+          "id": 94,
           "options": {
             "legend": {
               "calcs": [],
@@ -5567,13 +6241,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"read_timeseries_metadata\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"read_timeseries_metadata\"}[1m])",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"load_chunk_metadata_list\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"load_chunk_metadata_list\"}[1m])",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of read timeseries metadata(avg)",
+          "title": "The time consumed of load chunk metadata list(avg)",
           "type": "timeseries"
         },
         {
@@ -5631,9 +6305,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 13
+            "y": 29
           },
-          "id": 87,
+          "id": 95,
           "options": {
             "legend": {
               "calcs": [],
@@ -5652,13 +6326,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"read_timeseries_metadata\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"load_chunk_metadata_list\"}",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of read timeseries metadata(50%)",
+          "title": "The time consumed of load chunk metadata list(50%)",
           "type": "timeseries"
         },
         {
@@ -5716,9 +6390,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 13
+            "y": 29
           },
-          "id": 88,
+          "id": 96,
           "options": {
             "legend": {
               "calcs": [],
@@ -5737,13 +6411,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"read_timeseries_metadata\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"load_chunk_metadata_list\"}",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of read timeseries metadata(75%)",
+          "title": "The time consumed of load chunk metadata list(75%)",
           "type": "timeseries"
         },
         {
@@ -5801,9 +6475,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 13
+            "y": 29
           },
-          "id": 89,
+          "id": 97,
           "options": {
             "legend": {
               "calcs": [],
@@ -5822,13 +6496,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"read_timeseries_metadata\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"load_chunk_metadata_list\"}",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of read timeseries metadata(100%)",
+          "title": "The time consumed of load chunk metadata list(100%)",
           "type": "timeseries"
         },
         {
@@ -5886,9 +6560,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 21
+            "y": 37
           },
-          "id": 90,
+          "id": 98,
           "options": {
             "legend": {
               "calcs": [],
@@ -5907,13 +6581,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"timeseries_metadata_modification\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"timeseries_metadata_modification\"}[1m])",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"chunk_metadata_modification\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"chunk_metadata_modification\"}[1m])",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of timeseries metadata modification(avg)",
+          "title": "The time consumed of chunk metadata modification(avg)",
           "type": "timeseries"
         },
         {
@@ -5921,6 +6595,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -5971,9 +6646,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 21
+            "y": 37
           },
-          "id": 91,
+          "id": 101,
           "options": {
             "legend": {
               "calcs": [],
@@ -5992,13 +6667,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"timeseries_metadata_modification\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"chunk_metadata_modification\"}",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of timeseries metadata modification(50%)",
+          "title": "The time consumed of chunk metadata modification(50%)",
           "type": "timeseries"
         },
         {
@@ -6006,6 +6681,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -6056,9 +6732,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 21
+            "y": 37
           },
-          "id": 92,
+          "id": 102,
           "options": {
             "legend": {
               "calcs": [],
@@ -6077,13 +6753,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"timeseries_metadata_modification\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"chunk_metadata_modification\"}",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of timeseries metadata modification(75%)",
+          "title": "The time consumed of chunk metadata modification(75%)",
           "type": "timeseries"
         },
         {
@@ -6091,6 +6767,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -6141,9 +6818,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 21
+            "y": 37
           },
-          "id": 93,
+          "id": 103,
           "options": {
             "legend": {
               "calcs": [],
@@ -6162,13 +6839,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"timeseries_metadata_modification\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"chunk_metadata_modification\"}",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of timeseries metadata modification(100%)",
+          "title": "The time consumed of chunk metadata modification(100%)",
           "type": "timeseries"
         },
         {
@@ -6226,9 +6903,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 29
+            "y": 45
           },
-          "id": 94,
+          "id": 104,
           "options": {
             "legend": {
               "calcs": [],
@@ -6247,13 +6924,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"load_chunk_metadata_list\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"load_chunk_metadata_list\"}[1m])",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"chunk_metadata_filter\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"chunk_metadata_filter\"}[1m])",
               "interval": "",
               "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of load chunk metadata list(avg)",
+          "title": "The time consumed of chunk metadata filter(avg)",
           "type": "timeseries"
         },
         {
@@ -6261,6 +6938,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -6311,9 +6989,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 29
+            "y": 45
           },
-          "id": 95,
+          "id": 105,
           "options": {
             "legend": {
               "calcs": [],
@@ -6332,13 +7010,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"load_chunk_metadata_list\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"chunk_metadata_filter\"}",
               "interval": "",
               "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of load chunk metadata list(50%)",
+          "title": "The time consumed of chunk metadata filter(50%)",
           "type": "timeseries"
         },
         {
@@ -6346,6 +7024,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -6396,9 +7075,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 29
+            "y": 45
           },
-          "id": 96,
+          "id": 106,
           "options": {
             "legend": {
               "calcs": [],
@@ -6417,13 +7096,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"load_chunk_metadata_list\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"chunk_metadata_filter\"}",
               "interval": "",
-              "legendFormat": "{{type}}_{{from}}",
+              "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of load chunk metadata list(75%)",
+          "title": "The time consumed of chunk metadata filter(75%)",
           "type": "timeseries"
         },
         {
@@ -6431,6 +7110,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -6481,9 +7161,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 29
+            "y": 45
           },
-          "id": 97,
+          "id": 107,
           "options": {
             "legend": {
               "calcs": [],
@@ -6502,13 +7182,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"load_chunk_metadata_list\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"chunk_metadata_filter\"}",
               "interval": "",
-              "legendFormat": "{{type}}_{{from}}",
+              "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of load chunk metadata list(100%)",
+          "title": "The time consumed of chunk metadata filter(100%)",
           "type": "timeseries"
         },
         {
@@ -6566,9 +7246,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 37
+            "y": 53
           },
-          "id": 98,
+          "id": 108,
           "options": {
             "legend": {
               "calcs": [],
@@ -6587,13 +7267,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"chunk_metadata_modification\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"chunk_metadata_modification\"}[1m])",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"construct_chunk_reader\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"construct_chunk_reader\"}[1m])",
               "interval": "",
               "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of chunk metadata modification(avg)",
+          "title": "The time consumed of construct chunk reader(avg)",
           "type": "timeseries"
         },
         {
@@ -6652,9 +7332,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 37
+            "y": 53
           },
-          "id": 101,
+          "id": 109,
           "options": {
             "legend": {
               "calcs": [],
@@ -6673,13 +7353,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"chunk_metadata_modification\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"construct_chunk_reader\"}",
               "interval": "",
               "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of chunk metadata modification(50%)",
+          "title": "The time consumed of construct chunk reader(50%)",
           "type": "timeseries"
         },
         {
@@ -6738,9 +7418,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 37
+            "y": 53
           },
-          "id": 102,
+          "id": 110,
           "options": {
             "legend": {
               "calcs": [],
@@ -6759,13 +7439,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"chunk_metadata_modification\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"construct_chunk_reader\"}",
               "interval": "",
               "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of chunk metadata modification(75%)",
+          "title": "The time consumed of construct chunk reader(75%)",
           "type": "timeseries"
         },
         {
@@ -6824,9 +7504,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 37
+            "y": 53
           },
-          "id": 103,
+          "id": 111,
           "options": {
             "legend": {
               "calcs": [],
@@ -6845,13 +7525,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"chunk_metadata_modification\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"construct_chunk_reader\"}",
               "interval": "",
               "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of chunk metadata modification(100%)",
+          "title": "The time consumed of construct chunk reader(100%)",
           "type": "timeseries"
         },
         {
@@ -6909,9 +7589,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 45
+            "y": 61
           },
-          "id": 104,
+          "id": 112,
           "options": {
             "legend": {
               "calcs": [],
@@ -6930,13 +7610,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"chunk_metadata_filter\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"chunk_metadata_filter\"}[1m])",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"read_chunk\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"read_chunk\"}[1m])",
               "interval": "",
-              "legendFormat": "{{type}}_{{from}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of chunk metadata filter(avg)",
+          "title": "The time consumed of read chunk(avg)",
           "type": "timeseries"
         },
         {
@@ -6995,9 +7675,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 45
+            "y": 61
           },
-          "id": 105,
+          "id": 113,
           "options": {
             "legend": {
               "calcs": [],
@@ -7016,13 +7696,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"chunk_metadata_filter\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"read_chunk\"}",
               "interval": "",
-              "legendFormat": "{{type}}-{{from}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of chunk metadata filter(50%)",
+          "title": "The time consumed of read chunk(50%)",
           "type": "timeseries"
         },
         {
@@ -7081,9 +7761,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 45
+            "y": 61
           },
-          "id": 106,
+          "id": 114,
           "options": {
             "legend": {
               "calcs": [],
@@ -7102,13 +7782,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"chunk_metadata_filter\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"read_chunk\"}",
               "interval": "",
-              "legendFormat": "{{type}}-{{from}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of chunk metadata filter(75%)",
+          "title": "The time consumed of read chunk(75%)",
           "type": "timeseries"
         },
         {
@@ -7167,9 +7847,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 45
+            "y": 61
           },
-          "id": 107,
+          "id": 115,
           "options": {
             "legend": {
               "calcs": [],
@@ -7188,13 +7868,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"chunk_metadata_filter\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"read_chunk\"}",
               "interval": "",
-              "legendFormat": "{{type}}-{{from}}",
+              "legendFormat": "{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of chunk metadata filter(100%)",
+          "title": "The time consumed of read chunk(100%)",
           "type": "timeseries"
         },
         {
@@ -7252,9 +7932,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 53
+            "y": 69
           },
-          "id": 108,
+          "id": 116,
           "options": {
             "legend": {
               "calcs": [],
@@ -7273,13 +7953,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"construct_chunk_reader\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"construct_chunk_reader\"}[1m])",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"init_chunk_reader\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"init_chunk_reader\"}[1m])",
               "interval": "",
               "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of construct chunk reader(avg)",
+          "title": "The time consumed of init chunk reader(avg)",
           "type": "timeseries"
         },
         {
@@ -7338,9 +8018,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 53
+            "y": 69
           },
-          "id": 109,
+          "id": 117,
           "options": {
             "legend": {
               "calcs": [],
@@ -7359,13 +8039,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"construct_chunk_reader\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"init_chunk_reader\"}",
               "interval": "",
               "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of construct chunk reader(50%)",
+          "title": "The time consumed of init chunk reader(50%)",
           "type": "timeseries"
         },
         {
@@ -7424,9 +8104,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 53
+            "y": 69
           },
-          "id": 110,
+          "id": 118,
           "options": {
             "legend": {
               "calcs": [],
@@ -7445,13 +8125,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"construct_chunk_reader\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"init_chunk_reader\"}",
               "interval": "",
               "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of construct chunk reader(75%)",
+          "title": "The time consumed of init chunk reader(75%)",
           "type": "timeseries"
         },
         {
@@ -7510,9 +8190,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 53
+            "y": 69
           },
-          "id": 111,
+          "id": 119,
           "options": {
             "legend": {
               "calcs": [],
@@ -7531,13 +8211,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"construct_chunk_reader\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"init_chunk_reader\"}",
               "interval": "",
               "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of construct chunk reader(100%)",
+          "title": "The time consumed of init chunk reader(100%)",
           "type": "timeseries"
         },
         {
@@ -7595,9 +8275,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 61
+            "y": 77
           },
-          "id": 112,
+          "id": 120,
           "options": {
             "legend": {
               "calcs": [],
@@ -7616,13 +8296,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"read_chunk\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"read_chunk\"}[1m])",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"build_tsblock_from_page_reader\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"build_tsblock_from_page_reader\"}[1m])",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}_{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of read chunk(avg)",
+          "title": "The time consumed of build tsblock from page reader(avg)",
           "type": "timeseries"
         },
         {
@@ -7681,9 +8361,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 61
+            "y": 77
           },
-          "id": 113,
+          "id": 121,
           "options": {
             "legend": {
               "calcs": [],
@@ -7702,13 +8382,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"read_chunk\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"build_tsblock_from_page_reader\"}",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of read chunk(50%)",
+          "title": "The time consumed of build tsblock from page reader(50%)",
           "type": "timeseries"
         },
         {
@@ -7767,9 +8447,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 61
+            "y": 77
           },
-          "id": 114,
+          "id": 122,
           "options": {
             "legend": {
               "calcs": [],
@@ -7788,13 +8468,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"read_chunk\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"build_tsblock_from_page_reader\"}",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of read chunk(75%)",
+          "title": "The time consumed of build tsblock from page reader(75%)",
           "type": "timeseries"
         },
         {
@@ -7853,9 +8533,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 61
+            "y": 77
           },
-          "id": 115,
+          "id": 123,
           "options": {
             "legend": {
               "calcs": [],
@@ -7874,13 +8554,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"read_chunk\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"build_tsblock_from_page_reader\"}",
               "interval": "",
-              "legendFormat": "{{from}}",
+              "legendFormat": "{{type}}-{{from}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of read chunk(100%)",
+          "title": "The time consumed of build tsblock from page reader(100%)",
           "type": "timeseries"
         },
         {
@@ -7938,9 +8618,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 69
+            "y": 85
           },
-          "id": 116,
+          "id": 124,
           "options": {
             "legend": {
               "calcs": [],
@@ -7959,13 +8639,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"init_chunk_reader\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"init_chunk_reader\"}[1m])",
+              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"build_tsblock_from_merge_reader\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"build_tsblock_from_merge_reader\"}[1m])",
               "interval": "",
-              "legendFormat": "{{type}}_{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of init chunk reader(avg)",
+          "title": "The time consumed of build tsblock from merge reader(avg)",
           "type": "timeseries"
         },
         {
@@ -8024,9 +8704,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 69
+            "y": 85
           },
-          "id": 117,
+          "id": 125,
           "options": {
             "legend": {
               "calcs": [],
@@ -8045,13 +8725,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"init_chunk_reader\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"build_tsblock_from_merge_reader\"}",
               "interval": "",
-              "legendFormat": "{{type}}-{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of init chunk reader(50%)",
+          "title": "The time consumed of build tsblock from merge reader(50%)",
           "type": "timeseries"
         },
         {
@@ -8110,9 +8790,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 69
+            "y": 85
           },
-          "id": 118,
+          "id": 126,
           "options": {
             "legend": {
               "calcs": [],
@@ -8131,13 +8811,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"init_chunk_reader\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"build_tsblock_from_merge_reader\"}",
               "interval": "",
-              "legendFormat": "{{type}}-{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of init chunk reader(75%)",
+          "title": "The time consumed of build tsblock from merge reader(75%)",
           "type": "timeseries"
         },
         {
@@ -8196,9 +8876,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 69
+            "y": 85
           },
-          "id": 119,
+          "id": 127,
           "options": {
             "legend": {
               "calcs": [],
@@ -8217,15 +8897,29 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"init_chunk_reader\"}",
+              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"build_tsblock_from_merge_reader\"}",
               "interval": "",
-              "legendFormat": "{{type}}-{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of init chunk reader(100%)",
+          "title": "The time consumed of build tsblock from merge reader(100%)",
           "type": "timeseries"
-        },
+        }
+      ],
+      "title": "Query Interface",
+      "type": "row"
+    },
+    {
+      "collapsed": true,
+      "gridPos": {
+        "h": 1,
+        "w": 24,
+        "x": 0,
+        "y": 5
+      },
+      "id": 142,
+      "panels": [
         {
           "datasource": {
             "type": "prometheus",
@@ -8281,9 +8975,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 77
+            "y": 6
           },
-          "id": 120,
+          "id": 143,
           "options": {
             "legend": {
               "calcs": [],
@@ -8302,13 +8996,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"build_tsblock_from_page_reader\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"build_tsblock_from_page_reader\"}[1m])",
+              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"source_handle_get_tsblock\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"source_handle_get_tsblock\"}[1m])",
               "interval": "",
-              "legendFormat": "{{type}}_{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of build tsblock from page reader(avg)",
+          "title": "The time consumed of source handle get tsblock(avg)",
           "type": "timeseries"
         },
         {
@@ -8316,7 +9010,6 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -8367,9 +9060,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 77
+            "y": 6
           },
-          "id": 121,
+          "id": 144,
           "options": {
             "legend": {
               "calcs": [],
@@ -8388,13 +9081,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"build_tsblock_from_page_reader\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_get_tsblock\", quantile=\"0.5\"}",
               "interval": "",
-              "legendFormat": "{{type}}-{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of build tsblock from page reader(50%)",
+          "title": "The  time consumed of source handle get tsblock(50%)",
           "type": "timeseries"
         },
         {
@@ -8402,7 +9095,6 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -8453,9 +9145,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 77
+            "y": 6
           },
-          "id": 122,
+          "id": 145,
           "options": {
             "legend": {
               "calcs": [],
@@ -8474,13 +9166,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"build_tsblock_from_page_reader\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_get_tsblock\", quantile=\"0.75\"}",
               "interval": "",
-              "legendFormat": "{{type}}-{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of build tsblock from page reader(75%)",
+          "title": "The  time consumed of source handle get tsblock(75%)",
           "type": "timeseries"
         },
         {
@@ -8488,7 +9180,6 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -8539,9 +9230,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 77
+            "y": 6
           },
-          "id": 123,
+          "id": 146,
           "options": {
             "legend": {
               "calcs": [],
@@ -8560,13 +9251,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"build_tsblock_from_page_reader\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_get_tsblock\", quantile=\"1.0\"}",
               "interval": "",
-              "legendFormat": "{{type}}-{{from}}",
+              "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of build tsblock from page reader(100%)",
+          "title": "The  time consumed of source handle get tsblock(100%)",
           "type": "timeseries"
         },
         {
@@ -8624,9 +9315,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 85
+            "y": 14
           },
-          "id": 124,
+          "id": 147,
           "options": {
             "legend": {
               "calcs": [],
@@ -8645,13 +9336,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(series_scan_cost_seconds_sum{instance=~\"$instance\", stage=\"build_tsblock_from_merge_reader\"}[1m]) / rate(series_scan_cost_seconds_count{instance=~\"$instance\", stage=\"build_tsblock_from_merge_reader\"}[1m])",
+              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\"}[1m])",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of build tsblock from merge reader(avg)",
+          "title": "The  time consumed of source handle deserialize tsblock(avg)",
           "type": "timeseries"
         },
         {
@@ -8659,7 +9350,6 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -8710,9 +9400,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 85
+            "y": 14
           },
-          "id": 125,
+          "id": 148,
           "options": {
             "legend": {
               "calcs": [],
@@ -8731,13 +9421,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.5\", stage=\"build_tsblock_from_merge_reader\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\", quantile=\"0.5\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of build tsblock from merge reader(50%)",
+          "title": "The time consumed of source handle deserialize tsblock(50%)",
           "type": "timeseries"
         },
         {
@@ -8745,7 +9435,6 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -8796,9 +9485,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 85
+            "y": 14
           },
-          "id": 126,
+          "id": 149,
           "options": {
             "legend": {
               "calcs": [],
@@ -8817,13 +9506,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"0.75\", stage=\"build_tsblock_from_merge_reader\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\", quantile=\"0.75\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of build tsblock from merge reader(75%)",
+          "title": "The time consumed of source handle deserialize tsblock(75%)",
           "type": "timeseries"
         },
         {
@@ -8831,7 +9520,6 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -8882,9 +9570,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 85
+            "y": 14
           },
-          "id": 127,
+          "id": 150,
           "options": {
             "legend": {
               "calcs": [],
@@ -8903,29 +9591,15 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "series_scan_cost_seconds{instance=~\"${instance}\", quantile=\"1.0\", stage=\"build_tsblock_from_merge_reader\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\", quantile=\"1.0\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of build tsblock from merge reader(100%)",
+          "title": "The time consumed of source handle deserialize tsblock(100%)",
           "type": "timeseries"
-        }
-      ],
-      "title": "Query Interface",
-      "type": "row"
-    },
-    {
-      "collapsed": true,
-      "gridPos": {
-        "h": 1,
-        "w": 24,
-        "x": 0,
-        "y": 29
-      },
-      "id": 142,
-      "panels": [
+        },
         {
           "datasource": {
             "type": "prometheus",
@@ -8981,9 +9655,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 6
+            "y": 22
           },
-          "id": 143,
+          "id": 151,
           "options": {
             "legend": {
               "calcs": [],
@@ -9002,13 +9676,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"source_handle_get_tsblock\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"source_handle_get_tsblock\"}[1m])",
+              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\"}[1m])",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of source handle get tsblock(avg)",
+          "title": "The time consumed  of sink handle send tsblock(avg)",
           "type": "timeseries"
         },
         {
@@ -9066,9 +9740,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 6
+            "y": 22
           },
-          "id": 144,
+          "id": 152,
           "options": {
             "legend": {
               "calcs": [],
@@ -9087,13 +9761,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_get_tsblock\", quantile=\"0.5\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\", quantile=\"0.5\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The  time consumed of source handle get tsblock(50%)",
+          "title": "The time consumed  of sink handle send tsblock(50%)",
           "type": "timeseries"
         },
         {
@@ -9151,9 +9825,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 6
+            "y": 22
           },
-          "id": 145,
+          "id": 153,
           "options": {
             "legend": {
               "calcs": [],
@@ -9172,13 +9846,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_get_tsblock\", quantile=\"0.75\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\", quantile=\"0.75\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The  time consumed of source handle get tsblock(75%)",
+          "title": "The time consumed  of sink handle send tsblock(75%)",
           "type": "timeseries"
         },
         {
@@ -9236,9 +9910,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 6
+            "y": 22
           },
-          "id": 146,
+          "id": 154,
           "options": {
             "legend": {
               "calcs": [],
@@ -9257,13 +9931,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_get_tsblock\", quantile=\"1.0\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\", quantile=\"1.0\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The  time consumed of source handle get tsblock(100%)",
+          "title": "The time consumed  of sink handle send tsblock(100%)",
           "type": "timeseries"
         },
         {
@@ -9321,9 +9995,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 14
+            "y": 30
           },
-          "id": 147,
+          "id": 155,
           "options": {
             "legend": {
               "calcs": [],
@@ -9342,13 +10016,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\"}[1m])",
+              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\"}[1m])",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The  time consumed of source handle deserialize tsblock(avg)",
+          "title": "The time consumed  of on acknowledge data block event task(avg)",
           "type": "timeseries"
         },
         {
@@ -9406,9 +10080,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 14
+            "y": 30
           },
-          "id": 148,
+          "id": 156,
           "options": {
             "legend": {
               "calcs": [],
@@ -9427,13 +10101,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\", quantile=\"0.5\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\", quantile=\"0.5\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of source handle deserialize tsblock(50%)",
+          "title": "The time consumed of on acknowledge data block event task(50%)",
           "type": "timeseries"
         },
         {
@@ -9491,9 +10165,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 14
+            "y": 30
           },
-          "id": 149,
+          "id": 157,
           "options": {
             "legend": {
               "calcs": [],
@@ -9512,13 +10186,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\", quantile=\"0.75\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\", quantile=\"0.75\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of source handle deserialize tsblock(75%)",
+          "title": "The time consumed  of on acknowledge data block event task(75%)",
           "type": "timeseries"
         },
         {
@@ -9576,9 +10250,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 14
+            "y": 30
           },
-          "id": 150,
+          "id": 158,
           "options": {
             "legend": {
               "calcs": [],
@@ -9597,13 +10271,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"source_handle_deserialize_tsblock\", quantile=\"1.0\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\", quantile=\"1.0\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed of source handle deserialize tsblock(100%)",
+          "title": "The time consumed  of on acknowledge data block event task(100%)",
           "type": "timeseries"
         },
         {
@@ -9661,9 +10335,9 @@
             "h": 8,
             "w": 6,
             "x": 0,
-            "y": 22
+            "y": 38
           },
-          "id": 151,
+          "id": 159,
           "options": {
             "legend": {
               "calcs": [],
@@ -9682,13 +10356,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\"}[1m])",
+              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"get_data_block_task\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"get_data_block_task\"}[1m])",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of sink handle send tsblock(avg)",
+          "title": "The time consumed  of get data block task(avg)",
           "type": "timeseries"
         },
         {
@@ -9746,9 +10420,9 @@
             "h": 8,
             "w": 6,
             "x": 6,
-            "y": 22
+            "y": 38
           },
-          "id": 152,
+          "id": 160,
           "options": {
             "legend": {
               "calcs": [],
@@ -9767,13 +10441,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\", quantile=\"0.5\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"get_data_block_task\", quantile=\"0.5\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of sink handle send tsblock(50%)",
+          "title": "The time consumed  of get data block task(50%)",
           "type": "timeseries"
         },
         {
@@ -9831,9 +10505,9 @@
             "h": 8,
             "w": 6,
             "x": 12,
-            "y": 22
+            "y": 38
           },
-          "id": 153,
+          "id": 161,
           "options": {
             "legend": {
               "calcs": [],
@@ -9852,13 +10526,13 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\", quantile=\"0.75\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"get_data_block_task\", quantile=\"0.75\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of sink handle send tsblock(75%)",
+          "title": "The time consumed  of get data block task(75%)",
           "type": "timeseries"
         },
         {
@@ -9916,9 +10590,9 @@
             "h": 8,
             "w": 6,
             "x": 18,
-            "y": 22
+            "y": 38
           },
-          "id": 154,
+          "id": 162,
           "options": {
             "legend": {
               "calcs": [],
@@ -9937,15 +10611,33 @@
                 "uid": "${DS_PROMETHEUS}"
               },
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"sink_handle_send_tsblock\", quantile=\"1.0\"}",
+              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"get_data_block_task\", quantile=\"1.0\"}",
               "interval": "",
               "legendFormat": "{{type}}",
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of sink handle send tsblock(100%)",
+          "title": "The time consumed  of get data block task(100%)",
           "type": "timeseries"
-        },
+        }
+      ],
+      "title": "Query Data Exchange",
+      "type": "row"
+    },
+    {
+      "collapsed": true,
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "gridPos": {
+        "h": 1,
+        "w": 24,
+        "x": 0,
+        "y": 6
+      },
+      "id": 20,
+      "panels": [
         {
           "datasource": {
             "type": "prometheus",
@@ -9993,22 +10685,23 @@
                   }
                 ]
               },
-              "unit": "s"
+              "unit": "bytes"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
+            "w": 8,
             "x": 0,
-            "y": 30
+            "y": 7
           },
-          "id": 155,
+          "id": 21,
           "options": {
             "legend": {
               "calcs": [],
               "displayMode": "list",
-              "placement": "bottom"
+              "placement": "bottom",
+              "showLegend": true
             },
             "tooltip": {
               "mode": "multi",
@@ -10021,14 +10714,16 @@
                 "type": "prometheus",
                 "uid": "${DS_PROMETHEUS}"
               },
+              "editorMode": "code",
               "exemplar": true,
-              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\"}[1m])",
+              "expr": "mem{instance=\"$instance\", name=\"IoTConsensus\"}",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{name}}",
+              "range": true,
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of on acknowledge data block event task(avg)",
+          "title": "IoTConsensus Used Memory",
           "type": "timeseries"
         },
         {
@@ -10036,6 +10731,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10077,23 +10773,23 @@
                     "color": "green"
                   }
                 ]
-              },
-              "unit": "s"
+              }
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 6,
-            "y": 30
+            "w": 8,
+            "x": 8,
+            "y": 7
           },
-          "id": 156,
+          "id": 22,
           "options": {
             "legend": {
               "calcs": [],
               "displayMode": "list",
-              "placement": "bottom"
+              "placement": "bottom",
+              "showLegend": true
             },
             "tooltip": {
               "mode": "multi",
@@ -10106,14 +10802,16 @@
                 "type": "prometheus",
                 "uid": "${DS_PROMETHEUS}"
               },
+              "editorMode": "code",
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\", quantile=\"0.5\"}",
+              "expr": "iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"safeIndex\"}",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{region}}",
+              "range": true,
               "refId": "A"
             }
           ],
-          "title": "The time consumed of on acknowledge data block event task(50%)",
+          "title": "IoTConsensus Sync Index",
           "type": "timeseries"
         },
         {
@@ -10121,6 +10819,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10163,22 +10862,23 @@
                   }
                 ]
               },
-              "unit": "s"
+              "unit": "none"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 12,
-            "y": 30
+            "w": 8,
+            "x": 16,
+            "y": 7
           },
-          "id": 157,
+          "id": 23,
           "options": {
             "legend": {
               "calcs": [],
               "displayMode": "list",
-              "placement": "bottom"
+              "placement": "bottom",
+              "showLegend": true
             },
             "tooltip": {
               "mode": "multi",
@@ -10191,14 +10891,31 @@
                 "type": "prometheus",
                 "uid": "${DS_PROMETHEUS}"
               },
+              "editorMode": "code",
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\", quantile=\"0.75\"}",
+              "expr": "sum(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"searchIndex\"}) by (instance) - sum(iot_consensus{name=\"ioTConsensusServerImpl\", type=\"safeIndex\"}) by (instance)",
+              "hide": false,
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "Total Sync Lag",
+              "range": true,
               "refId": "A"
+            },
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "exemplar": true,
+              "expr": "sum(iot_consensus{instance=~\"$instance\", type=~\"cachedRequestInMemoryQueue\"}) by (instance)",
+              "hide": false,
+              "interval": "",
+              "legendFormat": "Cached Request",
+              "range": true,
+              "refId": "B"
             }
           ],
-          "title": "The time consumed  of on acknowledge data block event task(75%)",
+          "title": "IoTConsensus Overview",
           "type": "timeseries"
         },
         {
@@ -10206,6 +10923,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10248,22 +10966,23 @@
                   }
                 ]
               },
-              "unit": "s"
+              "unit": "ms"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 18,
-            "y": 30
+            "w": 8,
+            "x": 0,
+            "y": 15
           },
-          "id": 158,
+          "id": 24,
           "options": {
             "legend": {
               "calcs": [],
               "displayMode": "list",
-              "placement": "bottom"
+              "placement": "bottom",
+              "showLegend": true
             },
             "tooltip": {
               "mode": "multi",
@@ -10276,14 +10995,16 @@
                 "type": "prometheus",
                 "uid": "${DS_PROMETHEUS}"
               },
+              "editorMode": "code",
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"on_acknowledge_data_block_event_task\", quantile=\"1.0\"}",
+              "expr": "avg(stage{quantile=\"0.5\", instance=~\"${instance}\"}) by (instance, type)",
               "interval": "",
               "legendFormat": "{{type}}",
+              "range": true,
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of on acknowledge data block event task(100%)",
+          "title": "The Time Consumed Of Different Stages (50%)",
           "type": "timeseries"
         },
         {
@@ -10291,6 +11012,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10333,22 +11055,53 @@
                   }
                 ]
               },
-              "unit": "s"
+              "unit": "ms"
             },
-            "overrides": []
+            "overrides": [
+              {
+                "__systemRef": "hideSeriesFrom",
+                "matcher": {
+                  "id": "byNames",
+                  "options": {
+                    "mode": "exclude",
+                    "names": [
+                      "writeStateMachine",
+                      "checkingBeforeWrite",
+                      "getStateMachineLock",
+                      "offerRequestToQueue",
+                      "constructBatch",
+                      "consensusWrite"
+                    ],
+                    "prefix": "All except:",
+                    "readOnly": true
+                  }
+                },
+                "properties": [
+                  {
+                    "id": "custom.hideFrom",
+                    "value": {
+                      "legend": false,
+                      "tooltip": false,
+                      "viz": true
+                    }
+                  }
+                ]
+              }
+            ]
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 0,
-            "y": 38
+            "w": 8,
+            "x": 8,
+            "y": 15
           },
-          "id": 159,
+          "id": 25,
           "options": {
             "legend": {
               "calcs": [],
               "displayMode": "list",
-              "placement": "bottom"
+              "placement": "bottom",
+              "showLegend": true
             },
             "tooltip": {
               "mode": "multi",
@@ -10361,14 +11114,16 @@
                 "type": "prometheus",
                 "uid": "${DS_PROMETHEUS}"
               },
+              "editorMode": "code",
               "exemplar": true,
-              "expr": "rate(data_exchange_cost_seconds_sum{instance=~\"$instance\", operation=\"get_data_block_task\"}[1m]) / rate(data_exchange_cost_seconds_count{instance=~\"$instance\", operation=\"get_data_block_task\"}[1m])",
+              "expr": "avg(stage{quantile=\"0.75\", instance=~\"${instance}\"}) by (instance, type)",
               "interval": "",
               "legendFormat": "{{type}}",
+              "range": true,
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of get data block task(avg)",
+          "title": "The Time Consumed Of Different Stages (75%)",
           "type": "timeseries"
         },
         {
@@ -10376,6 +11131,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10418,22 +11174,48 @@
                   }
                 ]
               },
-              "unit": "s"
+              "unit": "ms"
             },
-            "overrides": []
+            "overrides": [
+              {
+                "__systemRef": "hideSeriesFrom",
+                "matcher": {
+                  "id": "byNames",
+                  "options": {
+                    "mode": "exclude",
+                    "names": [
+                      "checkingBeforeWrite"
+                    ],
+                    "prefix": "All except:",
+                    "readOnly": true
+                  }
+                },
+                "properties": [
+                  {
+                    "id": "custom.hideFrom",
+                    "value": {
+                      "legend": false,
+                      "tooltip": false,
+                      "viz": true
+                    }
+                  }
+                ]
+              }
+            ]
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 6,
-            "y": 38
+            "w": 8,
+            "x": 16,
+            "y": 15
           },
-          "id": 160,
+          "id": 26,
           "options": {
             "legend": {
               "calcs": [],
               "displayMode": "list",
-              "placement": "bottom"
+              "placement": "bottom",
+              "showLegend": true
             },
             "tooltip": {
               "mode": "multi",
@@ -10446,14 +11228,16 @@
                 "type": "prometheus",
                 "uid": "${DS_PROMETHEUS}"
               },
+              "editorMode": "code",
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"get_data_block_task\", quantile=\"0.5\"}",
+              "expr": "avg(stage{quantile=\"1.0\", instance=~\"${instance}\"}) by (instance, type)",
               "interval": "",
               "legendFormat": "{{type}}",
+              "range": true,
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of get data block task(50%)",
+          "title": "The Time Consumed Of Different Stages (100%)",
           "type": "timeseries"
         },
         {
@@ -10461,6 +11245,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10502,23 +11287,23 @@
                     "color": "green"
                   }
                 ]
-              },
-              "unit": "s"
+              }
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 12,
-            "y": 38
+            "w": 8,
+            "x": 0,
+            "y": 23
           },
-          "id": 161,
+          "id": 27,
           "options": {
             "legend": {
               "calcs": [],
               "displayMode": "list",
-              "placement": "bottom"
+              "placement": "bottom",
+              "showLegend": true
             },
             "tooltip": {
               "mode": "multi",
@@ -10531,14 +11316,16 @@
                 "type": "prometheus",
                 "uid": "${DS_PROMETHEUS}"
               },
+              "editorMode": "code",
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"get_data_block_task\", quantile=\"0.75\"}",
+              "expr": "irate(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"searchIndex\"}[1m])",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{region}}",
+              "range": true,
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of get data block task(75%)",
+          "title": "IoTConsensus Search Index Rate",
           "type": "timeseries"
         },
         {
@@ -10546,6 +11333,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "description": "",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10587,23 +11375,23 @@
                     "color": "green"
                   }
                 ]
-              },
-              "unit": "s"
+              }
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
-            "w": 6,
-            "x": 18,
-            "y": 38
+            "w": 8,
+            "x": 8,
+            "y": 23
           },
-          "id": 162,
+          "id": 28,
           "options": {
             "legend": {
               "calcs": [],
               "displayMode": "list",
-              "placement": "bottom"
+              "placement": "bottom",
+              "showLegend": true
             },
             "tooltip": {
               "mode": "multi",
@@ -10616,34 +11404,18 @@
                 "type": "prometheus",
                 "uid": "${DS_PROMETHEUS}"
               },
+              "editorMode": "code",
               "exemplar": true,
-              "expr": "data_exchange_cost_seconds{instance=~\"$instance\", operation=\"get_data_block_task\", quantile=\"1.0\"}",
+              "expr": "irate(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"safeIndex\"}[1m])",
               "interval": "",
-              "legendFormat": "{{type}}",
+              "legendFormat": "{{region}}",
+              "range": true,
               "refId": "A"
             }
           ],
-          "title": "The time consumed  of get data block task(100%)",
+          "title": "IoTConsensus Safe Index Rate",
           "type": "timeseries"
-        }
-      ],
-      "title": "Query Data Exchange",
-      "type": "row"
-    },
-    {
-      "collapsed": true,
-      "datasource": {
-        "type": "prometheus",
-        "uid": "${DS_PROMETHEUS}"
-      },
-      "gridPos": {
-        "h": 1,
-        "w": 24,
-        "x": 0,
-        "y": 30
-      },
-      "id": 20,
-      "panels": [
+        },
         {
           "datasource": {
             "type": "prometheus",
@@ -10691,17 +11463,17 @@
                   }
                 ]
               },
-              "unit": "bytes"
+              "unit": "none"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
             "w": 8,
-            "x": 0,
-            "y": 7
+            "x": 16,
+            "y": 23
           },
-          "id": 21,
+          "id": 29,
           "options": {
             "legend": {
               "calcs": [],
@@ -10722,14 +11494,14 @@
               },
               "editorMode": "code",
               "exemplar": true,
-              "expr": "mem{instance=\"$instance\", name=\"IoTConsensus\"}",
+              "expr": "sum(iot_consensus{instance=~\"$instance\", type=~\"cachedRequestInMemoryQueue\"}) by (region, name)",
               "interval": "",
-              "legendFormat": "{{name}}",
+              "legendFormat": "{{region}} {{name}}",
               "range": true,
               "refId": "A"
             }
           ],
-          "title": "IoTConsensus Used Memory",
+          "title": "IoTConsensus LogDispatcher Request Size",
           "type": "timeseries"
         },
         {
@@ -10737,7 +11509,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
+          "description": "Total Sync Gap of region",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10779,17 +11551,18 @@
                     "color": "green"
                   }
                 ]
-              }
+              },
+              "unit": "none"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
             "w": 8,
-            "x": 8,
-            "y": 7
+            "x": 0,
+            "y": 31
           },
-          "id": 22,
+          "id": 30,
           "options": {
             "legend": {
               "calcs": [],
@@ -10810,14 +11583,16 @@
               },
               "editorMode": "code",
               "exemplar": true,
-              "expr": "iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"safeIndex\"}",
+              "expr": "sum(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"searchIndex\"}) by (region) - sum(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"safeIndex\"}) by (region)",
+              "hide": false,
               "interval": "",
               "legendFormat": "{{region}}",
               "range": true,
               "refId": "A"
             }
           ],
-          "title": "IoTConsensus Sync Index",
+          "title": "Sync Lag",
+          "transformations": [],
           "type": "timeseries"
         },
         {
@@ -10825,7 +11600,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
+          "description": "Gap between write and fastest LogDispatcherThread in one region",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10875,10 +11650,10 @@
           "gridPos": {
             "h": 8,
             "w": 8,
-            "x": 16,
-            "y": 7
+            "x": 8,
+            "y": 31
           },
-          "id": 23,
+          "id": 31,
           "options": {
             "legend": {
               "calcs": [],
@@ -10899,29 +11674,17 @@
               },
               "editorMode": "code",
               "exemplar": true,
-              "expr": "sum(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"searchIndex\"}) by (instance) - sum(iot_consensus{name=\"ioTConsensusServerImpl\", type=\"safeIndex\"}) by (instance)",
-              "hide": false,
+              "expr": "sum(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"searchIndex\"}) by (region) - max(iot_consensus{instance=~\"$instance\", name=~\"logDispatcher.*\", type=\"currentSyncIndex\"}) by (region)",
+              "format": "time_series",
+              "instant": false,
               "interval": "",
-              "legendFormat": "Total Sync Lag",
-              "range": true,
+              "intervalFactor": 1,
+              "legendFormat": "{{region}}",
               "refId": "A"
-            },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sum(iot_consensus{instance=~\"$instance\", type=~\"cachedRequestInMemoryQueue\"}) by (instance)",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "Cached Request",
-              "range": true,
-              "refId": "B"
             }
           ],
-          "title": "IoTConsensus Overview",
+          "title": "Min Peer Sync Lag",
+          "transformations": [],
           "type": "timeseries"
         },
         {
@@ -10929,7 +11692,7 @@
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
+          "description": "Gap between fastest LogDispatcherThread and slowest LogDispatcherThread in one region",
           "fieldConfig": {
             "defaults": {
               "color": {
@@ -10972,2604 +11735,2424 @@
                   }
                 ]
               },
-              "unit": "ms"
+              "unit": "none"
             },
             "overrides": []
           },
           "gridPos": {
             "h": 8,
             "w": 8,
-            "x": 0,
-            "y": 15
+            "x": 16,
+            "y": 31
+          },
+          "id": 32,
+          "options": {
+            "legend": {
+              "calcs": [],
+              "displayMode": "list",
+              "placement": "bottom",
+              "showLegend": true
+            },
+            "tooltip": {
+              "mode": "multi",
+              "sort": "desc"
+            }
+          },
+          "targets": [
+            {
+              "datasource": {
+                "type": "prometheus",
+                "uid": "${DS_PROMETHEUS}"
+              },
+              "editorMode": "code",
+              "exemplar": true,
+              "expr": "max(iot_consensus{instance=~\"$instance\", name=~\"logDispatcher.*\", type=\"currentSyncIndex\"}) by (region) - min(iot_consensus{instance=~\"$instance\", name=~\"logDispatcher.*\", type=\"currentSyncIndex\"}) by (region)",
+              "format": "time_series",
+              "instant": false,
+              "interval": "",
+              "intervalFactor": 1,
+              "legendFormat": "{{region}}",
+              "refId": "A"
+            }
+          ],
+          "title": "Sync Speed Diff Of Peers",
+          "transformations": [],
+          "type": "timeseries"
+        }
+      ],
+      "targets": [
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "refId": "A"
+        }
+      ],
+      "title": "IoT Consensus",
+      "type": "row"
+    },
+    {
+      "collapsed": false,
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "gridPos": {
+        "h": 1,
+        "w": 24,
+        "x": 0,
+        "y": 7
+      },
+      "id": 33,
+      "panels": [],
+      "targets": [
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "refId": "A"
+        }
+      ],
+      "title": "System",
+      "type": "row"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "thresholds"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "percentage",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "Core"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 0,
+        "y": 8
+      },
+      "id": 34,
+      "options": {
+        "colorMode": "value",
+        "graphMode": "area",
+        "justifyMode": "auto",
+        "orientation": "auto",
+        "reduceOptions": {
+          "calcs": [
+            "lastNotNull"
+          ],
+          "fields": "",
+          "values": false
+        },
+        "textMode": "auto"
+      },
+      "pluginVersion": "8.3.3",
+      "targets": [
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sys_cpu_cores{instance=\"$instance\",name=\"system\"}",
+          "interval": "",
+          "legendFormat": "__auto",
+          "range": true,
+          "refId": "A"
+        }
+      ],
+      "title": "CPU Core",
+      "type": "stat"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
+          },
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "axisSoftMax": 0,
+            "axisSoftMin": 0,
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
+            },
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
+            }
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "percentage",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "percent"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 8,
+        "y": 8
+      },
+      "id": 35,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
+        },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sys_cpu_load{instance=\"$instance\",name=\"system\"}",
+          "interval": "",
+          "legendFormat": "System CPU Load",
+          "range": true,
+          "refId": "A"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "editorMode": "code",
+          "expr": "process_cpu_load{instance=\"$instance\",name=\"process\"}",
+          "hide": false,
+          "legendFormat": "Process CPU Load",
+          "range": true,
+          "refId": "B"
+        }
+      ],
+      "title": "CPU Load",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 24,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "axisSoftMax": 0,
+            "axisSoftMin": 0,
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
           },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "avg(stage{quantile=\"0.5\", instance=~\"${instance}\"}) by (instance, type)",
-              "interval": "",
-              "legendFormat": "{{type}}",
-              "range": true,
-              "refId": "A"
-            }
-          ],
-          "title": "The Time Consumed Of Different Stages (50%)",
-          "type": "timeseries"
+          "mappings": [],
+          "thresholds": {
+            "mode": "percentage",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "ns"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 16,
+        "y": 8
+      },
+      "id": 40,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "none"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "ms"
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sum(rate(process_cpu_time{instance=\"$instance\",name=\"process\"}[1m]))*60",
+          "interval": "",
+          "legendFormat": "System CPU Load",
+          "range": true,
+          "refId": "A"
+        }
+      ],
+      "title": "CPU Time(per minute)",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
+          },
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "axisSoftMax": 0,
+            "axisSoftMin": 0,
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "overrides": [
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
+            }
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "percentage",
+            "steps": [
               {
-                "__systemRef": "hideSeriesFrom",
-                "matcher": {
-                  "id": "byNames",
-                  "options": {
-                    "mode": "exclude",
-                    "names": [
-                      "writeStateMachine",
-                      "checkingBeforeWrite",
-                      "getStateMachineLock",
-                      "offerRequestToQueue",
-                      "constructBatch",
-                      "consensusWrite"
-                    ],
-                    "prefix": "All except:",
-                    "readOnly": true
-                  }
-                },
-                "properties": [
-                  {
-                    "id": "custom.hideFrom",
-                    "value": {
-                      "legend": false,
-                      "tooltip": false,
-                      "viz": true
-                    }
-                  }
-                ]
+                "color": "green",
+                "value": null
               }
             ]
           },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 8,
-            "y": 15
-          },
-          "id": 25,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
+          "unit": "bytes"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 0,
+        "y": 16
+      },
+      "id": 41,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
+        },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
           },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "avg(stage{quantile=\"0.75\", instance=~\"${instance}\"}) by (instance, type)",
-              "interval": "",
-              "legendFormat": "{{type}}",
-              "range": true,
-              "refId": "A"
-            }
-          ],
-          "title": "The Time Consumed Of Different Stages (75%)",
-          "type": "timeseries"
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sys_total_physical_memory_size{instance=\"$instance\", name=\"system\"}-sys_free_physical_memory_size{instance=\"$instance\", name=\"system\"}",
+          "interval": "",
+          "legendFormat": "Used physical memory",
+          "range": true,
+          "refId": "A"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "ms"
+          "editorMode": "code",
+          "expr": "sys_total_physical_memory_size{instance=\"$instance\", name=\"system\"}",
+          "hide": false,
+          "legendFormat": "Total physical memory",
+          "range": true,
+          "refId": "B"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "editorMode": "code",
+          "expr": "sys_committed_vm_size{instance=\"$instance\"}",
+          "hide": false,
+          "legendFormat": "Committed vm size",
+          "range": true,
+          "refId": "C"
+        }
+      ],
+      "title": "System Memory",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
+          },
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "axisSoftMax": 0,
+            "axisSoftMin": 0,
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "overrides": [
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
+            }
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "percentage",
+            "steps": [
               {
-                "__systemRef": "hideSeriesFrom",
-                "matcher": {
-                  "id": "byNames",
-                  "options": {
-                    "mode": "exclude",
-                    "names": [
-                      "checkingBeforeWrite"
-                    ],
-                    "prefix": "All except:",
-                    "readOnly": true
-                  }
-                },
-                "properties": [
-                  {
-                    "id": "custom.hideFrom",
-                    "value": {
-                      "legend": false,
-                      "tooltip": false,
-                      "viz": true
-                    }
-                  }
-                ]
+                "color": "green",
+                "value": null
               }
             ]
           },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 16,
-            "y": 15
+          "unit": "bytes"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 8,
+        "y": 16
+      },
+      "id": 42,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
+        },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
           },
-          "id": 26,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sys_total_swap_space_size{instance=\"$instance\", name=\"system\"} - sys_free_swap_space_size{instance=\"$instance\", name=\"system\"}",
+          "interval": "",
+          "legendFormat": "Used Swap Size",
+          "range": true,
+          "refId": "A"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
           },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "avg(stage{quantile=\"1.0\", instance=~\"${instance}\"}) by (instance, type)",
-              "interval": "",
-              "legendFormat": "{{type}}",
-              "range": true,
-              "refId": "A"
+          "editorMode": "code",
+          "expr": "sys_total_swap_space_size{instance=\"$instance\", name=\"system\"}",
+          "hide": false,
+          "legendFormat": "Total Swap Size",
+          "range": true,
+          "refId": "B"
+        }
+      ],
+      "title": "System Swap Size",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
+          },
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "axisSoftMax": 0,
+            "axisSoftMin": 0,
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
+            },
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "The Time Consumed Of Different Stages (100%)",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "percentage",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "bytes"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 16,
+        "y": 16
+      },
+      "id": 43,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              }
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 0,
-            "y": 23
-          },
-          "id": 27,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "irate(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"searchIndex\"}[1m])",
-              "interval": "",
-              "legendFormat": "{{region}}",
-              "range": true,
-              "refId": "A"
-            }
-          ],
-          "title": "IoTConsensus Search Index Rate",
-          "type": "timeseries"
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "process_max_mem{instance=~\"${instance}\"}",
+          "interval": "",
+          "legendFormat": "Max Memory",
+          "range": true,
+          "refId": "A"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "",
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              }
-            },
-            "overrides": []
+          "editorMode": "code",
+          "expr": "process_total_mem{instance=~\"${instance}\"}",
+          "hide": false,
+          "legendFormat": "Total Memory",
+          "range": true,
+          "refId": "B"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
           },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 8,
-            "y": 23
+          "editorMode": "code",
+          "expr": "process_total_mem{instance=~\"${instance}\"} - process_free_mem{instance=~\"${instance}\"}",
+          "hide": false,
+          "legendFormat": "Used Memory",
+          "range": true,
+          "refId": "C"
+        }
+      ],
+      "title": "Process Memory",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 28,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "irate(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"safeIndex\"}[1m])",
-              "interval": "",
-              "legendFormat": "{{region}}",
-              "range": true,
-              "refId": "A"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "IoTConsensus Safe Index Rate",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "bytes"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 0,
+        "y": 24
+      },
+      "id": 44,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "none"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 16,
-            "y": 23
-          },
-          "id": 29,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sum(iot_consensus{instance=~\"$instance\", type=~\"cachedRequestInMemoryQueue\"}) by (region, name)",
-              "interval": "",
-              "legendFormat": "{{region}} {{name}}",
-              "range": true,
-              "refId": "A"
-            }
-          ],
-          "title": "IoTConsensus LogDispatcher Request Size",
-          "type": "timeseries"
+          "exemplar": true,
+          "expr": "file_size{instance=~\"$instance\"}",
+          "interval": "",
+          "legendFormat": "{{name}}",
+          "refId": "A"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "Total Sync Gap of region",
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "none"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 0,
-            "y": 31
+          "exemplar": true,
+          "expr": "sum(file_size{instance=~\"$instance\"})",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "total size of file",
+          "refId": "B"
+        }
+      ],
+      "title": "The Size Of File",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 30,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
           },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sum(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"searchIndex\"}) by (region) - sum(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"safeIndex\"}) by (region)",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "{{region}}",
-              "range": true,
-              "refId": "A"
-            }
-          ],
-          "title": "Sync Lag",
-          "transformations": [],
-          "type": "timeseries"
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          }
+        },
+        "overrides": [
+          {
+            "__systemRef": "hideSeriesFrom",
+            "matcher": {
+              "id": "byNames",
+              "options": {
+                "mode": "exclude",
+                "names": [
+                  "inner-seq-temp-num"
+                ],
+                "prefix": "All except:",
+                "readOnly": true
+              }
+            },
+            "properties": [
+              {
+                "id": "custom.hideFrom",
+                "value": {
+                  "legend": false,
+                  "tooltip": false,
+                  "viz": true
+                }
+              }
+            ]
+          }
+        ]
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 8,
+        "y": 24
+      },
+      "id": 45,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "Gap between write and fastest LogDispatcherThread in one region",
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "none"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 8,
-            "y": 31
-          },
-          "id": 31,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sum(iot_consensus{instance=~\"$instance\", name=\"ioTConsensusServerImpl\", type=\"searchIndex\"}) by (region) - max(iot_consensus{instance=~\"$instance\", name=~\"logDispatcher.*\", type=\"currentSyncIndex\"}) by (region)",
-              "format": "time_series",
-              "instant": false,
-              "interval": "",
-              "intervalFactor": 1,
-              "legendFormat": "{{region}}",
-              "refId": "A"
-            }
-          ],
-          "title": "Min Peer Sync Lag",
-          "transformations": [],
-          "type": "timeseries"
+          "exemplar": true,
+          "expr": "file_count{instance=~\"$instance\"}",
+          "interval": "",
+          "legendFormat": "{{name}}",
+          "refId": "A"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "description": "Gap between fastest LogDispatcherThread and slowest LogDispatcherThread in one region",
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "none"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 16,
-            "y": 31
+          "exemplar": true,
+          "expr": "sum(file_count{instance=~\"$instance\"})",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "total number of file",
+          "refId": "B"
+        }
+      ],
+      "title": "The Number Of File",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 32,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "axisSoftMin": -5,
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
           },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "max(iot_consensus{instance=~\"$instance\", name=~\"logDispatcher.*\", type=\"currentSyncIndex\"}) by (region) - min(iot_consensus{instance=~\"$instance\", name=~\"logDispatcher.*\", type=\"currentSyncIndex\"}) by (region)",
-              "format": "time_series",
-              "instant": false,
-              "interval": "",
-              "intervalFactor": 1,
-              "legendFormat": "{{region}}",
-              "refId": "A"
-            }
-          ],
-          "title": "Sync Speed Diff Of Peers",
-          "transformations": [],
-          "type": "timeseries"
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "bytes"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 16,
+        "y": 24
+      },
+      "id": 46,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
+        },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
         }
-      ],
+      },
       "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sys_disk_total_space{instance=~\"$instance\", name=\"system\"}-sys_disk_free_space{instance=\"$instance\", name=\"system\"}",
+          "interval": "",
+          "legendFormat": "Used disk space",
+          "range": true,
           "refId": "A"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
+          },
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sys_disk_total_space{instance=~\"$instance\", name=\"system\"}",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "Total disk space",
+          "range": true,
+          "refId": "B"
         }
       ],
-      "title": "IoT Consensus",
-      "type": "row"
+      "title": "The Space of Disk",
+      "type": "timeseries"
     },
     {
-      "collapsed": true,
       "datasource": {
         "type": "prometheus",
         "uid": "${DS_PROMETHEUS}"
       },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
+          },
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
+            },
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
+            }
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          }
+        },
+        "overrides": []
+      },
       "gridPos": {
-        "h": 1,
-        "w": 24,
+        "h": 7,
+        "w": 8,
         "x": 0,
-        "y": 31
+        "y": 32
       },
-      "id": 33,
-      "panels": [
+      "id": 47,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
+        },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "none"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "thresholds"
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "percentage",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "Core"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 0,
-            "y": 8
-          },
-          "id": 34,
-          "options": {
-            "colorMode": "value",
-            "graphMode": "area",
-            "justifyMode": "auto",
-            "orientation": "auto",
-            "reduceOptions": {
-              "calcs": [
-                "lastNotNull"
-              ],
-              "fields": "",
-              "values": false
-            },
-            "textMode": "auto"
-          },
-          "pluginVersion": "8.4.6",
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sys_cpu_cores{instance=\"$instance\",name=\"system\"}",
-              "interval": "",
-              "legendFormat": "__auto",
-              "range": true,
-              "refId": "A"
-            }
-          ],
-          "title": "CPU Core",
-          "type": "stat"
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sum(rate(jvm_gc_pause_seconds_count{instance=~\"$instance\", action=\"end of minor GC\"}[1m]))*60",
+          "interval": "",
+          "legendFormat": "Young GC number",
+          "range": true,
+          "refId": "A"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "axisSoftMax": 0,
-                "axisSoftMin": 0,
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "percentage",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "percent"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 8,
-            "y": 8
+          "exemplar": true,
+          "expr": "sum(rate(jvm_gc_pause_seconds_count{instance=~\"$instance\", action=\"end of major GC\"}[1m]))*60",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "Full GC number",
+          "refId": "B"
+        }
+      ],
+      "title": "The Number of GC Per Minute",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 35,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sys_cpu_load{instance=\"$instance\",name=\"system\"}",
-              "interval": "",
-              "legendFormat": "System CPU Load",
-              "range": true,
-              "refId": "A"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "expr": "process_cpu_load{instance=\"$instance\",name=\"process\"}",
-              "hide": false,
-              "legendFormat": "Process CPU Load",
-              "range": true,
-              "refId": "B"
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "CPU Load",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "s"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 7,
+        "w": 8,
+        "x": 8,
+        "y": 32
+      },
+      "id": 48,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "axisSoftMax": 0,
-                "axisSoftMin": 0,
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "percentage",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "ns"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 16,
-            "y": 8
-          },
-          "id": 40,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "none"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sum(rate(process_cpu_time{instance=\"$instance\",name=\"process\"}[1m]))*60",
-              "interval": "",
-              "legendFormat": "System CPU Load",
-              "range": true,
-              "refId": "A"
-            }
-          ],
-          "title": "CPU Time(per minute)",
-          "type": "timeseries"
+          "exemplar": true,
+          "expr": "sum(rate(jvm_gc_pause_seconds_sum{instance=~\"$instance\", action=\"end of minor GC\"}[1m]))*60",
+          "interval": "",
+          "legendFormat": "The time of young GC",
+          "refId": "A"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "axisSoftMax": 0,
-                "axisSoftMin": 0,
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "percentage",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "bytes"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 0,
-            "y": 16
+          "exemplar": true,
+          "expr": "sum(rate(jvm_gc_pause_seconds_sum{instance=~\"$instance\", action=\"end of major GC\"}[1m]))*60",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "The time of full GC",
+          "refId": "B"
+        }
+      ],
+      "title": "The Time Consumed Of GC Per Minute",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 41,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sys_total_physical_memory_size{instance=\"$instance\", name=\"system\"}-sys_free_physical_memory_size{instance=\"$instance\", name=\"system\"}",
-              "interval": "",
-              "legendFormat": "Used physical memory",
-              "range": true,
-              "refId": "A"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "expr": "sys_total_physical_memory_size{instance=\"$instance\", name=\"system\"}",
-              "hide": false,
-              "legendFormat": "Total physical memory",
-              "range": true,
-              "refId": "B"
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "expr": "sys_committed_vm_size{instance=\"$instance\"}",
-              "hide": false,
-              "legendFormat": "Committed vm size",
-              "range": true,
-              "refId": "C"
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "System Memory",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          }
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 7,
+        "w": 8,
+        "x": 16,
+        "y": 32
+      },
+      "id": 49,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "none"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "axisSoftMax": 0,
-                "axisSoftMin": 0,
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "percentage",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "bytes"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 8,
-            "y": 16
-          },
-          "id": 42,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sys_total_swap_space_size{instance=\"$instance\", name=\"system\"} - sys_free_swap_space_size{instance=\"$instance\", name=\"system\"}",
-              "interval": "",
-              "legendFormat": "Used Swap Size",
-              "range": true,
-              "refId": "A"
-            },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "expr": "sys_total_swap_space_size{instance=\"$instance\", name=\"system\"}",
-              "hide": false,
-              "legendFormat": "Total Swap Size",
-              "range": true,
-              "refId": "B"
-            }
-          ],
-          "title": "System Swap Size",
-          "type": "timeseries"
+          "exemplar": true,
+          "expr": "jvm_threads_live_threads{instance=~\"$instance\"}",
+          "interval": "",
+          "legendFormat": "The total number of jvm thread",
+          "refId": "A"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "axisSoftMax": 0,
-                "axisSoftMin": 0,
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "percentage",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "bytes"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 16,
-            "y": 16
+          "exemplar": true,
+          "expr": "jvm_threads_states_threads{instance=~\"$instance\"}",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "{{state}}",
+          "refId": "B"
+        }
+      ],
+      "title": "The Number Of Java Thread",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 43,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "process_max_mem{instance=~\"${instance}\"}",
-              "interval": "",
-              "legendFormat": "Max Memory",
-              "range": true,
-              "refId": "A"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "expr": "process_total_mem{instance=~\"${instance}\"}",
-              "hide": false,
-              "legendFormat": "Total Memory",
-              "range": true,
-              "refId": "B"
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "expr": "process_total_mem{instance=~\"${instance}\"} - process_free_mem{instance=~\"${instance}\"}",
-              "hide": false,
-              "legendFormat": "Used Memory",
-              "range": true,
-              "refId": "C"
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "Process Memory",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "bytes"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 0,
+        "y": 39
+      },
+      "id": 50,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "none"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "bytes"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 0,
-            "y": 24
+          "exemplar": true,
+          "expr": "sum(jvm_memory_max_bytes{instance=~\"$instance\",area=\"heap\"})",
+          "interval": "",
+          "legendFormat": "Maximum heap memory",
+          "refId": "A"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
           },
-          "id": 44,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
+          "exemplar": true,
+          "expr": "sum(jvm_memory_used_bytes{instance=~\"$instance\",area=\"heap\"})",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "Used heap memory",
+          "refId": "B"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
           },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "file_size{instance=~\"$instance\"}",
-              "interval": "",
-              "legendFormat": "{{name}}",
-              "refId": "A"
-            },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "sum(file_size{instance=~\"$instance\"})",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "total size of file",
-              "refId": "B"
-            }
-          ],
-          "title": "The Size Of File",
-          "type": "timeseries"
+          "exemplar": true,
+          "expr": "jvm_memory_used_bytes{instance=~\"$instance\",area=\"heap\",id=\"PS Old Gen\"}",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "Old area",
+          "refId": "C"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              }
-            },
-            "overrides": [
-              {
-                "__systemRef": "hideSeriesFrom",
-                "matcher": {
-                  "id": "byNames",
-                  "options": {
-                    "mode": "exclude",
-                    "names": [
-                      "inner-seq-temp-num"
-                    ],
-                    "prefix": "All except:",
-                    "readOnly": true
-                  }
-                },
-                "properties": [
-                  {
-                    "id": "custom.hideFrom",
-                    "value": {
-                      "legend": false,
-                      "tooltip": false,
-                      "viz": true
-                    }
-                  }
-                ]
-              }
-            ]
+          "exemplar": true,
+          "expr": "jvm_memory_used_bytes{instance=~\"$instance\",area=\"heap\",id=\"PS Eden Space\"}",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "Eden area",
+          "refId": "D"
+        },
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
           },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 8,
-            "y": 24
+          "exemplar": true,
+          "expr": "jvm_memory_used_bytes{instance=~\"$instance\",area=\"heap\",id=\"PS Survivor Space\"}",
+          "hide": false,
+          "interval": "",
+          "legendFormat": "Survivor area",
+          "refId": "E"
+        }
+      ],
+      "title": "Heap Memory",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 45,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "file_count{instance=~\"$instance\"}",
-              "interval": "",
-              "legendFormat": "{{name}}",
-              "refId": "A"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "sum(file_count{instance=~\"$instance\"})",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "total number of file",
-              "refId": "B"
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "The Number Of File",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "bytes"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 8,
+        "y": 39
+      },
+      "id": 51,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "axisSoftMin": -5,
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "bytes"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 16,
-            "y": 24
+          "exemplar": true,
+          "expr": "sum(jvm_buffer_memory_used_bytes{instance=~\"$instance\"})",
+          "interval": "",
+          "legendFormat": "off heap memory",
+          "refId": "A"
+        }
+      ],
+      "title": "Off Heap Memory",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 46,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sys_disk_total_space{instance=~\"$instance\", name=\"system\"}-sys_disk_free_space{instance=\"$instance\", name=\"system\"}",
-              "interval": "",
-              "legendFormat": "Used disk space",
-              "range": true,
-              "refId": "A"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sys_disk_total_space{instance=~\"$instance\", name=\"system\"}",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "Total disk space",
-              "range": true,
-              "refId": "B"
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "The Space of Disk",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "none"
         },
-        {
-          "datasource": {
-            "type": "prometheus",
-            "uid": "${DS_PROMETHEUS}"
+        "overrides": [
+          {
+            "matcher": {
+              "id": "byName",
+              "options": "warn"
+            },
+            "properties": [
+              {
+                "id": "color",
+                "value": {
+                  "fixedColor": "orange",
+                  "mode": "fixed"
+                }
+              }
+            ]
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
+          {
+            "matcher": {
+              "id": "byName",
+              "options": "trace"
+            },
+            "properties": [
+              {
+                "id": "color",
+                "value": {
+                  "fixedColor": "purple",
+                  "mode": "fixed"
                 }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
               }
+            ]
+          },
+          {
+            "matcher": {
+              "id": "byName",
+              "options": "error"
             },
-            "overrides": []
+            "properties": [
+              {
+                "id": "color",
+                "value": {
+                  "fixedColor": "red",
+                  "mode": "fixed"
+                }
+              }
+            ]
+          }
+        ]
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 16,
+        "y": 39
+      },
+      "id": 52,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
+        },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
+        {
+          "datasource": {
+            "type": "prometheus",
+            "uid": "${DS_PROMETHEUS}"
           },
-          "gridPos": {
-            "h": 7,
-            "w": 8,
-            "x": 0,
-            "y": 32
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sum(rate(logback_events_total{instance=~\"${instance}\"}[1m])) by (level) * 60",
+          "interval": "",
+          "legendFormat": "{{level}}",
+          "range": true,
+          "refId": "A"
+        }
+      ],
+      "title": "Log Number Per Minute",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "description": "",
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 47,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "none"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "editorMode": "code",
-              "exemplar": true,
-              "expr": "sum(rate(jvm_gc_pause_seconds_count{instance=~\"$instance\", action=\"end of minor GC\"}[1m]))*60",
-              "interval": "",
-              "legendFormat": "Young GC number",
-              "range": true,
-              "refId": "A"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "sum(rate(jvm_gc_pause_seconds_count{instance=~\"$instance\", action=\"end of major GC\"}[1m]))*60",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "Full GC number",
-              "refId": "B"
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "The Number of GC Per Minute",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "ms"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 0,
+        "y": 47
+      },
+      "id": 53,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "s"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 7,
-            "w": 8,
-            "x": 8,
-            "y": 32
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "sum(rate(jvm_compilation_time_ms{instance=~\"${instance}\"}[1m]))*60",
+          "interval": "",
+          "legendFormat": "compiler",
+          "range": true,
+          "refId": "A"
+        }
+      ],
+      "title": "The Time Consumed Of Compilation Per Minute",
+      "type": "timeseries"
+    },
+    {
+      "datasource": {
+        "type": "prometheus",
+        "uid": "${DS_PROMETHEUS}"
+      },
+      "description": "",
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 48,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "sum(rate(jvm_gc_pause_seconds_sum{instance=~\"$instance\", action=\"end of minor GC\"}[1m]))*60",
-              "interval": "",
-              "legendFormat": "The time of young GC",
-              "refId": "A"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "sum(rate(jvm_gc_pause_seconds_sum{instance=~\"$instance\", action=\"end of major GC\"}[1m]))*60",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "The time of full GC",
-              "refId": "B"
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "The Time Consumed Of GC Per Minute",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "none"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 8,
+        "y": 47
+      },
+      "id": 54,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom",
+          "showLegend": true
         },
+        "tooltip": {
+          "mode": "multi",
+          "sort": "desc"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              }
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 7,
-            "w": 8,
-            "x": 16,
-            "y": 32
-          },
-          "id": 49,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "none"
-            }
-          },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "jvm_threads_live_threads{instance=~\"$instance\"}",
-              "interval": "",
-              "legendFormat": "The total number of jvm thread",
-              "refId": "A"
-            },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "jvm_threads_states_threads{instance=~\"$instance\"}",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "{{state}}",
-              "refId": "B"
-            }
-          ],
-          "title": "The Number Of Java Thread",
-          "type": "timeseries"
+          "editorMode": "code",
+          "exemplar": true,
+          "expr": "jvm_classes_unloaded_classes{instance=~\"$instance\"}",
+          "interval": "",
+          "legendFormat": "Unloaded Number",
+          "range": true,
+          "refId": "A"
         },
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "bytes"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 0,
-            "y": 39
-          },
-          "id": 50,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
-            },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "none"
-            }
+          "editorMode": "code",
+          "expr": "jvm_classes_loaded_classes{instance=~\"$instance\"}",
+          "hide": false,
+          "legendFormat": "Loaded Number",
+          "range": true,
+          "refId": "B"
+        }
+      ],
+      "title": "The Number Of Class",
+      "type": "timeseries"
+    },
+    {
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "sum(jvm_memory_max_bytes{instance=~\"$instance\",area=\"heap\"})",
-              "interval": "",
-              "legendFormat": "Maximum heap memory",
-              "refId": "A"
-            },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "sum(jvm_memory_used_bytes{instance=~\"$instance\",area=\"heap\"})",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "Used heap memory",
-              "refId": "B"
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "jvm_memory_used_bytes{instance=~\"$instance\",area=\"heap\",id=\"PS Old Gen\"}",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "Old area",
-              "refId": "C"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "jvm_memory_used_bytes{instance=~\"$instance\",area=\"heap\",id=\"PS Eden Space\"}",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "Eden area",
-              "refId": "D"
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
             },
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "jvm_memory_used_bytes{instance=~\"$instance\",area=\"heap\",id=\"PS Survivor Space\"}",
-              "hide": false,
-              "interval": "",
-              "legendFormat": "Survivor area",
-              "refId": "E"
+            "thresholdsStyle": {
+              "mode": "off"
             }
-          ],
-          "title": "Heap Memory",
-          "type": "timeseries"
+          },
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "op/s"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 16,
+        "y": 47
+      },
+      "id": 173,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom"
         },
+        "tooltip": {
+          "mode": "single",
+          "sort": "none"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
-                "lineInterpolation": "linear",
-                "lineWidth": 1,
-                "pointSize": 5,
-                "scaleDistribution": {
-                  "type": "linear"
-                },
-                "showPoints": "auto",
-                "spanNulls": false,
-                "stacking": {
-                  "group": "A",
-                  "mode": "none"
-                },
-                "thresholdsStyle": {
-                  "mode": "off"
-                }
-              },
-              "mappings": [],
-              "thresholds": {
-                "mode": "absolute",
-                "steps": [
-                  {
-                    "color": "green"
-                  }
-                ]
-              },
-              "unit": "bytes"
-            },
-            "overrides": []
-          },
-          "gridPos": {
-            "h": 8,
-            "w": 8,
-            "x": 8,
-            "y": 39
+          "exemplar": true,
+          "expr": "disk_io_ops{instance=~\"$instance\"}",
+          "interval": "",
+          "legendFormat": "{{name}}-{{type}}",
+          "refId": "A"
+        }
+      ],
+      "title": "Disk IOPS",
+      "type": "timeseries"
+    },
+    {
+      "fieldConfig": {
+        "defaults": {
+          "color": {
+            "mode": "palette-classic"
           },
-          "id": 51,
-          "options": {
-            "legend": {
-              "calcs": [],
-              "displayMode": "list",
-              "placement": "bottom",
-              "showLegend": true
+          "custom": {
+            "axisLabel": "",
+            "axisPlacement": "auto",
+            "barAlignment": 0,
+            "drawStyle": "line",
+            "fillOpacity": 0,
+            "gradientMode": "none",
+            "hideFrom": {
+              "legend": false,
+              "tooltip": false,
+              "viz": false
             },
-            "tooltip": {
-              "mode": "multi",
-              "sort": "desc"
+            "lineInterpolation": "linear",
+            "lineWidth": 1,
+            "pointSize": 5,
+            "scaleDistribution": {
+              "type": "linear"
+            },
+            "showPoints": "auto",
+            "spanNulls": false,
+            "stacking": {
+              "group": "A",
+              "mode": "none"
+            },
+            "thresholdsStyle": {
+              "mode": "off"
             }
           },
-          "targets": [
-            {
-              "datasource": {
-                "type": "prometheus",
-                "uid": "${DS_PROMETHEUS}"
-              },
-              "exemplar": true,
-              "expr": "sum(jvm_buffer_memory_used_bytes{instance=~\"$instance\"})",
-              "interval": "",
-              "legendFormat": "off heap memory",
-              "refId": "A"
-            }
-          ],
-          "title": "Off Heap Memory",
-          "type": "timeseries"
+          "mappings": [],
+          "thresholds": {
+            "mode": "absolute",
+            "steps": [
+              {
+                "color": "green",
+                "value": null
+              }
+            ]
+          },
+          "unit": "KBs"
+        },
+        "overrides": []
+      },
+      "gridPos": {
+        "h": 8,
+        "w": 8,
+        "x": 0,
+        "y": 55
+      },
+      "id": 175,
+      "options": {
+        "legend": {
+          "calcs": [],
+          "displayMode": "list",
+          "placement": "bottom"
         },
+        "tooltip": {
+          "mode": "single",
+          "sort": "none"
+        }
+      },
+      "targets": [
         {
           "datasource": {
             "type": "prometheus",
             "uid": "${DS_PROMETHEUS}"
           },
-          "fieldConfig": {
-            "defaults": {
-              "color": {
-                "mode": "palette-classic"
-              },
-              "custom": {
-                "axisLabel": "",
-                "axisPlacement": "auto",
-                "barAlignment": 0,
-                "drawStyle": "line",
-                "fillOpacity": 0,
-                "gradientMode": "none",
-                "hideFrom": {
-                  "legend": false,
-                  "tooltip": false,
-                  "viz": false
-                },
... 703 lines suppressed ...


[iotdb] 02/04: Merge branch 'IOTDB-5517' of https://github.com/apache/iotdb into IOTDB-5517

Posted by ma...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

marklau99 pushed a commit to branch IOTDB-5517
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit 8193bef6b15538b557b98423d7d3ed7312975745
Merge: 715c1a0192 a2ffa7b9f9
Author: liuxuxin <li...@outlook.com>
AuthorDate: Mon Feb 13 15:04:27 2023 +0800

    Merge branch 'IOTDB-5517' of https://github.com/apache/iotdb into IOTDB-5517

 .../iotdb/db/service/metrics/io/AbstractDiskMetricsManager.java      | 5 +----
 1 file changed, 1 insertion(+), 4 deletions(-)