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/08/21 06:24:50 UTC

[GitHub] [flink] RocMarshal opened a new pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   *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 'History Server' page of 'Debugging & Monitoring' into Chinese*
   
   
   ## Brief change log
   
   *Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese*
     - The page url is https://ci.apache.org/projects/flink/flink-docs-release-1.11/zh/monitoring/historyserver.html
     - The markdown file is located in flink/docs/monitoring/historyserver.zh.md
   
   
   ## Verifying this change
   
   *This change is a pure documentation translation.*
   
   
   ## Does this pull request potentially affect one of the following parts:
   
     - Dependencies (does it add or upgrade a dependency): no
     - The public API, i.e., is any changed class annotated with `@Public(Evolving)`: no
     - The serializers: no
     - The runtime per-record code paths (performance sensitive): no
     - Anything that affects deployment or recovery: JobManager (and its components), Checkpointing, Kubernetes/Yarn/Mesos, ZooKeeper: no
     - The S3 file system connector: no
   
   ## Documentation
   
     - Does this pull request introduce a new feature? no
     - If yes, how is the feature documented? no
   


----------------------------------------------------------------
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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758) 
   * 0371b8be3b5a368623bf8dc553f94fd57cf0c60e 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 a change in pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。

Review comment:
       ```suggestion
   此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并返回 JSON 格式的数据。
   ```

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:

Review comment:
       ```suggestion
   在配置 HistoryServer *和* JobManager 之后,你可以使用相应的脚本来启动和停止 HistoryServer:
   ```

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+目前,只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据归档路径和已归档作业刷新间隔进行调整。

Review comment:
       ```suggestion
   配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据存档路径和已存档作业刷新间隔进行调整。
   ```

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。

Review comment:
       ```suggestion
   默认情况下,此服务器绑定到 `localhost` 的 `8082` 端口。
   ```




----------------------------------------------------------------
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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "",
       "status" : "DELETED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878",
       "triggerID" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * b3602a770dcbc2c274ad64f858ed55d68b70039e Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783) 
   * 7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878) 
   
   <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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "CANCELED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54 Azure: [CANCELED](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758) 
   * 0371b8be3b5a368623bf8dc553f94fd57cf0c60e Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765) 
   
   <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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "FAILURE",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 0371b8be3b5a368623bf8dc553f94fd57cf0c60e Azure: [FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765) 
   
   <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 a change in pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,68 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并返回 JSON 格式的数据。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用相应的脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 的 `8082` 端口。
+
+目前,只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据`作业存档目录`和`刷新作业存档目录的时间间隔`进行调整。

Review comment:
       ```suggestion
   配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据 `作业存档目录` 和 `刷新作业存档目录的时间间隔` 进行调整。
   ```




----------------------------------------------------------------
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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。

Review comment:
       `并返回 JSON 格式的数据` 会好一些吗?

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:

Review comment:
       `你可以使用相应的脚本来启动和停止 HistoryServer` 会好一些吗?

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。

Review comment:
       “此服务器绑定到 `localhost` 的 `8082` 端口”  这样描述会好一些吗?

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+目前,只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据归档路径和已归档作业刷新间隔进行调整。

Review comment:
       `和已归档作业刷新间隔进行调整` 这里的描述可以看出意思,不过读起来有点点拗口,这里有更好的描述吗?或者看看其他人是否有更好的建议

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+目前,只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据归档路径和已归档作业刷新间隔进行调整。
 
 **JobManager**
 
-The archiving of completed jobs happens on the JobManager, which uploads the archived job information to a file system directory. You can configure the directory to archive completed jobs in `flink-conf.yaml` by setting a directory via `jobmanager.archive.fs.dir`.
+已完成作业的存档在 JobManager 上进行,将已存档的作业信息上传到文件系统目录中。你可以在 `flink-conf.yaml` 文件中通过 `jobmanager.archive.fs.dir` 设置一个目录存档已完成的作业。

Review comment:
       上面用 `归档`, 这里用了 `存档`,建议全文可以统一

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+目前,只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据归档路径和已归档作业刷新间隔进行调整。
 
 **JobManager**
 
-The archiving of completed jobs happens on the JobManager, which uploads the archived job information to a file system directory. You can configure the directory to archive completed jobs in `flink-conf.yaml` by setting a directory via `jobmanager.archive.fs.dir`.
+已完成作业的存档在 JobManager 上进行,将已存档的作业信息上传到文件系统目录中。你可以在 `flink-conf.yaml` 文件中通过 `jobmanager.archive.fs.dir` 设置一个目录存档已完成的作业。
 
 {% highlight yaml %}
-# Directory to upload completed job information
+# 上传已完成作业信息的目录
 jobmanager.archive.fs.dir: hdfs:///completed-jobs
 {% endhighlight %}
 
 **HistoryServer**
 
-The HistoryServer can be configured to monitor a comma-separated list of directories in via `historyserver.archive.fs.dir`. The configured directories are regularly polled for new archives; the polling interval can be configured via `historyserver.archive.fs.refresh-interval`.
+可以通过 `historyserver.archive.fs.dir` 设置 HistoryServer 监视以逗号分隔的目录列表。定期轮询已配置的目录以查找新的存档;轮询间隔可以通过 `historyserver.archive.fs.refresh-interval` 来配置。
 
 {% highlight yaml %}
-# Monitor the following directories for completed jobs
+# 监视以下目录中已完成的作业
 historyserver.archive.fs.dir: hdfs:///completed-jobs
 
-# Refresh every 10 seconds
+# 每 10 秒刷新一次
 historyserver.archive.fs.refresh-interval: 10000
 {% endhighlight %}
 
-The contained archives are downloaded and cached in the local filesystem. The local directory for this is configured via `historyserver.web.tmpdir`.
+所包含的存档被下载缓存在本地文件系统中。本地目录通过 `historyserver.web.tmpdir` 配置。
 
-Check out the configuration page for a [complete list of configuration options]({{ site.baseurl }}/ops/config.html#history-server).
+请查看配置页面以获取[配置选项的完整列表]({% link ops/config.zh.md %}#history-server)。
 
-## Available Requests
+<a name="available-requests"></a>
 
-Below is a list of available requests, with a sample JSON response. All requests are of the sample form `http://hostname:8082/jobs`, below we list only the *path* part of the URLs.
+## 可用的请求
 
-Values in angle brackets are variables, for example `http://hostname:port/jobs/<jobid>/exceptions` will have to requested for example as `http://hostname:port/jobs/7684be6004e4e955c2a558a9bc463f65/exceptions`.
+以下是可用且带有示例 JSON 响应的请求列表。所有请求格式样例均为 `http://hostname:8082/jobs`,下面我们仅列出了 URLs 的 *path* 部分。
+尖括号中的值是变量,例如 `http://hostname:port/jobs/<jobid>/exceptions` 将必须请求如 `http://hostname:port/jobs/7684be6004e4e955c2a558a9bc463f65/exceptions`。

Review comment:
       这句话读起来有些拗口,主要是后面的 ”将必须请求如 xxx“ 有更好的描述吗?




----------------------------------------------------------------
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 merged pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   


----------------------------------------------------------------
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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "",
       "status" : "DELETED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * b3602a770dcbc2c274ad64f858ed55d68b70039e Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783) 
   * 7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f 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 edited a comment on pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   @klion26 
   Thank you very much for your guidance and advices. I made some adjustments according to your suggestions.
   If you have free time, please have a look. Looking forward to your further 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] RocMarshal commented on a change in pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,69 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+当前,你只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据归档路径和已归档作业刷新间隔进行调整。
 
 **JobManager**
 
-The archiving of completed jobs happens on the JobManager, which uploads the archived job information to a file system directory. You can configure the directory to archive completed jobs in `flink-conf.yaml` by setting a directory via `jobmanager.archive.fs.dir`.
+已完成作业的存档在 JobManager 上进行,将已存档的作业信息上传到文件系统目录中。你可以在 `flink-conf.yaml` 文件中通过 `jobmanager.archive.fs.dir` 设置一个目录存档已完成的作业。
 
 {% highlight yaml %}
-# Directory to upload completed job information
+# 上传已完成作业信息的目录
 jobmanager.archive.fs.dir: hdfs:///completed-jobs
 {% endhighlight %}
 
 **HistoryServer**
 
-The HistoryServer can be configured to monitor a comma-separated list of directories in via `historyserver.archive.fs.dir`. The configured directories are regularly polled for new archives; the polling interval can be configured via `historyserver.archive.fs.refresh-interval`.
+可以通过 `historyserver.archive.fs.dir` 设置 HistoryServer 监视以逗号分隔的目录列表。定期轮询已配置的目录以查找新的存档;轮询间隔可以通过 `historyserver.archive.fs.refresh-interval` 来配置。
 
 {% highlight yaml %}
-# Monitor the following directories for completed jobs
+# 监视以下目录中已完成的作业
 historyserver.archive.fs.dir: hdfs:///completed-jobs
 
-# Refresh every 10 seconds
+# 每 10 秒刷新一次
 historyserver.archive.fs.refresh-interval: 10000
 {% endhighlight %}
 
-The contained archives are downloaded and cached in the local filesystem. The local directory for this is configured via `historyserver.web.tmpdir`.
+所包含的归档被下载并缓存在本地文件系统中。本地目录通过 `historyserver.web.tmpdir` 配置。
+
+请查看配置页面以获取[配置选项的完整列表]({% link ops/config.zh.md %}#history-server)。
 
-Check out the configuration page for a [complete list of configuration options]({{ site.baseurl }}/ops/config.html#history-server).
+<a name="available-requests"></a>
 
-## Available Requests
+## 可用的请求
 
-Below is a list of available requests, with a sample JSON response. All requests are of the sample form `http://hostname:8082/jobs`, below we list only the *path* part of the URLs.
+以下是可用并带有示例 JSON 响应的请求列表。所有请求都是示例表格 http://hostname:8082/jobs,我们在下面仅列出了URL 的路径部分。
+所有请求均为样本格式 `http://hostname:8082/jobs`,下面我们只列出了 URLs 的*路径*部分。
 

Review comment:
       ```suggestion
   ```

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,69 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+当前,你只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据归档路径和已归档作业刷新间隔进行调整。
 
 **JobManager**
 
-The archiving of completed jobs happens on the JobManager, which uploads the archived job information to a file system directory. You can configure the directory to archive completed jobs in `flink-conf.yaml` by setting a directory via `jobmanager.archive.fs.dir`.
+已完成作业的存档在 JobManager 上进行,将已存档的作业信息上传到文件系统目录中。你可以在 `flink-conf.yaml` 文件中通过 `jobmanager.archive.fs.dir` 设置一个目录存档已完成的作业。
 
 {% highlight yaml %}
-# Directory to upload completed job information
+# 上传已完成作业信息的目录
 jobmanager.archive.fs.dir: hdfs:///completed-jobs
 {% endhighlight %}
 
 **HistoryServer**
 
-The HistoryServer can be configured to monitor a comma-separated list of directories in via `historyserver.archive.fs.dir`. The configured directories are regularly polled for new archives; the polling interval can be configured via `historyserver.archive.fs.refresh-interval`.
+可以通过 `historyserver.archive.fs.dir` 设置 HistoryServer 监视以逗号分隔的目录列表。定期轮询已配置的目录以查找新的存档;轮询间隔可以通过 `historyserver.archive.fs.refresh-interval` 来配置。
 
 {% highlight yaml %}
-# Monitor the following directories for completed jobs
+# 监视以下目录中已完成的作业
 historyserver.archive.fs.dir: hdfs:///completed-jobs
 
-# Refresh every 10 seconds
+# 每 10 秒刷新一次
 historyserver.archive.fs.refresh-interval: 10000
 {% endhighlight %}
 
-The contained archives are downloaded and cached in the local filesystem. The local directory for this is configured via `historyserver.web.tmpdir`.
+所包含的归档被下载并缓存在本地文件系统中。本地目录通过 `historyserver.web.tmpdir` 配置。
+
+请查看配置页面以获取[配置选项的完整列表]({% link ops/config.zh.md %}#history-server)。
 
-Check out the configuration page for a [complete list of configuration options]({{ site.baseurl }}/ops/config.html#history-server).
+<a name="available-requests"></a>
 
-## Available Requests
+## 可用的请求
 
-Below is a list of available requests, with a sample JSON response. All requests are of the sample form `http://hostname:8082/jobs`, below we list only the *path* part of the URLs.
+以下是可用并带有示例 JSON 响应的请求列表。所有请求都是示例表格 http://hostname:8082/jobs,我们在下面仅列出了URL 的路径部分。
+所有请求均为样本格式 `http://hostname:8082/jobs`,下面我们只列出了 URLs 的*路径*部分。

Review comment:
       ```suggestion
   ```

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,69 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+当前,你只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据归档路径和已归档作业刷新间隔进行调整。
 
 **JobManager**
 
-The archiving of completed jobs happens on the JobManager, which uploads the archived job information to a file system directory. You can configure the directory to archive completed jobs in `flink-conf.yaml` by setting a directory via `jobmanager.archive.fs.dir`.
+已完成作业的存档在 JobManager 上进行,将已存档的作业信息上传到文件系统目录中。你可以在 `flink-conf.yaml` 文件中通过 `jobmanager.archive.fs.dir` 设置一个目录存档已完成的作业。
 
 {% highlight yaml %}
-# Directory to upload completed job information
+# 上传已完成作业信息的目录
 jobmanager.archive.fs.dir: hdfs:///completed-jobs
 {% endhighlight %}
 
 **HistoryServer**
 
-The HistoryServer can be configured to monitor a comma-separated list of directories in via `historyserver.archive.fs.dir`. The configured directories are regularly polled for new archives; the polling interval can be configured via `historyserver.archive.fs.refresh-interval`.
+可以通过 `historyserver.archive.fs.dir` 设置 HistoryServer 监视以逗号分隔的目录列表。定期轮询已配置的目录以查找新的存档;轮询间隔可以通过 `historyserver.archive.fs.refresh-interval` 来配置。
 
 {% highlight yaml %}
-# Monitor the following directories for completed jobs
+# 监视以下目录中已完成的作业
 historyserver.archive.fs.dir: hdfs:///completed-jobs
 
-# Refresh every 10 seconds
+# 每 10 秒刷新一次
 historyserver.archive.fs.refresh-interval: 10000
 {% endhighlight %}
 
-The contained archives are downloaded and cached in the local filesystem. The local directory for this is configured via `historyserver.web.tmpdir`.
+所包含的归档被下载并缓存在本地文件系统中。本地目录通过 `historyserver.web.tmpdir` 配置。

Review comment:
       ```suggestion
   所包含的存档被下载缓存在本地文件系统中。本地目录通过 `historyserver.web.tmpdir` 配置。
   ```

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,69 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+当前,你只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据归档路径和已归档作业刷新间隔进行调整。
 
 **JobManager**
 
-The archiving of completed jobs happens on the JobManager, which uploads the archived job information to a file system directory. You can configure the directory to archive completed jobs in `flink-conf.yaml` by setting a directory via `jobmanager.archive.fs.dir`.
+已完成作业的存档在 JobManager 上进行,将已存档的作业信息上传到文件系统目录中。你可以在 `flink-conf.yaml` 文件中通过 `jobmanager.archive.fs.dir` 设置一个目录存档已完成的作业。
 
 {% highlight yaml %}
-# Directory to upload completed job information
+# 上传已完成作业信息的目录
 jobmanager.archive.fs.dir: hdfs:///completed-jobs
 {% endhighlight %}
 
 **HistoryServer**
 
-The HistoryServer can be configured to monitor a comma-separated list of directories in via `historyserver.archive.fs.dir`. The configured directories are regularly polled for new archives; the polling interval can be configured via `historyserver.archive.fs.refresh-interval`.
+可以通过 `historyserver.archive.fs.dir` 设置 HistoryServer 监视以逗号分隔的目录列表。定期轮询已配置的目录以查找新的存档;轮询间隔可以通过 `historyserver.archive.fs.refresh-interval` 来配置。
 
 {% highlight yaml %}
-# Monitor the following directories for completed jobs
+# 监视以下目录中已完成的作业
 historyserver.archive.fs.dir: hdfs:///completed-jobs
 
-# Refresh every 10 seconds
+# 每 10 秒刷新一次
 historyserver.archive.fs.refresh-interval: 10000
 {% endhighlight %}
 
-The contained archives are downloaded and cached in the local filesystem. The local directory for this is configured via `historyserver.web.tmpdir`.
+所包含的归档被下载并缓存在本地文件系统中。本地目录通过 `historyserver.web.tmpdir` 配置。
+
+请查看配置页面以获取[配置选项的完整列表]({% link ops/config.zh.md %}#history-server)。
 
-Check out the configuration page for a [complete list of configuration options]({{ site.baseurl }}/ops/config.html#history-server).
+<a name="available-requests"></a>
 
-## Available Requests
+## 可用的请求
 
-Below is a list of available requests, with a sample JSON response. All requests are of the sample form `http://hostname:8082/jobs`, below we list only the *path* part of the URLs.
+以下是可用并带有示例 JSON 响应的请求列表。所有请求都是示例表格 http://hostname:8082/jobs,我们在下面仅列出了URL 的路径部分。

Review comment:
       ```suggestion
   以下是可用且带有示例 JSON 响应的请求列表。所有请求格式均为 `http://hostname:8082/jobs`,下面我们仅列出了 URLs 的 *path* 部分。
   ```

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,69 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+当前,你只能将 HistoryServer 作为独立的进程运行。

Review comment:
       ```suggestion
   目前,只能将 HistoryServer 作为独立的进程运行。
   ```




----------------------------------------------------------------
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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "",
       "status" : "DELETED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878",
       "triggerID" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "triggerType" : "PUSH"
     }, {
       "hash" : "573b789a5293888cc002892d481fdebfee8a7163",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "573b789a5293888cc002892d481fdebfee8a7163",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878) 
   * 573b789a5293888cc002892d481fdebfee8a7163 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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54 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 edited a comment on pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "",
       "status" : "DELETED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878",
       "triggerID" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878) 
   
   <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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   @klion26 
   Thank you very much for your guidance and advices. I made some adjustments according to your suggestions.
   If you have time, please have a look. Looking forward to your further 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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "",
       "status" : "DELETED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878",
       "triggerID" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "triggerType" : "PUSH"
     }, {
       "hash" : "573b789a5293888cc002892d481fdebfee8a7163",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "573b789a5293888cc002892d481fdebfee8a7163",
       "triggerType" : "PUSH"
     }, {
       "hash" : "c36cb4876c626b0d67048f0bd43381a2eab9fa60",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5893",
       "triggerID" : "c36cb4876c626b0d67048f0bd43381a2eab9fa60",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878) 
   * 573b789a5293888cc002892d481fdebfee8a7163 UNKNOWN
   * c36cb4876c626b0d67048f0bd43381a2eab9fa60 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5893) 
   
   <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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "",
       "status" : "DELETED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878",
       "triggerID" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "triggerType" : "PUSH"
     }, {
       "hash" : "573b789a5293888cc002892d481fdebfee8a7163",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "573b789a5293888cc002892d481fdebfee8a7163",
       "triggerType" : "PUSH"
     }, {
       "hash" : "c36cb4876c626b0d67048f0bd43381a2eab9fa60",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "c36cb4876c626b0d67048f0bd43381a2eab9fa60",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878) 
   * 573b789a5293888cc002892d481fdebfee8a7163 UNKNOWN
   * c36cb4876c626b0d67048f0bd43381a2eab9fa60 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 edited a comment on pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "",
       "status" : "CANCELED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   *  Unknown: [CANCELED](TBD) 
   * b3602a770dcbc2c274ad64f858ed55d68b70039e Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783) 
   
   <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] wuchong commented on pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   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 commented on pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   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 d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54 (Fri Aug 21 06:26:19 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] flinkbot edited a comment on pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758) 
   
   <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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "",
       "status" : "CANCELED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   *  Unknown: [CANCELED](TBD) 
   * b3602a770dcbc2c274ad64f858ed55d68b70039e 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 a change in pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,69 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用其相应的启动脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 并监听 `8082` 端口。
+
+当前,你只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据归档路径和已归档作业刷新间隔进行调整。
 
 **JobManager**
 
-The archiving of completed jobs happens on the JobManager, which uploads the archived job information to a file system directory. You can configure the directory to archive completed jobs in `flink-conf.yaml` by setting a directory via `jobmanager.archive.fs.dir`.
+已完成作业的存档在 JobManager 上进行,将已存档的作业信息上传到文件系统目录中。你可以在 `flink-conf.yaml` 文件中通过 `jobmanager.archive.fs.dir` 设置一个目录存档已完成的作业。
 
 {% highlight yaml %}
-# Directory to upload completed job information
+# 上传已完成作业信息的目录
 jobmanager.archive.fs.dir: hdfs:///completed-jobs
 {% endhighlight %}
 
 **HistoryServer**
 
-The HistoryServer can be configured to monitor a comma-separated list of directories in via `historyserver.archive.fs.dir`. The configured directories are regularly polled for new archives; the polling interval can be configured via `historyserver.archive.fs.refresh-interval`.
+可以通过 `historyserver.archive.fs.dir` 设置 HistoryServer 监视以逗号分隔的目录列表。定期轮询已配置的目录以查找新的存档;轮询间隔可以通过 `historyserver.archive.fs.refresh-interval` 来配置。
 
 {% highlight yaml %}
-# Monitor the following directories for completed jobs
+# 监视以下目录中已完成的作业
 historyserver.archive.fs.dir: hdfs:///completed-jobs
 
-# Refresh every 10 seconds
+# 每 10 秒刷新一次
 historyserver.archive.fs.refresh-interval: 10000
 {% endhighlight %}
 
-The contained archives are downloaded and cached in the local filesystem. The local directory for this is configured via `historyserver.web.tmpdir`.
+所包含的归档被下载并缓存在本地文件系统中。本地目录通过 `historyserver.web.tmpdir` 配置。
+
+请查看配置页面以获取[配置选项的完整列表]({% link ops/config.zh.md %}#history-server)。
 
-Check out the configuration page for a [complete list of configuration options]({{ site.baseurl }}/ops/config.html#history-server).
+<a name="available-requests"></a>
 
-## Available Requests
+## 可用的请求
 
-Below is a list of available requests, with a sample JSON response. All requests are of the sample form `http://hostname:8082/jobs`, below we list only the *path* part of the URLs.
+以下是可用并带有示例 JSON 响应的请求列表。所有请求都是示例表格 http://hostname:8082/jobs,我们在下面仅列出了URL 的路径部分。

Review comment:
       ```suggestion
   以下是可用且带有示例 JSON 响应的请求列表。所有请求格式样例均为 `http://hostname:8082/jobs`,下面我们仅列出了 URLs 的 *path* 部分。
   ```




----------------------------------------------------------------
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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   @flinkbot run azure


----------------------------------------------------------------
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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "",
       "status" : "DELETED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5878",
       "triggerID" : "7bc3859110ac2f7cbd589c06cd1b7fbb65aafd3f",
       "triggerType" : "PUSH"
     }, {
       "hash" : "573b789a5293888cc002892d481fdebfee8a7163",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "573b789a5293888cc002892d481fdebfee8a7163",
       "triggerType" : "PUSH"
     }, {
       "hash" : "c36cb4876c626b0d67048f0bd43381a2eab9fa60",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5893",
       "triggerID" : "c36cb4876c626b0d67048f0bd43381a2eab9fa60",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 573b789a5293888cc002892d481fdebfee8a7163 UNKNOWN
   * c36cb4876c626b0d67048f0bd43381a2eab9fa60 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5893) 
   
   <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 a change in pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并返回 JSON 格式的数据。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用相应的脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 的 `8082` 端口。
+
+目前,只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据存档路径和已存档作业刷新间隔进行调整。
 
 **JobManager**
 
-The archiving of completed jobs happens on the JobManager, which uploads the archived job information to a file system directory. You can configure the directory to archive completed jobs in `flink-conf.yaml` by setting a directory via `jobmanager.archive.fs.dir`.
+已完成作业的存档在 JobManager 上进行,将已存档的作业信息上传到文件系统目录中。你可以在 `flink-conf.yaml` 文件中通过 `jobmanager.archive.fs.dir` 设置一个目录存档已完成的作业。
 
 {% highlight yaml %}
-# Directory to upload completed job information
+# 上传已完成作业信息的目录
 jobmanager.archive.fs.dir: hdfs:///completed-jobs
 {% endhighlight %}
 
 **HistoryServer**
 
-The HistoryServer can be configured to monitor a comma-separated list of directories in via `historyserver.archive.fs.dir`. The configured directories are regularly polled for new archives; the polling interval can be configured via `historyserver.archive.fs.refresh-interval`.
+可以通过 `historyserver.archive.fs.dir` 设置 HistoryServer 监视以逗号分隔的目录列表。定期轮询已配置的目录以查找新的存档;轮询间隔可以通过 `historyserver.archive.fs.refresh-interval` 来配置。
 
 {% highlight yaml %}
-# Monitor the following directories for completed jobs
+# 监视以下目录中已完成的作业
 historyserver.archive.fs.dir: hdfs:///completed-jobs
 
-# Refresh every 10 seconds
+# 每 10 秒刷新一次
 historyserver.archive.fs.refresh-interval: 10000
 {% endhighlight %}
 
-The contained archives are downloaded and cached in the local filesystem. The local directory for this is configured via `historyserver.web.tmpdir`.
+所包含的存档被下载缓存在本地文件系统中。本地目录通过 `historyserver.web.tmpdir` 配置。
 
-Check out the configuration page for a [complete list of configuration options]({{ site.baseurl }}/ops/config.html#history-server).
+请查看配置页面以获取[配置选项的完整列表]({% link ops/config.zh.md %}#history-server)。
 
-## Available Requests
+<a name="available-requests"></a>
 
-Below is a list of available requests, with a sample JSON response. All requests are of the sample form `http://hostname:8082/jobs`, below we list only the *path* part of the URLs.
+## 可用的请求
 
-Values in angle brackets are variables, for example `http://hostname:port/jobs/<jobid>/exceptions` will have to requested for example as `http://hostname:port/jobs/7684be6004e4e955c2a558a9bc463f65/exceptions`.
+以下是可用且带有示例 JSON 响应的请求列表。所有请求格式样例均为 `http://hostname:8082/jobs`,下面我们仅列出了 URLs 的 *path* 部分。
+尖括号中的值是变量,例如 `http://hostname:port/jobs/<jobid>/exceptions` 将必须请求如 `http://hostname:port/jobs/7684be6004e4e955c2a558a9bc463f65/exceptions`。

Review comment:
       ```suggestion
   尖括号中的值为变量,例如作业 `7684be6004e4e955c2a558a9bc463f65` 的 
   `http://hostname:port/jobs/<jobid>/exceptions` 请求须写为 `http://hostname:port/jobs/7684be6004e4e955c2a558a9bc463f65/exceptions`。
   ```

##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,67 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并返回 JSON 格式的数据。
 
 * This will be replaced by the TOC
 {:toc}
 
-## Overview
+<a name="overview"></a>
 
-The HistoryServer allows you to query the status and statistics of completed jobs that have been archived by a JobManager.
+## 概览
 
-After you have configured the HistoryServer *and* JobManager, you start and stop the HistoryServer via its corresponding startup script:
+HistoryServer 允许查询 JobManager 存档的已完成作业的状态和统计信息。
+
+在配置 HistoryServer *和* JobManager 之后,你可以使用相应的脚本来启动和停止 HistoryServer:
 
 {% highlight shell %}
-# Start or stop the HistoryServer
+# 启动或者停止 HistoryServer
 bin/historyserver.sh (start|start-foreground|stop)
 {% endhighlight %}
 
-By default, this server binds to `localhost` and listens at port `8082`.
+默认情况下,此服务器绑定到 `localhost` 的 `8082` 端口。
+
+目前,只能将 HistoryServer 作为独立的进程运行。
 
-Currently, you can only run it as a standalone process.
+<a name="configuration"></a>
 
-## Configuration
+## 配置参数
 
-The configuration keys `jobmanager.archive.fs.dir` and `historyserver.archive.fs.refresh-interval` need to be adjusted for archiving and displaying archived jobs.
+配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据存档路径和已存档作业刷新间隔进行调整。

Review comment:
       ```suggestion
   配置项 `jobmanager.archive.fs.dir` 和 `historyserver.archive.fs.refresh-interval` 需要根据`作业存档目录`和`刷新作业存档目录的时间间隔`进行调整。
   ```




----------------------------------------------------------------
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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5758",
       "triggerID" : "d6b806b3c50e505b2e7fe0beef37a6efc9f0ae54",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5765",
       "triggerID" : "0371b8be3b5a368623bf8dc553f94fd57cf0c60e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     }, {
       "hash" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783",
       "triggerID" : "b3602a770dcbc2c274ad64f858ed55d68b70039e",
       "triggerType" : "PUSH"
     }, {
       "hash" : "",
       "status" : "DELETED",
       "url" : "TBD",
       "triggerID" : "678601215",
       "triggerType" : "MANUAL"
     } ]
   }-->
   ## CI report:
   
   * b3602a770dcbc2c274ad64f858ed55d68b70039e Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5783) 
   
   <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 #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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


   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] RocMarshal commented on a change in pull request #13212: [FLINK-18973][docs-zh] Translate the 'History Server' page of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/historyserver.zh.md
##########
@@ -22,62 +22,69 @@ specific language governing permissions and limitations
 under the License.
 -->
 
-Flink has a history server that can be used to query the statistics of completed jobs after the corresponding Flink cluster has been shut down.
+Flink 提供了 history server,可以在相应的 Flink 集群关闭之后查询已完成作业的统计信息。
 
-Furthermore, it exposes a REST API that accepts HTTP requests and responds with JSON data.
+此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据进行响应。

Review comment:
       ```suggestion
   此外,它暴露了一套 REST API,该 API 接受 HTTP 请求并以 JSON 数据格式进行响应。
   ```




----------------------------------------------------------------
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