You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by GitBox <gi...@apache.org> on 2020/10/22 14:46:48 UTC

[GitHub] [flink] RocMarshal opened a new pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

RocMarshal opened a new pull request #13750:
URL: https://github.com/apache/flink/pull/13750


   <!--
   *Thank you very much for contributing to Apache Flink - we are happy that you want to help us improve Flink. To help the community review your contribution in the best possible way, please go through the checklist below, which will get the contribution into a shape in which it can be best reviewed.*
   
   *Please understand that we do not do this to make contributions to Flink a hassle. In order to uphold a high standard of quality for code contributions, while at the same time managing a large number of contributions, we need contributors to prepare the contributions well, and give reviewers enough contextual information for the review. Please also understand that contributions that do not follow this guide will take longer to review and thus typically be picked up with lower priority by the community.*
   
   ## Contribution Checklist
   
     - Make sure that the pull request corresponds to a [JIRA issue](https://issues.apache.org/jira/projects/FLINK/issues). Exceptions are made for typos in JavaDoc or documentation files, which need no JIRA issue.
     
     - Name the pull request in the form "[FLINK-XXXX] [component] Title of the pull request", where *FLINK-XXXX* should be replaced by the actual issue number. Skip *component* if you are unsure about which is the best component.
     Typo fixes that have no associated JIRA issue should be named following this pattern: `[hotfix] [docs] Fix typo in event time introduction` or `[hotfix] [javadocs] Expand JavaDoc for PuncuatedWatermarkGenerator`.
   
     - Fill out the template below to describe the changes contributed by the pull request. That will give reviewers the context they need to do the review.
     
     - Make sure that the change passes the automated tests, i.e., `mvn clean verify` passes. You can set up Azure Pipelines CI to do that following [this guide](https://cwiki.apache.org/confluence/display/FLINK/Azure+Pipelines#AzurePipelines-Tutorial:SettingupAzurePipelinesforaforkoftheFlinkrepository).
   
     - Each pull request should address only one issue, not mix up code from multiple issues.
     
     - Each commit in the pull request has a meaningful commit message (including the JIRA id)
   
     - Once all items of the checklist are addressed, remove the above text and this checklist, leaving only the filled out template below.
   
   
   **(The sections below can be removed for hotfixes of typos)**
   -->
   
   ## What is the purpose of the change
   
   *Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese*
   
   
   ## Brief change log
   
   *Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese*
     - *page file location: docs/monitoring/checkpoint_monitoring.zh.md*
     - *page url in documentation-web is : https://ci.apache.org/projects/flink/flink-docs-release-1.11/zh/monitoring/checkpoint_monitoring.html*
   
   
   ## Verifying this change
   
   *A pure translation work .*
   
   
   ## Does this pull request potentially affect one of the following parts:
   
     - Dependencies (does it add or upgrade a dependency): (yes / **no**)
     - The public API, i.e., is any changed class annotated with `@Public(Evolving)`: (yes / **no**)
     - The serializers: (yes / **no** / don't know)
     - The runtime per-record code paths (performance sensitive): (yes / **no** / don't know)
     - Anything that affects deployment or recovery: JobManager (and its components), Checkpointing, Kubernetes/Yarn/Mesos, ZooKeeper: (yes / **no** / don't know)
     - The S3 file system connector: (yes / **no** / don't know)
   
   ## Documentation
   
     - Does this pull request introduce a new feature? (yes / **no**)
     - If yes, how is the feature documented? (**not applicable** / docs / JavaDocs / not documented)
   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] RocMarshal commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
RocMarshal commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-719256518


   @xccui 


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot edited a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714567487


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119",
       "triggerID" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 1ec411ddcfd58a0ab5f22c7ebe5433439b217d27 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run travis` re-run the last Travis build
    - `@flinkbot run azure` re-run the last Azure build
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] klion26 commented on a change in pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
klion26 commented on a change in pull request #13750:
URL: https://github.com/apache/flink/pull/13750#discussion_r513181496



##########
File path: docs/monitoring/checkpoint_monitoring.zh.md
##########
@@ -25,105 +25,125 @@ under the License.
 * ToC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-Flink's web interface provides a tab to monitor the checkpoints of jobs. These stats are also available after the job has terminated. There are four different tabs to display information about your checkpoints: Overview, History, Summary, and Configuration. The following sections will cover all of these in turn.
+## 概览(Overview)
 
-## Monitoring
+Flink 的 Web 界面提供了`选项卡/标签(tab)`来监视作业的 Checkpoint 信息。作业终止后,这些统计信息仍然可用。有四个不同的选项卡可显示有关 Checkpoint 的信息:概览(Overview),历史记录(History),摘要信息(Summary)和配置信息(Configuration)。以下各节将依次介绍这些内容。
 
-### Overview Tab
+<a name="monitoring"></a>
 
-The overview tabs lists the following statistics. Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+## 监控(Monitoring)
+
+<a name="overview-tab"></a>
+
+### 概览(Overview)选项卡
+
+概览选项卡列出了以下统计信息。请注意,这些统计信息在 JobManager 丢失时无法保存,如果 JobManager 发生故障转移,这些统计信息将重置。
 
 - **Checkpoint Counts**
-	- Triggered: The total number of checkpoints that have been triggered since the job started.
-	- In Progress: The current number of checkpoints that are in progress.
-	- Completed: The total number of successfully completed checkpoints since the job started.
-	- Failed: The total number of failed checkpoints since the job started.
-	- Restored: The number of restore operations since the job started. This also tells you how many times the job has restarted since submission. Note that the initial submission with a savepoint also counts as a restore and the count is reset if the JobManager was lost during operation.
-- **Latest Completed Checkpoint**: The latest successfully completed checkpoints. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Failed Checkpoint**: The latest failed checkpoint. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Savepoint**: The latest triggered savepoint with its external path. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Restore**: There are two types of restore operations.
-	- Restore from Checkpoint: We restored from a regular periodic checkpoint.
-	- Restore from Savepoint: We restored from a savepoint.
-
-### History Tab
-
-The checkpoint history keeps statistics about recently triggered checkpoints, including those that are currently in progress.
+	- Triggered:自作业开始以来触发的 Checkpoint 总数。
+	- In Progress:当前正在进行的 Checkpoint 数量。
+	- Completed:自作业开始以来成功完成的 Checkpoint 总数。
+	- Failed:自作业开始以来失败的 Checkpoint 总数。
+	- Restored:自作业开始以来进行的 Restored 操作的次数。这还表示自 Job 提交以来已重新启动多少次。请注意,带有 Savepoint 的初始提交也算作一次 Restore,如果 JobManager 在此操作过程中丢失,则该计数将重置。
+- **Latest Completed Checkpoint**:最新(最近)成功完成的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Failed Checkpoint**:最新失败的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Savepoint**:最新触发的 Savepoint 及其外部路径。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Restore**:有两种类型的 Restore 操作。
+	- Restore from Checkpoint:从定期的 Checkpoint 还原。

Review comment:
       这里如果翻译成 `从 Checkpoint 还原` 或者 `从 Checkpoint 恢复` 是否可以,因为 Checkpoint 默认都是 定期的

##########
File path: docs/monitoring/checkpoint_monitoring.zh.md
##########
@@ -25,105 +25,125 @@ under the License.
 * ToC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-Flink's web interface provides a tab to monitor the checkpoints of jobs. These stats are also available after the job has terminated. There are four different tabs to display information about your checkpoints: Overview, History, Summary, and Configuration. The following sections will cover all of these in turn.
+## 概览(Overview)
 
-## Monitoring
+Flink 的 Web 界面提供了`选项卡/标签(tab)`来监视作业的 Checkpoint 信息。作业终止后,这些统计信息仍然可用。有四个不同的选项卡可显示有关 Checkpoint 的信息:概览(Overview),历史记录(History),摘要信息(Summary)和配置信息(Configuration)。以下各节将依次介绍这些内容。
 
-### Overview Tab
+<a name="monitoring"></a>
 
-The overview tabs lists the following statistics. Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+## 监控(Monitoring)
+
+<a name="overview-tab"></a>
+
+### 概览(Overview)选项卡
+
+概览选项卡列出了以下统计信息。请注意,这些统计信息在 JobManager 丢失时无法保存,如果 JobManager 发生故障转移,这些统计信息将重置。
 
 - **Checkpoint Counts**
-	- Triggered: The total number of checkpoints that have been triggered since the job started.
-	- In Progress: The current number of checkpoints that are in progress.
-	- Completed: The total number of successfully completed checkpoints since the job started.
-	- Failed: The total number of failed checkpoints since the job started.
-	- Restored: The number of restore operations since the job started. This also tells you how many times the job has restarted since submission. Note that the initial submission with a savepoint also counts as a restore and the count is reset if the JobManager was lost during operation.
-- **Latest Completed Checkpoint**: The latest successfully completed checkpoints. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Failed Checkpoint**: The latest failed checkpoint. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Savepoint**: The latest triggered savepoint with its external path. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Restore**: There are two types of restore operations.
-	- Restore from Checkpoint: We restored from a regular periodic checkpoint.
-	- Restore from Savepoint: We restored from a savepoint.
-
-### History Tab
-
-The checkpoint history keeps statistics about recently triggered checkpoints, including those that are currently in progress.
+	- Triggered:自作业开始以来触发的 Checkpoint 总数。
+	- In Progress:当前正在进行的 Checkpoint 数量。
+	- Completed:自作业开始以来成功完成的 Checkpoint 总数。
+	- Failed:自作业开始以来失败的 Checkpoint 总数。
+	- Restored:自作业开始以来进行的 Restored 操作的次数。这还表示自 Job 提交以来已重新启动多少次。请注意,带有 Savepoint 的初始提交也算作一次 Restore,如果 JobManager 在此操作过程中丢失,则该计数将重置。
+- **Latest Completed Checkpoint**:最新(最近)成功完成的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Failed Checkpoint**:最新失败的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Savepoint**:最新触发的 Savepoint 及其外部路径。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Restore**:有两种类型的 Restore 操作。
+	- Restore from Checkpoint:从定期的 Checkpoint 还原。
+	- Restore from Savepoint:从 Savepoint 还原。
+
+<a name="history-tab"></a>
+
+### 历史记录(History)选项卡
+
+Checkpoint 历史记录保存有关最近触发的 Checkpoint 的统计信息,包括当前正在进行的 Checkpoint。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **ID**: The ID of the triggered checkpoint. The IDs are incremented for each checkpoint, starting at 1.
-- **Status**: The current status of the checkpoint, which is either *In Progress* (<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>), *Completed* (<i aria-hidden="true" class="fa fa-check"/>), or *Failed* (<i aria-hidden="true" class="fa fa-remove"/>). If the triggered checkpoint is a savepoint, you will see a <i aria-hidden="true" class="fa fa-floppy-o"/> symbol.
-- **Trigger Time**: The time when the checkpoint was triggered at the JobManager.
-- **Latest Acknowledgement**: The time when the latest acknowledgement for any subtask was received at the JobManager (or n/a if no acknowledgement received yet).
-- **End to End Duration**: The duration from the trigger timestamp until the latest acknowledgement (or n/a if no acknowledgement received yet). This end to end duration for a complete checkpoint is determined by the last subtask that acknowledges the checkpoint. This time is usually larger than single subtasks need to actually checkpoint the state.
-- **Checkpointed Data Size**: The checkpointed data size over all acknowledged subtasks. If incremental checkpointing is enabled this value is the checkpointed data size delta.
-- **Processed in-flight data**: The approximate number of bytes processed during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks.
-- **Persisted in-flight data**: The number of bytes persisted during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks. This is > 0 only if the unaligned checkpoints are enabled.
+- **ID**:已触发 Checkpoint 的 ID。每个 Checkpoint 的 ID 都会递增,从 1 开始。
+- **Status**:Checkpoint 的当前状态,可以是*正在进行(In Progress)*(<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>)、*已完成(Completed)*(<i aria-hidden="true" class="fa fa-check"/>)或*失败(Failed)*(<i aria-hidden="true" class="fa fa-remove"/>)。如果触发的检查点是一个保存点,你将看到一个 <i aria-hidden="true" class="fa fa-floppy-o"/> 符号。
+- **Trigger Time**:在 JobManager 上发起 Checkpoint 的时间。
+- **Latest Acknowledgement**:JobManager 接收到任何 subtask 的最新确认的时间(如果尚未收到确认,则不适用)。
+- **End to End Duration**:从触发时间戳到最后一次确认的持续时间(如果还没有收到确认,则不适用)。完整 Checkpoint 的端到端持续时间由确认 Checkpoint 的最后一个 Subtask 确定。这个时间通常大于单个 Subtask 实际 Checkpoint State 所需的时间。
+- **Checkpointed Data Size**:所有已确认 Subtasks 的 checkpoint 的数据大小。如果启用了增量 Checkpoint,则此值为 Checkpoint 数据的增量大小。
+- **Processed in-flight data**:在对齐(Checkpoint alignment)期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 处理的大约字节数。
+- **Persisted in-flight data**:在对齐期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 持久化的字节数。仅当启用未对齐的 Checkpoint 时,此值大于 0。
 
-For subtasks there are a couple of more detailed stats available.
+对于 subtasks,有两个更详细的统计信息可用。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history-subtasks.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history-subtasks.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **Sync Duration**: The duration of the synchronous part of the checkpoint. This includes snapshotting state of the operators and blocks all other activity on the subtask (processing records, firing timers, etc).
-- **Async Duration**: The duration of the asynchronous part of the checkpoint. This includes time it took to write the checkpoint on to the selected filesystem. For unaligned checkpoints this also includes also the time the subtask had to wait for last of the checkpoint barriers to arrive (alignment duration) and the time it took to persist the in-flight data.
-- **Alignment Duration**: The time between processing the first and the last checkpoint barrier. For aligned checkpoints, during the alignment, the channels that have already received checkpoint barrier are blocked from processing more data.
-- **Start Delay**: The time it took for the first checkpoint barrier to reach this subtasks since the checkpoint barrier has been created.
+- **Sync Duration**:Checkpoint 同步部分的持续时间。这包括 operators 的快照状态,并阻塞 subtask 上的所有其他活动(处理记录、触发计时器等)。
+- **Async Duration**:Checkpoint 的异步部分的持续时间。这包括将 Checkpoint 写入设置的文件系统所需的时间。对于未对齐的 Checkpoints,这还包括 subtask 必须等待最后一个 checkpoint barrier 到达的时间(对齐持续时间)以及持久化数据所需的时间。
+- **Alignment Duration**:处理第一个和最后一个 checkpoint barrier 之间的时间。对于对齐机制的 checkpoints,在对齐过程中,已经接收到 checkpoint barrier 的 channels 将阻塞并停止处理后续的数据。
+- **Start Delay**:自创建 checkpoint barrier 开始,第一个 checkpoint barrier 到达此 subtask 所用的时间。
 
-#### History Size Configuration
+<a name="history-size-configuration"></a>
 
-You can configure the number of recent checkpoints that are remembered for the history via the following configuration key. The default is `10`.
+#### 历史记录数量配置
+
+你可以通过以下配置键配置历史记录所保存的最近检查点的数量。默认值为 `10`。
 
 {% highlight yaml %}
-# Number of recent checkpoints that are remembered
+# 保存最近 Checkpoints 的个数
 web.checkpoints.history: 15
 {% endhighlight %}
 
-### Summary Tab
+<a name="summary-tab"></a>
+
+### 摘要信息(Summary)选项卡
 
-The summary computes a simple min/average/maximum statistics over all completed checkpoints for the End to End Duration, Checkpointed Data Size, and Bytes Buffered During Alignment (see [History](#history) for details about what these mean).
+摘要计算了所有已完成 checkpoints 的端到端持续时间、Checkpointed 数据大小和对齐期间缓冲的字节数的简单 min/average/maximum 统计信息(有关这些内容的详细信息,请参见 [History](#History tab))。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-summary.png" width="700px" alt="Checkpoint Monitoring: Summary">
+  <img src="{% link /fig/checkpoint_monitoring-summary.png %}" width="700px" alt="Checkpoint Monitoring: Summary">
 </center>
 
-Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+请注意,这些统计信息不会在 JobManager 丢失后无法保存,如果 JobManager 故障转移,这些统计信息将被重置。

Review comment:
       这里的意思应该是 jm 重启后,这些信息会丢失,和上文说的一样,会重新计数

##########
File path: docs/monitoring/checkpoint_monitoring.zh.md
##########
@@ -25,105 +25,125 @@ under the License.
 * ToC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-Flink's web interface provides a tab to monitor the checkpoints of jobs. These stats are also available after the job has terminated. There are four different tabs to display information about your checkpoints: Overview, History, Summary, and Configuration. The following sections will cover all of these in turn.
+## 概览(Overview)
 
-## Monitoring
+Flink 的 Web 界面提供了`选项卡/标签(tab)`来监视作业的 Checkpoint 信息。作业终止后,这些统计信息仍然可用。有四个不同的选项卡可显示有关 Checkpoint 的信息:概览(Overview),历史记录(History),摘要信息(Summary)和配置信息(Configuration)。以下各节将依次介绍这些内容。
 
-### Overview Tab
+<a name="monitoring"></a>
 
-The overview tabs lists the following statistics. Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+## 监控(Monitoring)
+
+<a name="overview-tab"></a>
+
+### 概览(Overview)选项卡
+
+概览选项卡列出了以下统计信息。请注意,这些统计信息在 JobManager 丢失时无法保存,如果 JobManager 发生故障转移,这些统计信息将重置。
 
 - **Checkpoint Counts**
-	- Triggered: The total number of checkpoints that have been triggered since the job started.
-	- In Progress: The current number of checkpoints that are in progress.
-	- Completed: The total number of successfully completed checkpoints since the job started.
-	- Failed: The total number of failed checkpoints since the job started.
-	- Restored: The number of restore operations since the job started. This also tells you how many times the job has restarted since submission. Note that the initial submission with a savepoint also counts as a restore and the count is reset if the JobManager was lost during operation.
-- **Latest Completed Checkpoint**: The latest successfully completed checkpoints. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Failed Checkpoint**: The latest failed checkpoint. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Savepoint**: The latest triggered savepoint with its external path. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Restore**: There are two types of restore operations.
-	- Restore from Checkpoint: We restored from a regular periodic checkpoint.
-	- Restore from Savepoint: We restored from a savepoint.
-
-### History Tab
-
-The checkpoint history keeps statistics about recently triggered checkpoints, including those that are currently in progress.
+	- Triggered:自作业开始以来触发的 Checkpoint 总数。
+	- In Progress:当前正在进行的 Checkpoint 数量。
+	- Completed:自作业开始以来成功完成的 Checkpoint 总数。
+	- Failed:自作业开始以来失败的 Checkpoint 总数。
+	- Restored:自作业开始以来进行的 Restored 操作的次数。这还表示自 Job 提交以来已重新启动多少次。请注意,带有 Savepoint 的初始提交也算作一次 Restore,如果 JobManager 在此操作过程中丢失,则该计数将重置。
+- **Latest Completed Checkpoint**:最新(最近)成功完成的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Failed Checkpoint**:最新失败的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Savepoint**:最新触发的 Savepoint 及其外部路径。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Restore**:有两种类型的 Restore 操作。
+	- Restore from Checkpoint:从定期的 Checkpoint 还原。
+	- Restore from Savepoint:从 Savepoint 还原。
+
+<a name="history-tab"></a>
+
+### 历史记录(History)选项卡
+
+Checkpoint 历史记录保存有关最近触发的 Checkpoint 的统计信息,包括当前正在进行的 Checkpoint。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **ID**: The ID of the triggered checkpoint. The IDs are incremented for each checkpoint, starting at 1.
-- **Status**: The current status of the checkpoint, which is either *In Progress* (<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>), *Completed* (<i aria-hidden="true" class="fa fa-check"/>), or *Failed* (<i aria-hidden="true" class="fa fa-remove"/>). If the triggered checkpoint is a savepoint, you will see a <i aria-hidden="true" class="fa fa-floppy-o"/> symbol.
-- **Trigger Time**: The time when the checkpoint was triggered at the JobManager.
-- **Latest Acknowledgement**: The time when the latest acknowledgement for any subtask was received at the JobManager (or n/a if no acknowledgement received yet).
-- **End to End Duration**: The duration from the trigger timestamp until the latest acknowledgement (or n/a if no acknowledgement received yet). This end to end duration for a complete checkpoint is determined by the last subtask that acknowledges the checkpoint. This time is usually larger than single subtasks need to actually checkpoint the state.
-- **Checkpointed Data Size**: The checkpointed data size over all acknowledged subtasks. If incremental checkpointing is enabled this value is the checkpointed data size delta.
-- **Processed in-flight data**: The approximate number of bytes processed during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks.
-- **Persisted in-flight data**: The number of bytes persisted during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks. This is > 0 only if the unaligned checkpoints are enabled.
+- **ID**:已触发 Checkpoint 的 ID。每个 Checkpoint 的 ID 都会递增,从 1 开始。
+- **Status**:Checkpoint 的当前状态,可以是*正在进行(In Progress)*(<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>)、*已完成(Completed)*(<i aria-hidden="true" class="fa fa-check"/>)或*失败(Failed)*(<i aria-hidden="true" class="fa fa-remove"/>)。如果触发的检查点是一个保存点,你将看到一个 <i aria-hidden="true" class="fa fa-floppy-o"/> 符号。
+- **Trigger Time**:在 JobManager 上发起 Checkpoint 的时间。
+- **Latest Acknowledgement**:JobManager 接收到任何 subtask 的最新确认的时间(如果尚未收到确认,则不适用)。
+- **End to End Duration**:从触发时间戳到最后一次确认的持续时间(如果还没有收到确认,则不适用)。完整 Checkpoint 的端到端持续时间由确认 Checkpoint 的最后一个 Subtask 确定。这个时间通常大于单个 Subtask 实际 Checkpoint State 所需的时间。
+- **Checkpointed Data Size**:所有已确认 Subtasks 的 checkpoint 的数据大小。如果启用了增量 Checkpoint,则此值为 Checkpoint 数据的增量大小。
+- **Processed in-flight data**:在对齐(Checkpoint alignment)期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 处理的大约字节数。
+- **Persisted in-flight data**:在对齐期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 持久化的字节数。仅当启用未对齐的 Checkpoint 时,此值大于 0。
 
-For subtasks there are a couple of more detailed stats available.
+对于 subtasks,有两个更详细的统计信息可用。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history-subtasks.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history-subtasks.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **Sync Duration**: The duration of the synchronous part of the checkpoint. This includes snapshotting state of the operators and blocks all other activity on the subtask (processing records, firing timers, etc).
-- **Async Duration**: The duration of the asynchronous part of the checkpoint. This includes time it took to write the checkpoint on to the selected filesystem. For unaligned checkpoints this also includes also the time the subtask had to wait for last of the checkpoint barriers to arrive (alignment duration) and the time it took to persist the in-flight data.
-- **Alignment Duration**: The time between processing the first and the last checkpoint barrier. For aligned checkpoints, during the alignment, the channels that have already received checkpoint barrier are blocked from processing more data.
-- **Start Delay**: The time it took for the first checkpoint barrier to reach this subtasks since the checkpoint barrier has been created.
+- **Sync Duration**:Checkpoint 同步部分的持续时间。这包括 operators 的快照状态,并阻塞 subtask 上的所有其他活动(处理记录、触发计时器等)。
+- **Async Duration**:Checkpoint 的异步部分的持续时间。这包括将 Checkpoint 写入设置的文件系统所需的时间。对于未对齐的 Checkpoints,这还包括 subtask 必须等待最后一个 checkpoint barrier 到达的时间(对齐持续时间)以及持久化数据所需的时间。
+- **Alignment Duration**:处理第一个和最后一个 checkpoint barrier 之间的时间。对于对齐机制的 checkpoints,在对齐过程中,已经接收到 checkpoint barrier 的 channels 将阻塞并停止处理后续的数据。
+- **Start Delay**:自创建 checkpoint barrier 开始,第一个 checkpoint barrier 到达此 subtask 所用的时间。
 
-#### History Size Configuration
+<a name="history-size-configuration"></a>
 
-You can configure the number of recent checkpoints that are remembered for the history via the following configuration key. The default is `10`.
+#### 历史记录数量配置
+
+你可以通过以下配置键配置历史记录所保存的最近检查点的数量。默认值为 `10`。
 
 {% highlight yaml %}
-# Number of recent checkpoints that are remembered
+# 保存最近 Checkpoints 的个数
 web.checkpoints.history: 15
 {% endhighlight %}
 
-### Summary Tab
+<a name="summary-tab"></a>
+
+### 摘要信息(Summary)选项卡
 
-The summary computes a simple min/average/maximum statistics over all completed checkpoints for the End to End Duration, Checkpointed Data Size, and Bytes Buffered During Alignment (see [History](#history) for details about what these mean).
+摘要计算了所有已完成 checkpoints 的端到端持续时间、Checkpointed 数据大小和对齐期间缓冲的字节数的简单 min/average/maximum 统计信息(有关这些内容的详细信息,请参见 [History](#History tab))。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-summary.png" width="700px" alt="Checkpoint Monitoring: Summary">
+  <img src="{% link /fig/checkpoint_monitoring-summary.png %}" width="700px" alt="Checkpoint Monitoring: Summary">
 </center>
 
-Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+请注意,这些统计信息不会在 JobManager 丢失后无法保存,如果 JobManager 故障转移,这些统计信息将被重置。
+
+<a name="configuration-tab"></a>
 
-### Configuration Tab
+### 配置信息(Configuration)选项卡
 
-The configuration list your streaming configuration:
+该配置选项卡列出了你指定的流式配置:

Review comment:
       streaming configuration 翻译成 `流式配置` 不确定是否合适

##########
File path: docs/monitoring/checkpoint_monitoring.zh.md
##########
@@ -25,105 +25,125 @@ under the License.
 * ToC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-Flink's web interface provides a tab to monitor the checkpoints of jobs. These stats are also available after the job has terminated. There are four different tabs to display information about your checkpoints: Overview, History, Summary, and Configuration. The following sections will cover all of these in turn.
+## 概览(Overview)
 
-## Monitoring
+Flink 的 Web 界面提供了`选项卡/标签(tab)`来监视作业的 Checkpoint 信息。作业终止后,这些统计信息仍然可用。有四个不同的选项卡可显示有关 Checkpoint 的信息:概览(Overview),历史记录(History),摘要信息(Summary)和配置信息(Configuration)。以下各节将依次介绍这些内容。
 
-### Overview Tab
+<a name="monitoring"></a>
 
-The overview tabs lists the following statistics. Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+## 监控(Monitoring)
+
+<a name="overview-tab"></a>
+
+### 概览(Overview)选项卡
+
+概览选项卡列出了以下统计信息。请注意,这些统计信息在 JobManager 丢失时无法保存,如果 JobManager 发生故障转移,这些统计信息将重置。
 
 - **Checkpoint Counts**
-	- Triggered: The total number of checkpoints that have been triggered since the job started.
-	- In Progress: The current number of checkpoints that are in progress.
-	- Completed: The total number of successfully completed checkpoints since the job started.
-	- Failed: The total number of failed checkpoints since the job started.
-	- Restored: The number of restore operations since the job started. This also tells you how many times the job has restarted since submission. Note that the initial submission with a savepoint also counts as a restore and the count is reset if the JobManager was lost during operation.
-- **Latest Completed Checkpoint**: The latest successfully completed checkpoints. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Failed Checkpoint**: The latest failed checkpoint. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Savepoint**: The latest triggered savepoint with its external path. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Restore**: There are two types of restore operations.
-	- Restore from Checkpoint: We restored from a regular periodic checkpoint.
-	- Restore from Savepoint: We restored from a savepoint.
-
-### History Tab
-
-The checkpoint history keeps statistics about recently triggered checkpoints, including those that are currently in progress.
+	- Triggered:自作业开始以来触发的 Checkpoint 总数。
+	- In Progress:当前正在进行的 Checkpoint 数量。
+	- Completed:自作业开始以来成功完成的 Checkpoint 总数。
+	- Failed:自作业开始以来失败的 Checkpoint 总数。
+	- Restored:自作业开始以来进行的 Restored 操作的次数。这还表示自 Job 提交以来已重新启动多少次。请注意,带有 Savepoint 的初始提交也算作一次 Restore,如果 JobManager 在此操作过程中丢失,则该计数将重置。
+- **Latest Completed Checkpoint**:最新(最近)成功完成的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Failed Checkpoint**:最新失败的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Savepoint**:最新触发的 Savepoint 及其外部路径。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Restore**:有两种类型的 Restore 操作。
+	- Restore from Checkpoint:从定期的 Checkpoint 还原。
+	- Restore from Savepoint:从 Savepoint 还原。
+
+<a name="history-tab"></a>
+
+### 历史记录(History)选项卡
+
+Checkpoint 历史记录保存有关最近触发的 Checkpoint 的统计信息,包括当前正在进行的 Checkpoint。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **ID**: The ID of the triggered checkpoint. The IDs are incremented for each checkpoint, starting at 1.
-- **Status**: The current status of the checkpoint, which is either *In Progress* (<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>), *Completed* (<i aria-hidden="true" class="fa fa-check"/>), or *Failed* (<i aria-hidden="true" class="fa fa-remove"/>). If the triggered checkpoint is a savepoint, you will see a <i aria-hidden="true" class="fa fa-floppy-o"/> symbol.
-- **Trigger Time**: The time when the checkpoint was triggered at the JobManager.
-- **Latest Acknowledgement**: The time when the latest acknowledgement for any subtask was received at the JobManager (or n/a if no acknowledgement received yet).
-- **End to End Duration**: The duration from the trigger timestamp until the latest acknowledgement (or n/a if no acknowledgement received yet). This end to end duration for a complete checkpoint is determined by the last subtask that acknowledges the checkpoint. This time is usually larger than single subtasks need to actually checkpoint the state.
-- **Checkpointed Data Size**: The checkpointed data size over all acknowledged subtasks. If incremental checkpointing is enabled this value is the checkpointed data size delta.
-- **Processed in-flight data**: The approximate number of bytes processed during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks.
-- **Persisted in-flight data**: The number of bytes persisted during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks. This is > 0 only if the unaligned checkpoints are enabled.
+- **ID**:已触发 Checkpoint 的 ID。每个 Checkpoint 的 ID 都会递增,从 1 开始。
+- **Status**:Checkpoint 的当前状态,可以是*正在进行(In Progress)*(<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>)、*已完成(Completed)*(<i aria-hidden="true" class="fa fa-check"/>)或*失败(Failed)*(<i aria-hidden="true" class="fa fa-remove"/>)。如果触发的检查点是一个保存点,你将看到一个 <i aria-hidden="true" class="fa fa-floppy-o"/> 符号。
+- **Trigger Time**:在 JobManager 上发起 Checkpoint 的时间。
+- **Latest Acknowledgement**:JobManager 接收到任何 subtask 的最新确认的时间(如果尚未收到确认,则不适用)。
+- **End to End Duration**:从触发时间戳到最后一次确认的持续时间(如果还没有收到确认,则不适用)。完整 Checkpoint 的端到端持续时间由确认 Checkpoint 的最后一个 Subtask 确定。这个时间通常大于单个 Subtask 实际 Checkpoint State 所需的时间。
+- **Checkpointed Data Size**:所有已确认 Subtasks 的 checkpoint 的数据大小。如果启用了增量 Checkpoint,则此值为 Checkpoint 数据的增量大小。
+- **Processed in-flight data**:在对齐(Checkpoint alignment)期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 处理的大约字节数。
+- **Persisted in-flight data**:在对齐期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 持久化的字节数。仅当启用未对齐的 Checkpoint 时,此值大于 0。
 
-For subtasks there are a couple of more detailed stats available.
+对于 subtasks,有两个更详细的统计信息可用。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history-subtasks.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history-subtasks.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **Sync Duration**: The duration of the synchronous part of the checkpoint. This includes snapshotting state of the operators and blocks all other activity on the subtask (processing records, firing timers, etc).
-- **Async Duration**: The duration of the asynchronous part of the checkpoint. This includes time it took to write the checkpoint on to the selected filesystem. For unaligned checkpoints this also includes also the time the subtask had to wait for last of the checkpoint barriers to arrive (alignment duration) and the time it took to persist the in-flight data.
-- **Alignment Duration**: The time between processing the first and the last checkpoint barrier. For aligned checkpoints, during the alignment, the channels that have already received checkpoint barrier are blocked from processing more data.
-- **Start Delay**: The time it took for the first checkpoint barrier to reach this subtasks since the checkpoint barrier has been created.
+- **Sync Duration**:Checkpoint 同步部分的持续时间。这包括 operators 的快照状态,并阻塞 subtask 上的所有其他活动(处理记录、触发计时器等)。
+- **Async Duration**:Checkpoint 的异步部分的持续时间。这包括将 Checkpoint 写入设置的文件系统所需的时间。对于未对齐的 Checkpoints,这还包括 subtask 必须等待最后一个 checkpoint barrier 到达的时间(对齐持续时间)以及持久化数据所需的时间。
+- **Alignment Duration**:处理第一个和最后一个 checkpoint barrier 之间的时间。对于对齐机制的 checkpoints,在对齐过程中,已经接收到 checkpoint barrier 的 channels 将阻塞并停止处理后续的数据。
+- **Start Delay**:自创建 checkpoint barrier 开始,第一个 checkpoint barrier 到达此 subtask 所用的时间。

Review comment:
       这个的意思能否再优化下呢?如果我没猜错的话,这里应该是 "从 barrier 在 source 创建到流到这个 task 的时间差“ 当然这个含义我需要看代码 check 下

##########
File path: docs/monitoring/checkpoint_monitoring.zh.md
##########
@@ -25,105 +25,125 @@ under the License.
 * ToC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-Flink's web interface provides a tab to monitor the checkpoints of jobs. These stats are also available after the job has terminated. There are four different tabs to display information about your checkpoints: Overview, History, Summary, and Configuration. The following sections will cover all of these in turn.
+## 概览(Overview)
 
-## Monitoring
+Flink 的 Web 界面提供了`选项卡/标签(tab)`来监视作业的 Checkpoint 信息。作业终止后,这些统计信息仍然可用。有四个不同的选项卡可显示有关 Checkpoint 的信息:概览(Overview),历史记录(History),摘要信息(Summary)和配置信息(Configuration)。以下各节将依次介绍这些内容。
 
-### Overview Tab
+<a name="monitoring"></a>
 
-The overview tabs lists the following statistics. Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+## 监控(Monitoring)
+
+<a name="overview-tab"></a>
+
+### 概览(Overview)选项卡
+
+概览选项卡列出了以下统计信息。请注意,这些统计信息在 JobManager 丢失时无法保存,如果 JobManager 发生故障转移,这些统计信息将重置。
 
 - **Checkpoint Counts**
-	- Triggered: The total number of checkpoints that have been triggered since the job started.
-	- In Progress: The current number of checkpoints that are in progress.
-	- Completed: The total number of successfully completed checkpoints since the job started.
-	- Failed: The total number of failed checkpoints since the job started.
-	- Restored: The number of restore operations since the job started. This also tells you how many times the job has restarted since submission. Note that the initial submission with a savepoint also counts as a restore and the count is reset if the JobManager was lost during operation.
-- **Latest Completed Checkpoint**: The latest successfully completed checkpoints. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Failed Checkpoint**: The latest failed checkpoint. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Savepoint**: The latest triggered savepoint with its external path. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Restore**: There are two types of restore operations.
-	- Restore from Checkpoint: We restored from a regular periodic checkpoint.
-	- Restore from Savepoint: We restored from a savepoint.
-
-### History Tab
-
-The checkpoint history keeps statistics about recently triggered checkpoints, including those that are currently in progress.
+	- Triggered:自作业开始以来触发的 Checkpoint 总数。
+	- In Progress:当前正在进行的 Checkpoint 数量。
+	- Completed:自作业开始以来成功完成的 Checkpoint 总数。
+	- Failed:自作业开始以来失败的 Checkpoint 总数。
+	- Restored:自作业开始以来进行的 Restored 操作的次数。这还表示自 Job 提交以来已重新启动多少次。请注意,带有 Savepoint 的初始提交也算作一次 Restore,如果 JobManager 在此操作过程中丢失,则该计数将重置。
+- **Latest Completed Checkpoint**:最新(最近)成功完成的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Failed Checkpoint**:最新失败的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Savepoint**:最新触发的 Savepoint 及其外部路径。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Restore**:有两种类型的 Restore 操作。
+	- Restore from Checkpoint:从定期的 Checkpoint 还原。
+	- Restore from Savepoint:从 Savepoint 还原。
+
+<a name="history-tab"></a>
+
+### 历史记录(History)选项卡
+
+Checkpoint 历史记录保存有关最近触发的 Checkpoint 的统计信息,包括当前正在进行的 Checkpoint。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **ID**: The ID of the triggered checkpoint. The IDs are incremented for each checkpoint, starting at 1.
-- **Status**: The current status of the checkpoint, which is either *In Progress* (<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>), *Completed* (<i aria-hidden="true" class="fa fa-check"/>), or *Failed* (<i aria-hidden="true" class="fa fa-remove"/>). If the triggered checkpoint is a savepoint, you will see a <i aria-hidden="true" class="fa fa-floppy-o"/> symbol.
-- **Trigger Time**: The time when the checkpoint was triggered at the JobManager.
-- **Latest Acknowledgement**: The time when the latest acknowledgement for any subtask was received at the JobManager (or n/a if no acknowledgement received yet).
-- **End to End Duration**: The duration from the trigger timestamp until the latest acknowledgement (or n/a if no acknowledgement received yet). This end to end duration for a complete checkpoint is determined by the last subtask that acknowledges the checkpoint. This time is usually larger than single subtasks need to actually checkpoint the state.
-- **Checkpointed Data Size**: The checkpointed data size over all acknowledged subtasks. If incremental checkpointing is enabled this value is the checkpointed data size delta.
-- **Processed in-flight data**: The approximate number of bytes processed during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks.
-- **Persisted in-flight data**: The number of bytes persisted during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks. This is > 0 only if the unaligned checkpoints are enabled.
+- **ID**:已触发 Checkpoint 的 ID。每个 Checkpoint 的 ID 都会递增,从 1 开始。
+- **Status**:Checkpoint 的当前状态,可以是*正在进行(In Progress)*(<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>)、*已完成(Completed)*(<i aria-hidden="true" class="fa fa-check"/>)或*失败(Failed)*(<i aria-hidden="true" class="fa fa-remove"/>)。如果触发的检查点是一个保存点,你将看到一个 <i aria-hidden="true" class="fa fa-floppy-o"/> 符号。
+- **Trigger Time**:在 JobManager 上发起 Checkpoint 的时间。
+- **Latest Acknowledgement**:JobManager 接收到任何 subtask 的最新确认的时间(如果尚未收到确认,则不适用)。
+- **End to End Duration**:从触发时间戳到最后一次确认的持续时间(如果还没有收到确认,则不适用)。完整 Checkpoint 的端到端持续时间由确认 Checkpoint 的最后一个 Subtask 确定。这个时间通常大于单个 Subtask 实际 Checkpoint State 所需的时间。
+- **Checkpointed Data Size**:所有已确认 Subtasks 的 checkpoint 的数据大小。如果启用了增量 Checkpoint,则此值为 Checkpoint 数据的增量大小。
+- **Processed in-flight data**:在对齐(Checkpoint alignment)期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 处理的大约字节数。
+- **Persisted in-flight data**:在对齐期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 持久化的字节数。仅当启用未对齐的 Checkpoint 时,此值大于 0。

Review comment:
       unaligned checkpoint 翻译成 `未对齐的 Checkpoint` 这个是否合适呢?

##########
File path: docs/monitoring/checkpoint_monitoring.zh.md
##########
@@ -25,105 +25,125 @@ under the License.
 * ToC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-Flink's web interface provides a tab to monitor the checkpoints of jobs. These stats are also available after the job has terminated. There are four different tabs to display information about your checkpoints: Overview, History, Summary, and Configuration. The following sections will cover all of these in turn.
+## 概览(Overview)
 
-## Monitoring
+Flink 的 Web 界面提供了`选项卡/标签(tab)`来监视作业的 Checkpoint 信息。作业终止后,这些统计信息仍然可用。有四个不同的选项卡可显示有关 Checkpoint 的信息:概览(Overview),历史记录(History),摘要信息(Summary)和配置信息(Configuration)。以下各节将依次介绍这些内容。
 
-### Overview Tab
+<a name="monitoring"></a>
 
-The overview tabs lists the following statistics. Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+## 监控(Monitoring)
+
+<a name="overview-tab"></a>
+
+### 概览(Overview)选项卡
+
+概览选项卡列出了以下统计信息。请注意,这些统计信息在 JobManager 丢失时无法保存,如果 JobManager 发生故障转移,这些统计信息将重置。
 
 - **Checkpoint Counts**
-	- Triggered: The total number of checkpoints that have been triggered since the job started.
-	- In Progress: The current number of checkpoints that are in progress.
-	- Completed: The total number of successfully completed checkpoints since the job started.
-	- Failed: The total number of failed checkpoints since the job started.
-	- Restored: The number of restore operations since the job started. This also tells you how many times the job has restarted since submission. Note that the initial submission with a savepoint also counts as a restore and the count is reset if the JobManager was lost during operation.
-- **Latest Completed Checkpoint**: The latest successfully completed checkpoints. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Failed Checkpoint**: The latest failed checkpoint. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Savepoint**: The latest triggered savepoint with its external path. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Restore**: There are two types of restore operations.
-	- Restore from Checkpoint: We restored from a regular periodic checkpoint.
-	- Restore from Savepoint: We restored from a savepoint.
-
-### History Tab
-
-The checkpoint history keeps statistics about recently triggered checkpoints, including those that are currently in progress.
+	- Triggered:自作业开始以来触发的 Checkpoint 总数。
+	- In Progress:当前正在进行的 Checkpoint 数量。
+	- Completed:自作业开始以来成功完成的 Checkpoint 总数。
+	- Failed:自作业开始以来失败的 Checkpoint 总数。
+	- Restored:自作业开始以来进行的 Restored 操作的次数。这还表示自 Job 提交以来已重新启动多少次。请注意,带有 Savepoint 的初始提交也算作一次 Restore,如果 JobManager 在此操作过程中丢失,则该计数将重置。
+- **Latest Completed Checkpoint**:最新(最近)成功完成的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Failed Checkpoint**:最新失败的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Savepoint**:最新触发的 Savepoint 及其外部路径。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Restore**:有两种类型的 Restore 操作。
+	- Restore from Checkpoint:从定期的 Checkpoint 还原。
+	- Restore from Savepoint:从 Savepoint 还原。
+
+<a name="history-tab"></a>
+
+### 历史记录(History)选项卡
+
+Checkpoint 历史记录保存有关最近触发的 Checkpoint 的统计信息,包括当前正在进行的 Checkpoint。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **ID**: The ID of the triggered checkpoint. The IDs are incremented for each checkpoint, starting at 1.
-- **Status**: The current status of the checkpoint, which is either *In Progress* (<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>), *Completed* (<i aria-hidden="true" class="fa fa-check"/>), or *Failed* (<i aria-hidden="true" class="fa fa-remove"/>). If the triggered checkpoint is a savepoint, you will see a <i aria-hidden="true" class="fa fa-floppy-o"/> symbol.
-- **Trigger Time**: The time when the checkpoint was triggered at the JobManager.
-- **Latest Acknowledgement**: The time when the latest acknowledgement for any subtask was received at the JobManager (or n/a if no acknowledgement received yet).
-- **End to End Duration**: The duration from the trigger timestamp until the latest acknowledgement (or n/a if no acknowledgement received yet). This end to end duration for a complete checkpoint is determined by the last subtask that acknowledges the checkpoint. This time is usually larger than single subtasks need to actually checkpoint the state.
-- **Checkpointed Data Size**: The checkpointed data size over all acknowledged subtasks. If incremental checkpointing is enabled this value is the checkpointed data size delta.
-- **Processed in-flight data**: The approximate number of bytes processed during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks.
-- **Persisted in-flight data**: The number of bytes persisted during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks. This is > 0 only if the unaligned checkpoints are enabled.
+- **ID**:已触发 Checkpoint 的 ID。每个 Checkpoint 的 ID 都会递增,从 1 开始。
+- **Status**:Checkpoint 的当前状态,可以是*正在进行(In Progress)*(<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>)、*已完成(Completed)*(<i aria-hidden="true" class="fa fa-check"/>)或*失败(Failed)*(<i aria-hidden="true" class="fa fa-remove"/>)。如果触发的检查点是一个保存点,你将看到一个 <i aria-hidden="true" class="fa fa-floppy-o"/> 符号。
+- **Trigger Time**:在 JobManager 上发起 Checkpoint 的时间。
+- **Latest Acknowledgement**:JobManager 接收到任何 subtask 的最新确认的时间(如果尚未收到确认,则不适用)。
+- **End to End Duration**:从触发时间戳到最后一次确认的持续时间(如果还没有收到确认,则不适用)。完整 Checkpoint 的端到端持续时间由确认 Checkpoint 的最后一个 Subtask 确定。这个时间通常大于单个 Subtask 实际 Checkpoint State 所需的时间。
+- **Checkpointed Data Size**:所有已确认 Subtasks 的 checkpoint 的数据大小。如果启用了增量 Checkpoint,则此值为 Checkpoint 数据的增量大小。
+- **Processed in-flight data**:在对齐(Checkpoint alignment)期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 处理的大约字节数。
+- **Persisted in-flight data**:在对齐期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 持久化的字节数。仅当启用未对齐的 Checkpoint 时,此值大于 0。
 
-For subtasks there are a couple of more detailed stats available.
+对于 subtasks,有两个更详细的统计信息可用。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history-subtasks.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history-subtasks.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **Sync Duration**: The duration of the synchronous part of the checkpoint. This includes snapshotting state of the operators and blocks all other activity on the subtask (processing records, firing timers, etc).
-- **Async Duration**: The duration of the asynchronous part of the checkpoint. This includes time it took to write the checkpoint on to the selected filesystem. For unaligned checkpoints this also includes also the time the subtask had to wait for last of the checkpoint barriers to arrive (alignment duration) and the time it took to persist the in-flight data.
-- **Alignment Duration**: The time between processing the first and the last checkpoint barrier. For aligned checkpoints, during the alignment, the channels that have already received checkpoint barrier are blocked from processing more data.
-- **Start Delay**: The time it took for the first checkpoint barrier to reach this subtasks since the checkpoint barrier has been created.
+- **Sync Duration**:Checkpoint 同步部分的持续时间。这包括 operators 的快照状态,并阻塞 subtask 上的所有其他活动(处理记录、触发计时器等)。
+- **Async Duration**:Checkpoint 的异步部分的持续时间。这包括将 Checkpoint 写入设置的文件系统所需的时间。对于未对齐的 Checkpoints,这还包括 subtask 必须等待最后一个 checkpoint barrier 到达的时间(对齐持续时间)以及持久化数据所需的时间。
+- **Alignment Duration**:处理第一个和最后一个 checkpoint barrier 之间的时间。对于对齐机制的 checkpoints,在对齐过程中,已经接收到 checkpoint barrier 的 channels 将阻塞并停止处理后续的数据。
+- **Start Delay**:自创建 checkpoint barrier 开始,第一个 checkpoint barrier 到达此 subtask 所用的时间。
 
-#### History Size Configuration
+<a name="history-size-configuration"></a>
 
-You can configure the number of recent checkpoints that are remembered for the history via the following configuration key. The default is `10`.
+#### 历史记录数量配置
+
+你可以通过以下配置键配置历史记录所保存的最近检查点的数量。默认值为 `10`。
 
 {% highlight yaml %}
-# Number of recent checkpoints that are remembered
+# 保存最近 Checkpoints 的个数
 web.checkpoints.history: 15
 {% endhighlight %}
 
-### Summary Tab
+<a name="summary-tab"></a>
+
+### 摘要信息(Summary)选项卡
 
-The summary computes a simple min/average/maximum statistics over all completed checkpoints for the End to End Duration, Checkpointed Data Size, and Bytes Buffered During Alignment (see [History](#history) for details about what these mean).
+摘要计算了所有已完成 checkpoints 的端到端持续时间、Checkpointed 数据大小和对齐期间缓冲的字节数的简单 min/average/maximum 统计信息(有关这些内容的详细信息,请参见 [History](#History tab))。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-summary.png" width="700px" alt="Checkpoint Monitoring: Summary">
+  <img src="{% link /fig/checkpoint_monitoring-summary.png %}" width="700px" alt="Checkpoint Monitoring: Summary">
 </center>
 
-Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+请注意,这些统计信息不会在 JobManager 丢失后无法保存,如果 JobManager 故障转移,这些统计信息将被重置。
+
+<a name="configuration-tab"></a>
 
-### Configuration Tab
+### 配置信息(Configuration)选项卡
 
-The configuration list your streaming configuration:
+该配置选项卡列出了你指定的流式配置:
 
-- **Checkpointing Mode**: Either *Exactly Once* or *At least Once*.
-- **Interval**: The configured checkpointing interval. Trigger checkpoints in this interval.
-- **Timeout**: Timeout after which a checkpoint is cancelled by the JobManager and a new checkpoint is triggered.
-- **Minimum Pause Between Checkpoints**: Minimum required pause between checkpoints. After a checkpoint has completed successfully, we wait at least for this amount of time before triggering the next one, potentially delaying the regular interval.
-- **Maximum Concurrent Checkpoints**: The maximum number of checkpoints that can be in progress concurrently.
-- **Persist Checkpoints Externally**: Enabled or Disabled. If enabled, furthermore lists the cleanup config for externalized checkpoints (delete or retain on cancellation).
+- **Checkpointing Mode**:*恰好一次(Exactly Once)*或者*至少一次(At least Once)*。
+- **Interval**:配置的 Checkpoint 触发间隔。在此间隔内触发 Checkpoint。
+- **Timeout**:超时之后,JobManager 取消 checkpoint 并触发新的 checkpoint。
+- **Minimum Pause Between Checkpoints**:Checkpoint 之间所需的最小暂停时间。Checkpoint 成功完成后,我们至少要等这段时间再触发下一个,这可能会延迟正常的间隔。
+- **Maximum Concurrent Checkpoints**:可以同时进行的最大 checkpoint 个数。
+- **Persist Checkpoints Externally**:启用或禁用持久化 Checkpoints 到外部系统。如果启用,还会列出外部化 checkpoints 的清理配置(取消时删除或保留)。

Review comment:
       `Checkpoint` 的大小写建议统一,非首字母可以小写

##########
File path: docs/monitoring/checkpoint_monitoring.zh.md
##########
@@ -25,105 +25,125 @@ under the License.
 * ToC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-Flink's web interface provides a tab to monitor the checkpoints of jobs. These stats are also available after the job has terminated. There are four different tabs to display information about your checkpoints: Overview, History, Summary, and Configuration. The following sections will cover all of these in turn.
+## 概览(Overview)
 
-## Monitoring
+Flink 的 Web 界面提供了`选项卡/标签(tab)`来监视作业的 Checkpoint 信息。作业终止后,这些统计信息仍然可用。有四个不同的选项卡可显示有关 Checkpoint 的信息:概览(Overview),历史记录(History),摘要信息(Summary)和配置信息(Configuration)。以下各节将依次介绍这些内容。
 
-### Overview Tab
+<a name="monitoring"></a>
 
-The overview tabs lists the following statistics. Note that these statistics don't survive a JobManager loss and are reset to if your JobManager fails over.
+## 监控(Monitoring)
+
+<a name="overview-tab"></a>
+
+### 概览(Overview)选项卡
+
+概览选项卡列出了以下统计信息。请注意,这些统计信息在 JobManager 丢失时无法保存,如果 JobManager 发生故障转移,这些统计信息将重置。
 
 - **Checkpoint Counts**
-	- Triggered: The total number of checkpoints that have been triggered since the job started.
-	- In Progress: The current number of checkpoints that are in progress.
-	- Completed: The total number of successfully completed checkpoints since the job started.
-	- Failed: The total number of failed checkpoints since the job started.
-	- Restored: The number of restore operations since the job started. This also tells you how many times the job has restarted since submission. Note that the initial submission with a savepoint also counts as a restore and the count is reset if the JobManager was lost during operation.
-- **Latest Completed Checkpoint**: The latest successfully completed checkpoints. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Failed Checkpoint**: The latest failed checkpoint. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Savepoint**: The latest triggered savepoint with its external path. Clicking on `More details` gives you detailed statistics down to the subtask level.
-- **Latest Restore**: There are two types of restore operations.
-	- Restore from Checkpoint: We restored from a regular periodic checkpoint.
-	- Restore from Savepoint: We restored from a savepoint.
-
-### History Tab
-
-The checkpoint history keeps statistics about recently triggered checkpoints, including those that are currently in progress.
+	- Triggered:自作业开始以来触发的 Checkpoint 总数。
+	- In Progress:当前正在进行的 Checkpoint 数量。
+	- Completed:自作业开始以来成功完成的 Checkpoint 总数。
+	- Failed:自作业开始以来失败的 Checkpoint 总数。
+	- Restored:自作业开始以来进行的 Restored 操作的次数。这还表示自 Job 提交以来已重新启动多少次。请注意,带有 Savepoint 的初始提交也算作一次 Restore,如果 JobManager 在此操作过程中丢失,则该计数将重置。
+- **Latest Completed Checkpoint**:最新(最近)成功完成的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Failed Checkpoint**:最新失败的 Checkpoint。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Savepoint**:最新触发的 Savepoint 及其外部路径。点击 `More details` 可以得到 subtask 级别的详细统计信息。
+- **Latest Restore**:有两种类型的 Restore 操作。
+	- Restore from Checkpoint:从定期的 Checkpoint 还原。
+	- Restore from Savepoint:从 Savepoint 还原。
+
+<a name="history-tab"></a>
+
+### 历史记录(History)选项卡
+
+Checkpoint 历史记录保存有关最近触发的 Checkpoint 的统计信息,包括当前正在进行的 Checkpoint。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **ID**: The ID of the triggered checkpoint. The IDs are incremented for each checkpoint, starting at 1.
-- **Status**: The current status of the checkpoint, which is either *In Progress* (<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>), *Completed* (<i aria-hidden="true" class="fa fa-check"/>), or *Failed* (<i aria-hidden="true" class="fa fa-remove"/>). If the triggered checkpoint is a savepoint, you will see a <i aria-hidden="true" class="fa fa-floppy-o"/> symbol.
-- **Trigger Time**: The time when the checkpoint was triggered at the JobManager.
-- **Latest Acknowledgement**: The time when the latest acknowledgement for any subtask was received at the JobManager (or n/a if no acknowledgement received yet).
-- **End to End Duration**: The duration from the trigger timestamp until the latest acknowledgement (or n/a if no acknowledgement received yet). This end to end duration for a complete checkpoint is determined by the last subtask that acknowledges the checkpoint. This time is usually larger than single subtasks need to actually checkpoint the state.
-- **Checkpointed Data Size**: The checkpointed data size over all acknowledged subtasks. If incremental checkpointing is enabled this value is the checkpointed data size delta.
-- **Processed in-flight data**: The approximate number of bytes processed during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks.
-- **Persisted in-flight data**: The number of bytes persisted during the alignment (time between receiving the first and the last checkpoint barrier) over all acknowledged subtasks. This is > 0 only if the unaligned checkpoints are enabled.
+- **ID**:已触发 Checkpoint 的 ID。每个 Checkpoint 的 ID 都会递增,从 1 开始。
+- **Status**:Checkpoint 的当前状态,可以是*正在进行(In Progress)*(<i aria-hidden="true" class="fa fa-circle-o-notch fa-spin fa-fw"/>)、*已完成(Completed)*(<i aria-hidden="true" class="fa fa-check"/>)或*失败(Failed)*(<i aria-hidden="true" class="fa fa-remove"/>)。如果触发的检查点是一个保存点,你将看到一个 <i aria-hidden="true" class="fa fa-floppy-o"/> 符号。
+- **Trigger Time**:在 JobManager 上发起 Checkpoint 的时间。
+- **Latest Acknowledgement**:JobManager 接收到任何 subtask 的最新确认的时间(如果尚未收到确认,则不适用)。
+- **End to End Duration**:从触发时间戳到最后一次确认的持续时间(如果还没有收到确认,则不适用)。完整 Checkpoint 的端到端持续时间由确认 Checkpoint 的最后一个 Subtask 确定。这个时间通常大于单个 Subtask 实际 Checkpoint State 所需的时间。
+- **Checkpointed Data Size**:所有已确认 Subtasks 的 checkpoint 的数据大小。如果启用了增量 Checkpoint,则此值为 Checkpoint 数据的增量大小。
+- **Processed in-flight data**:在对齐(Checkpoint alignment)期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 处理的大约字节数。
+- **Persisted in-flight data**:在对齐期间(从接收第一个和最后一个 Checkpoint barrier 之间的时间)对所有已确认的 Subtasks 持久化的字节数。仅当启用未对齐的 Checkpoint 时,此值大于 0。
 
-For subtasks there are a couple of more detailed stats available.
+对于 subtasks,有两个更详细的统计信息可用。
 
 <center>
-  <img src="{{ site.baseurl }}/fig/checkpoint_monitoring-history-subtasks.png" width="700px" alt="Checkpoint Monitoring: History">
+  <img src="{% link /fig/checkpoint_monitoring-history-subtasks.png %}" width="700px" alt="Checkpoint Monitoring: History">
 </center>
 
-- **Sync Duration**: The duration of the synchronous part of the checkpoint. This includes snapshotting state of the operators and blocks all other activity on the subtask (processing records, firing timers, etc).
-- **Async Duration**: The duration of the asynchronous part of the checkpoint. This includes time it took to write the checkpoint on to the selected filesystem. For unaligned checkpoints this also includes also the time the subtask had to wait for last of the checkpoint barriers to arrive (alignment duration) and the time it took to persist the in-flight data.
-- **Alignment Duration**: The time between processing the first and the last checkpoint barrier. For aligned checkpoints, during the alignment, the channels that have already received checkpoint barrier are blocked from processing more data.
-- **Start Delay**: The time it took for the first checkpoint barrier to reach this subtasks since the checkpoint barrier has been created.
+- **Sync Duration**:Checkpoint 同步部分的持续时间。这包括 operators 的快照状态,并阻塞 subtask 上的所有其他活动(处理记录、触发计时器等)。
+- **Async Duration**:Checkpoint 的异步部分的持续时间。这包括将 Checkpoint 写入设置的文件系统所需的时间。对于未对齐的 Checkpoints,这还包括 subtask 必须等待最后一个 checkpoint barrier 到达的时间(对齐持续时间)以及持久化数据所需的时间。
+- **Alignment Duration**:处理第一个和最后一个 checkpoint barrier 之间的时间。对于对齐机制的 checkpoints,在对齐过程中,已经接收到 checkpoint barrier 的 channels 将阻塞并停止处理后续的数据。
+- **Start Delay**:自创建 checkpoint barrier 开始,第一个 checkpoint barrier 到达此 subtask 所用的时间。
 
-#### History Size Configuration
+<a name="history-size-configuration"></a>
 
-You can configure the number of recent checkpoints that are remembered for the history via the following configuration key. The default is `10`.
+#### 历史记录数量配置
+
+你可以通过以下配置键配置历史记录所保存的最近检查点的数量。默认值为 `10`。
 
 {% highlight yaml %}
-# Number of recent checkpoints that are remembered
+# 保存最近 Checkpoints 的个数
 web.checkpoints.history: 15
 {% endhighlight %}
 
-### Summary Tab
+<a name="summary-tab"></a>
+
+### 摘要信息(Summary)选项卡
 
-The summary computes a simple min/average/maximum statistics over all completed checkpoints for the End to End Duration, Checkpointed Data Size, and Bytes Buffered During Alignment (see [History](#history) for details about what these mean).
+摘要计算了所有已完成 checkpoints 的端到端持续时间、Checkpointed 数据大小和对齐期间缓冲的字节数的简单 min/average/maximum 统计信息(有关这些内容的详细信息,请参见 [History](#History tab))。

Review comment:
       这个 history 的 tab 链接应该是有问题的




----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] RocMarshal removed a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
RocMarshal removed a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-719256518


   @xccui @dianfu 
   Could you help me to review this PR if you have free time?
   Thank you.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] dianfu commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
dianfu commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-723559345


   @RocMarshal I'd like to leave it to @klion26 who is more professional in this area and have also reviewed this PR. @klion26 Feel free to merge this PR if you think it's OK to merge. :)


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] klion26 merged pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
klion26 merged pull request #13750:
URL: https://github.com/apache/flink/pull/13750


   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot edited a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714567487


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119",
       "triggerID" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "triggerType" : "PUSH"
     }, {
       "hash" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8502",
       "triggerID" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "triggerType" : "PUSH"
     }, {
       "hash" : "930c16e764a8e3c1ce6352ff7389cffd5c88485b",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "930c16e764a8e3c1ce6352ff7389cffd5c88485b",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 275378338d8c0968a73489764de84a0cb2096e2b Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8502) 
   * 930c16e764a8e3c1ce6352ff7389cffd5c88485b UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run travis` re-run the last Travis build
    - `@flinkbot run azure` re-run the last Azure build
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714567487


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 1ec411ddcfd58a0ab5f22c7ebe5433439b217d27 UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run travis` re-run the last Travis build
    - `@flinkbot run azure` re-run the last Azure build
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714547252


   Thanks a lot for your contribution to the Apache Flink project. I'm the @flinkbot. I help the community
   to review your pull request. We will use this comment to track the progress of the review.
   
   
   ## Automated Checks
   Last check on commit 1ec411ddcfd58a0ab5f22c7ebe5433439b217d27 (Thu Oct 22 14:48:41 UTC 2020)
   
    ✅no warnings
   
   <sub>Mention the bot in a comment to re-run the automated checks.</sub>
   ## Review Progress
   
   * ❓ 1. The [description] looks good.
   * ❓ 2. There is [consensus] that the contribution should go into to Flink.
   * ❓ 3. Needs [attention] from.
   * ❓ 4. The change fits into the overall [architecture].
   * ❓ 5. Overall code [quality] is good.
   
   Please see the [Pull Request Review Guide](https://flink.apache.org/contributing/reviewing-prs.html) for a full explanation of the review process.<details>
    The Bot is tracking the review progress through labels. Labels are applied according to the order of the review items. For consensus, approval by a Flink committer of PMC member is required <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot approve description` to approve one or more aspects (aspects: `description`, `consensus`, `architecture` and `quality`)
    - `@flinkbot approve all` to approve all aspects
    - `@flinkbot approve-until architecture` to approve everything until `architecture`
    - `@flinkbot attention @username1 [@username2 ..]` to require somebody's attention
    - `@flinkbot disapprove architecture` to remove an approval you gave earlier
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] RocMarshal commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
RocMarshal commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-724420531


   @klion26 I made a little change on the branch information. Please take a look.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot edited a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714567487


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119",
       "triggerID" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 1ec411ddcfd58a0ab5f22c7ebe5433439b217d27 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run travis` re-run the last Travis build
    - `@flinkbot run azure` re-run the last Azure build
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] klion26 commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
klion26 commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-724643200


   @RocMarshal thanks for the update, merging.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot edited a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714567487


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119",
       "triggerID" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "triggerType" : "PUSH"
     }, {
       "hash" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8502",
       "triggerID" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 275378338d8c0968a73489764de84a0cb2096e2b Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8502) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run travis` re-run the last Travis build
    - `@flinkbot run azure` re-run the last Azure build
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot edited a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714567487


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119",
       "triggerID" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "triggerType" : "PUSH"
     }, {
       "hash" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 1ec411ddcfd58a0ab5f22c7ebe5433439b217d27 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119) 
   * 275378338d8c0968a73489764de84a0cb2096e2b UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run travis` re-run the last Travis build
    - `@flinkbot run azure` re-run the last Azure build
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] RocMarshal commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
RocMarshal commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-724402907


   > @RocMarshal When I pull your branch locally, seems there are two other commits between [296c869](https://github.com/apache/flink/commit/296c869ceac85a5fd5c880a371f3bc6941f97acb) and [9793b9c](https://github.com/apache/flink/commit/9793b9c23786a99b65dbe044f84fb5d1232add20), I'm not sure why could this happen, could you please double-check it on your side?
   > 
   > And very much appreciate it if you could squash the commit into a single one, I'm not very familiar with merge commit into master currently :)
   > 
   > ```
   > 275378338d (HEAD -> RE_13750, R13750) Update docs/monitoring/checkpoint_monitoring.zh.md
   > 1ec411ddcf Update docs/monitoring/checkpoint_monitoring.zh.md
   > 9793b9c237 Update docs/monitoring/checkpoint_monitoring.zh.md
   > 726435e10d [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese
   > 3b9e20aafc [FLINK-17528][table] Remove ArrayData#get() API and use ElementGetter instead
   > debbdc66a4 [FLINK-17528][table] Remove RowData#get() API and use FieldGetter instead
   > 296c869cea [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese
   > ```
   
   @klion26 I'll check it as soon as possible. Thank you for your reply.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] RocMarshal commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
RocMarshal commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-718102068


   @klion26 
   Thank you  for your help.
   I made some change based  on  your suggestions.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] klion26 commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
klion26 commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-724001184


   @RocMarshal When I pull your branch locally, seems there are two other commits between 296c869ceac85 and 9793b9c23786a9, I'm not sure why could this happen, could you please double-check it on your side? 
   
   And very much appreciate it if you could squash the commit into a single one, I'm not very familiar with merge commit into master currently :)
   
   
   ```
   275378338d (HEAD -> RE_13750, R13750) Update docs/monitoring/checkpoint_monitoring.zh.md
   1ec411ddcf Update docs/monitoring/checkpoint_monitoring.zh.md
   9793b9c237 Update docs/monitoring/checkpoint_monitoring.zh.md
   726435e10d [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese
   3b9e20aafc [FLINK-17528][table] Remove ArrayData#get() API and use ElementGetter instead
   debbdc66a4 [FLINK-17528][table] Remove RowData#get() API and use FieldGetter instead
   296c869cea [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese
   ```


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] klion26 commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
klion26 commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-723711963


   @dianfu thanks for the review, will merge this one soon.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] RocMarshal commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
RocMarshal commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-723521553


   @dianfu 
   Could you help me to merge this PR if there is nothing inappropriate ?
   
   Thank you.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] wuchong commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
wuchong commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-720919126


   Feel free to merge @kl0u . 


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] RocMarshal commented on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
RocMarshal commented on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-715906722


   Hi, @klion26
   Could you help me to review this PR if you have free time?
   Thank you.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot edited a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714567487


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119",
       "triggerID" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "triggerType" : "PUSH"
     }, {
       "hash" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8502",
       "triggerID" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "triggerType" : "PUSH"
     }, {
       "hash" : "930c16e764a8e3c1ce6352ff7389cffd5c88485b",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=9373",
       "triggerID" : "930c16e764a8e3c1ce6352ff7389cffd5c88485b",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 930c16e764a8e3c1ce6352ff7389cffd5c88485b Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=9373) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run travis` re-run the last Travis build
    - `@flinkbot run azure` re-run the last Azure build
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot edited a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714567487


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119",
       "triggerID" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "triggerType" : "PUSH"
     }, {
       "hash" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8502",
       "triggerID" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 1ec411ddcfd58a0ab5f22c7ebe5433439b217d27 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119) 
   * 275378338d8c0968a73489764de84a0cb2096e2b Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8502) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run travis` re-run the last Travis build
    - `@flinkbot run azure` re-run the last Azure build
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] RocMarshal edited a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
RocMarshal edited a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-718102068


   @klion26 
   Thank you  for your help.
   I made some changes based  on  your suggestions.


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [flink] flinkbot edited a comment on pull request #13750: [FLINK-19394][docs-zh] Translate the 'Monitoring Checkpointing' page of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
flinkbot edited a comment on pull request #13750:
URL: https://github.com/apache/flink/pull/13750#issuecomment-714567487


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8119",
       "triggerID" : "1ec411ddcfd58a0ab5f22c7ebe5433439b217d27",
       "triggerType" : "PUSH"
     }, {
       "hash" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8502",
       "triggerID" : "275378338d8c0968a73489764de84a0cb2096e2b",
       "triggerType" : "PUSH"
     }, {
       "hash" : "930c16e764a8e3c1ce6352ff7389cffd5c88485b",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=9373",
       "triggerID" : "930c16e764a8e3c1ce6352ff7389cffd5c88485b",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 275378338d8c0968a73489764de84a0cb2096e2b Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=8502) 
   * 930c16e764a8e3c1ce6352ff7389cffd5c88485b Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=9373) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@flinkbot run travis` re-run the last Travis build
    - `@flinkbot run azure` re-run the last Azure build
   </details>


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org