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/25 04:38:08 UTC

[GitHub] [flink] RocMarshal opened a new pull request #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


   <!--
   *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 page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese*
   
   
   ## Brief change log
   
   *Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese*
     - The markdown file location: flink/docs/monitoring/application_profiling.zh.md
     - The page url is https://ci.apache.org/projects/flink/flink-docs-release-1.11/monitoring/application_profiling.html
   
   
   ## Verifying this change
   
   *A pure translation work in documentation module.*
   
   ## 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?  not applicable


----------------------------------------------------------------
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 #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


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


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

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



[GitHub] [flink] RocMarshal commented on pull request #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


   Hi @xccui 
   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 #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述
 
-## Profiling with Java Flight Recorder
+每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 后台进程都将 `stdout` 和 `stderr` 重定向到 `.out` 文件名后缀的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。
 
-Java Flight Recorder is a profiling and event collection framework built into the Oracle JDK.
-[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html)
-is an advanced set of tools that enables efficient and detailed analysis of the extensive of data collected by Java
-Flight Recorder. Example configuration:
+<a name="profiling-with-java-flight-recorder"></a>
+
+## 使用 Java Flight Recorder 分析
+
+Java Flight Recorder 是 Oracle JDK 内置的分析和事件收集框架。[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html) 是一套先进的工具,可以对 Java Flight Recorder 收集的大量数据进行高效和详细的分析。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockCommercialFeatures -XX:+UnlockDiagnosticVMOptions -XX:+FlightRecorder -XX:+DebugNonSafepoints -XX:FlightRecorderOptions=defaultrecording=true,dumponexit=true,dumponexitpath=${FLINK_LOG_PREFIX}.jfr"
 {% endhighlight %}
 
-## Profiling with JITWatch
+<a name="profiling-with-jitwatch"></a>
+
+## 使用 JITWatch 分析
 
-[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) is a log analyser and visualizer for the Java HotSpot JIT
-compiler used to inspect inlining decisions, hot methods, bytecode, and assembly. Example configuration:
+[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) Java HotSpot JIT 编译器的日志分析器和可视化工具,用于检查内联决策,热方法,字节码和汇编。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockDiagnosticVMOptions -XX:+TraceClassLoading -XX:+LogCompilation -XX:LogFile=${FLINK_LOG_PREFIX}.jit -XX:+PrintAssembly"
 {% endhighlight %}
 
-## Analyzing Out of Memory Problems
+<a name="analyzing-out-of-memory-problems"></a>
 
-If you encounter `OutOfMemoryExceptions` with your Flink application, then it is a good idea to enable heap dumps on out of memory errors.
+## 分析内存不足问题(Out of Memory Problems)

Review comment:
       ```suggestion
   ## 分析内存溢出问题(Out of Memory Problems)
   ```

##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述
 
-## Profiling with Java Flight Recorder
+每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 后台进程都将 `stdout` 和 `stderr` 重定向到 `.out` 文件名后缀的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。
 
-Java Flight Recorder is a profiling and event collection framework built into the Oracle JDK.
-[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html)
-is an advanced set of tools that enables efficient and detailed analysis of the extensive of data collected by Java
-Flight Recorder. Example configuration:
+<a name="profiling-with-java-flight-recorder"></a>
+
+## 使用 Java Flight Recorder 分析
+
+Java Flight Recorder 是 Oracle JDK 内置的分析和事件收集框架。[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html) 是一套先进的工具,可以对 Java Flight Recorder 收集的大量数据进行高效和详细的分析。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockCommercialFeatures -XX:+UnlockDiagnosticVMOptions -XX:+FlightRecorder -XX:+DebugNonSafepoints -XX:FlightRecorderOptions=defaultrecording=true,dumponexit=true,dumponexitpath=${FLINK_LOG_PREFIX}.jfr"
 {% endhighlight %}
 
-## Profiling with JITWatch
+<a name="profiling-with-jitwatch"></a>
+
+## 使用 JITWatch 分析
 
-[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) is a log analyser and visualizer for the Java HotSpot JIT
-compiler used to inspect inlining decisions, hot methods, bytecode, and assembly. Example configuration:
+[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) Java HotSpot JIT 编译器的日志分析器和可视化工具,用于检查内联决策,热方法,字节码和汇编。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockDiagnosticVMOptions -XX:+TraceClassLoading -XX:+LogCompilation -XX:LogFile=${FLINK_LOG_PREFIX}.jit -XX:+PrintAssembly"
 {% endhighlight %}
 
-## Analyzing Out of Memory Problems
+<a name="analyzing-out-of-memory-problems"></a>
 
-If you encounter `OutOfMemoryExceptions` with your Flink application, then it is a good idea to enable heap dumps on out of memory errors.
+## 分析内存不足问题(Out of Memory Problems)
+
+如果你的 Flink 应用程序遇到 `OutOfMemoryExceptions` ,那么启用在内存不足错误时堆转储是一个好主意。
 
 {% highlight yaml %}
 env.java.opts: "-XX:+HeapDumpOnOutOfMemoryError -XX:HeapDumpPath=${FLINK_LOG_PREFIX}.hprof"
 {% endhighlight %}
 
-The heap dump will allow you to analyze potential memory leaks in your user code.
-If the memory leak should be caused by Flink, then please reach out to the [dev mailing list](mailto:dev@flink.apache.org).
+堆转储将使你能够方便地分析用户代码中潜在的内存泄漏问题。如果内存泄漏是由 Flink 引起的,那么请联系[开发人员邮件列表](mailto:dev@flink.apache.org)。
+
+<a name="analyzing-memory--garbage-collection-behaviour"></a>
 
-## Analyzing Memory & Garbage Collection Behaviour
+## 分析内存和 Garbage Collection
 
-Memory usage and garbage collection can have a profound impact on your application.
-The effects can range from slight performance degradation to a complete cluster failure if the GC pauses are too long.
-If you want to better understand the memory and GC behaviour of your application, then you can enable memory logging on the `TaskManagers`.
+内存使用和 garbage collection 会对你的应用程序产生巨大的影响。如果 GC 停顿时间过长,其影响范围可能从轻微的性能下降到完全的集群故障。如果你想更好地理解应用程序的内存和 GC 行为,那么可以在 `TaskManagers` 上启用内存日志记录。
 
 {% highlight yaml %}
 taskmanager.debug.memory.log: true
 taskmanager.debug.memory.log-interval: 10000 // 10s interval
 {% endhighlight %}
 
-If you are interested in more detailed GC statistics, then you can activate the JVM's GC logging via:
+如果你对更详细的 GC 统计数据感兴趣,则可以通过以下方式激活 JVM 的 GC 日志记录:

Review comment:
       ```suggestion
   如果你想了解更详细的 GC 统计数据,可以通过以下方式激活 JVM 的 GC 日志记录:
   ```

##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述

Review comment:
       ```suggestion
   ## Apache Flink 自定义日志概述
   ```

##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述
 
-## Profiling with Java Flight Recorder
+每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 后台进程都将 `stdout` 和 `stderr` 重定向到 `.out` 文件名后缀的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。

Review comment:
       ```suggestion
   每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 守护进程都将 `stdout` 和 `stderr` 重定向到名称后缀为 `.out` 的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。
   ```

##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述
 
-## Profiling with Java Flight Recorder
+每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 后台进程都将 `stdout` 和 `stderr` 重定向到 `.out` 文件名后缀的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。
 
-Java Flight Recorder is a profiling and event collection framework built into the Oracle JDK.
-[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html)
-is an advanced set of tools that enables efficient and detailed analysis of the extensive of data collected by Java
-Flight Recorder. Example configuration:
+<a name="profiling-with-java-flight-recorder"></a>
+
+## 使用 Java Flight Recorder 分析
+
+Java Flight Recorder 是 Oracle JDK 内置的分析和事件收集框架。[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html) 是一套先进的工具,可以对 Java Flight Recorder 收集的大量数据进行高效和详细的分析。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockCommercialFeatures -XX:+UnlockDiagnosticVMOptions -XX:+FlightRecorder -XX:+DebugNonSafepoints -XX:FlightRecorderOptions=defaultrecording=true,dumponexit=true,dumponexitpath=${FLINK_LOG_PREFIX}.jfr"
 {% endhighlight %}
 
-## Profiling with JITWatch
+<a name="profiling-with-jitwatch"></a>
+
+## 使用 JITWatch 分析
 
-[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) is a log analyser and visualizer for the Java HotSpot JIT
-compiler used to inspect inlining decisions, hot methods, bytecode, and assembly. Example configuration:
+[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) Java HotSpot JIT 编译器的日志分析器和可视化工具,用于检查内联决策,热方法,字节码和汇编。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockDiagnosticVMOptions -XX:+TraceClassLoading -XX:+LogCompilation -XX:LogFile=${FLINK_LOG_PREFIX}.jit -XX:+PrintAssembly"
 {% endhighlight %}
 
-## Analyzing Out of Memory Problems
+<a name="analyzing-out-of-memory-problems"></a>
 
-If you encounter `OutOfMemoryExceptions` with your Flink application, then it is a good idea to enable heap dumps on out of memory errors.
+## 分析内存不足问题(Out of Memory Problems)
+
+如果你的 Flink 应用程序遇到 `OutOfMemoryExceptions` ,那么启用在内存不足错误时堆转储是一个好主意。
 
 {% highlight yaml %}
 env.java.opts: "-XX:+HeapDumpOnOutOfMemoryError -XX:HeapDumpPath=${FLINK_LOG_PREFIX}.hprof"
 {% endhighlight %}
 
-The heap dump will allow you to analyze potential memory leaks in your user code.
-If the memory leak should be caused by Flink, then please reach out to the [dev mailing list](mailto:dev@flink.apache.org).
+堆转储将使你能够方便地分析用户代码中潜在的内存泄漏问题。如果内存泄漏是由 Flink 引起的,那么请联系[开发人员邮件列表](mailto:dev@flink.apache.org)。
+
+<a name="analyzing-memory--garbage-collection-behaviour"></a>
 
-## Analyzing Memory & Garbage Collection Behaviour
+## 分析内存和 Garbage Collection
 
-Memory usage and garbage collection can have a profound impact on your application.
-The effects can range from slight performance degradation to a complete cluster failure if the GC pauses are too long.
-If you want to better understand the memory and GC behaviour of your application, then you can enable memory logging on the `TaskManagers`.
+内存使用和 garbage collection 会对你的应用程序产生巨大的影响。如果 GC 停顿时间过长,其影响范围可能从轻微的性能下降到完全的集群故障。如果你想更好地理解应用程序的内存和 GC 行为,那么可以在 `TaskManagers` 上启用内存日志记录。

Review comment:
       ```suggestion
   内存使用和 garbage collection 会对你的应用程序产生巨大的影响。如果 GC 停顿时间过长,其影响力小到性能下降,大到集群全面瘫痪。如果你想更好地理解应用程序的内存和 GC 行为,可以在 `TaskManagers` 上启用内存日志记录。
   ```




----------------------------------------------------------------
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 #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


   @xccui 
   Thank you so much for your help and suggestions. And I made some changes based on your comments.
   It's hoped it could somewhat improve further. 


----------------------------------------------------------------
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 #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## Apache Flink 自定义日志概述
 
-## Profiling with Java Flight Recorder
+每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 守护进程都将 `stdout` 和 `stderr` 重定向到名称后缀为 `.out` 的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。
 
-Java Flight Recorder is a profiling and event collection framework built into the Oracle JDK.
-[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html)
-is an advanced set of tools that enables efficient and detailed analysis of the extensive of data collected by Java
-Flight Recorder. Example configuration:
+<a name="profiling-with-java-flight-recorder"></a>
+
+## 使用 Java Flight Recorder 分析
+
+Java Flight Recorder 是 Oracle JDK 内置的分析和事件收集框架。[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html) 是一套先进的工具,可以对 Java Flight Recorder 收集的大量数据进行高效和详细的分析。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockCommercialFeatures -XX:+UnlockDiagnosticVMOptions -XX:+FlightRecorder -XX:+DebugNonSafepoints -XX:FlightRecorderOptions=defaultrecording=true,dumponexit=true,dumponexitpath=${FLINK_LOG_PREFIX}.jfr"
 {% endhighlight %}
 
-## Profiling with JITWatch
+<a name="profiling-with-jitwatch"></a>
+
+## 使用 JITWatch 分析
 
-[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) is a log analyser and visualizer for the Java HotSpot JIT
-compiler used to inspect inlining decisions, hot methods, bytecode, and assembly. Example configuration:
+[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) Java HotSpot JIT 编译器的日志分析器和可视化工具,用于检查内联决策,热方法,字节码和汇编。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockDiagnosticVMOptions -XX:+TraceClassLoading -XX:+LogCompilation -XX:LogFile=${FLINK_LOG_PREFIX}.jit -XX:+PrintAssembly"
 {% endhighlight %}
 
-## Analyzing Out of Memory Problems
+<a name="analyzing-out-of-memory-problems"></a>
 
-If you encounter `OutOfMemoryExceptions` with your Flink application, then it is a good idea to enable heap dumps on out of memory errors.
+## 分析内存溢出问题(Out of Memory Problems)
+
+如果你的 Flink 应用程序遇到 `OutOfMemoryExceptions` ,那么启用在内存不足错误时堆转储是一个好主意。

Review comment:
       ```suggestion
   如果你的 Flink 应用程序遇到 `OutOfMemoryExceptions` ,那么启用在内存溢出错误时堆转储是一个好主意。
   ```




----------------------------------------------------------------
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 #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "96c1c36cfd2ee8926f97dd48fa88d6fe3e0bdaba",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "96c1c36cfd2ee8926f97dd48fa88d6fe3e0bdaba",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 96c1c36cfd2ee8926f97dd48fa88d6fe3e0bdaba 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 #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "96c1c36cfd2ee8926f97dd48fa88d6fe3e0bdaba",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5839",
       "triggerID" : "96c1c36cfd2ee8926f97dd48fa88d6fe3e0bdaba",
       "triggerType" : "PUSH"
     }, {
       "hash" : "2375ec0fb6b8de2cffbb3fb8af54fe5b701353f4",
       "status" : "FAILURE",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=6021",
       "triggerID" : "2375ec0fb6b8de2cffbb3fb8af54fe5b701353f4",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 2375ec0fb6b8de2cffbb3fb8af54fe5b701353f4 Azure: [FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=6021) 
   
   <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] xccui commented on a change in pull request #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述
 
-## Profiling with Java Flight Recorder
+每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 后台进程都将 `stdout` 和 `stderr` 重定向到 `.out` 文件名后缀的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。
 
-Java Flight Recorder is a profiling and event collection framework built into the Oracle JDK.
-[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html)
-is an advanced set of tools that enables efficient and detailed analysis of the extensive of data collected by Java
-Flight Recorder. Example configuration:
+<a name="profiling-with-java-flight-recorder"></a>
+
+## 使用 Java Flight Recorder 分析
+
+Java Flight Recorder 是 Oracle JDK 内置的分析和事件收集框架。[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html) 是一套先进的工具,可以对 Java Flight Recorder 收集的大量数据进行高效和详细的分析。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockCommercialFeatures -XX:+UnlockDiagnosticVMOptions -XX:+FlightRecorder -XX:+DebugNonSafepoints -XX:FlightRecorderOptions=defaultrecording=true,dumponexit=true,dumponexitpath=${FLINK_LOG_PREFIX}.jfr"
 {% endhighlight %}
 
-## Profiling with JITWatch
+<a name="profiling-with-jitwatch"></a>
+
+## 使用 JITWatch 分析
 
-[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) is a log analyser and visualizer for the Java HotSpot JIT
-compiler used to inspect inlining decisions, hot methods, bytecode, and assembly. Example configuration:
+[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) Java HotSpot JIT 编译器的日志分析器和可视化工具,用于检查内联决策,热方法,字节码和汇编。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockDiagnosticVMOptions -XX:+TraceClassLoading -XX:+LogCompilation -XX:LogFile=${FLINK_LOG_PREFIX}.jit -XX:+PrintAssembly"
 {% endhighlight %}
 
-## Analyzing Out of Memory Problems
+<a name="analyzing-out-of-memory-problems"></a>
 
-If you encounter `OutOfMemoryExceptions` with your Flink application, then it is a good idea to enable heap dumps on out of memory errors.
+## 分析内存不足问题(Out of Memory Problems)
+
+如果你的 Flink 应用程序遇到 `OutOfMemoryExceptions` ,那么启用在内存不足错误时堆转储是一个好主意。
 
 {% highlight yaml %}
 env.java.opts: "-XX:+HeapDumpOnOutOfMemoryError -XX:HeapDumpPath=${FLINK_LOG_PREFIX}.hprof"
 {% endhighlight %}
 
-The heap dump will allow you to analyze potential memory leaks in your user code.
-If the memory leak should be caused by Flink, then please reach out to the [dev mailing list](mailto:dev@flink.apache.org).
+堆转储将使你能够方便地分析用户代码中潜在的内存泄漏问题。如果内存泄漏是由 Flink 引起的,那么请联系[开发人员邮件列表](mailto:dev@flink.apache.org)。
+
+<a name="analyzing-memory--garbage-collection-behaviour"></a>
 
-## Analyzing Memory & Garbage Collection Behaviour
+## 分析内存和 Garbage Collection
 
-Memory usage and garbage collection can have a profound impact on your application.
-The effects can range from slight performance degradation to a complete cluster failure if the GC pauses are too long.
-If you want to better understand the memory and GC behaviour of your application, then you can enable memory logging on the `TaskManagers`.
+内存使用和 garbage collection 会对你的应用程序产生巨大的影响。如果 GC 停顿时间过长,其影响范围可能从轻微的性能下降到完全的集群故障。如果你想更好地理解应用程序的内存和 GC 行为,那么可以在 `TaskManagers` 上启用内存日志记录。
 
 {% highlight yaml %}
 taskmanager.debug.memory.log: true
 taskmanager.debug.memory.log-interval: 10000 // 10s interval
 {% endhighlight %}
 
-If you are interested in more detailed GC statistics, then you can activate the JVM's GC logging via:
+如果你对更详细的 GC 统计数据感兴趣,则可以通过以下方式激活 JVM 的 GC 日志记录:

Review comment:
       * 如果你对更详细的 GC 统计数据感兴趣 -> 如果你想了解更详细的 GC 统计数据
   * ~~则~~




----------------------------------------------------------------
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 #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


   @wuchong 
   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 removed a comment on pull request #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


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


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

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



[GitHub] [flink] flinkbot edited a comment on pull request #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


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

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "96c1c36cfd2ee8926f97dd48fa88d6fe3e0bdaba",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5839",
       "triggerID" : "96c1c36cfd2ee8926f97dd48fa88d6fe3e0bdaba",
       "triggerType" : "PUSH"
     }, {
       "hash" : "2375ec0fb6b8de2cffbb3fb8af54fe5b701353f4",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=6021",
       "triggerID" : "2375ec0fb6b8de2cffbb3fb8af54fe5b701353f4",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * 96c1c36cfd2ee8926f97dd48fa88d6fe3e0bdaba Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=5839) 
   * 2375ec0fb6b8de2cffbb3fb8af54fe5b701353f4 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=6021) 
   
   <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] dianfu closed pull request #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

Posted by GitBox <gi...@apache.org>.
dianfu closed pull request #13235:
URL: https://github.com/apache/flink/pull/13235


   


----------------------------------------------------------------
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] xccui commented on a change in pull request #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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



##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述
 
-## Profiling with Java Flight Recorder
+每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 后台进程都将 `stdout` 和 `stderr` 重定向到 `.out` 文件名后缀的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。

Review comment:
       * 后台进程 -> 守护进程
   * `.out` 文件名后缀的文件 -> 名称后缀为 `.out`的文件

##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述
 
-## Profiling with Java Flight Recorder
+每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 后台进程都将 `stdout` 和 `stderr` 重定向到 `.out` 文件名后缀的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。
 
-Java Flight Recorder is a profiling and event collection framework built into the Oracle JDK.
-[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html)
-is an advanced set of tools that enables efficient and detailed analysis of the extensive of data collected by Java
-Flight Recorder. Example configuration:
+<a name="profiling-with-java-flight-recorder"></a>
+
+## 使用 Java Flight Recorder 分析
+
+Java Flight Recorder 是 Oracle JDK 内置的分析和事件收集框架。[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html) 是一套先进的工具,可以对 Java Flight Recorder 收集的大量数据进行高效和详细的分析。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockCommercialFeatures -XX:+UnlockDiagnosticVMOptions -XX:+FlightRecorder -XX:+DebugNonSafepoints -XX:FlightRecorderOptions=defaultrecording=true,dumponexit=true,dumponexitpath=${FLINK_LOG_PREFIX}.jfr"
 {% endhighlight %}
 
-## Profiling with JITWatch
+<a name="profiling-with-jitwatch"></a>
+
+## 使用 JITWatch 分析
 
-[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) is a log analyser and visualizer for the Java HotSpot JIT
-compiler used to inspect inlining decisions, hot methods, bytecode, and assembly. Example configuration:
+[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) Java HotSpot JIT 编译器的日志分析器和可视化工具,用于检查内联决策,热方法,字节码和汇编。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockDiagnosticVMOptions -XX:+TraceClassLoading -XX:+LogCompilation -XX:LogFile=${FLINK_LOG_PREFIX}.jit -XX:+PrintAssembly"
 {% endhighlight %}
 
-## Analyzing Out of Memory Problems
+<a name="analyzing-out-of-memory-problems"></a>
 
-If you encounter `OutOfMemoryExceptions` with your Flink application, then it is a good idea to enable heap dumps on out of memory errors.
+## 分析内存不足问题(Out of Memory Problems)

Review comment:
       内存不足 -> 内存溢出

##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述

Review comment:
       ~~使用~~

##########
File path: docs/monitoring/application_profiling.zh.md
##########
@@ -25,58 +25,56 @@ under the License.
 * ToC
 {:toc}
 
-## Overview of Custom Logging with Apache Flink
+<a name="overview-of-custom-logging-with-apache-flink"></a>
 
-Each standalone JobManager, TaskManager, HistoryServer, and ZooKeeper daemon redirects `stdout` and `stderr` to a file
-with a `.out` filename suffix and writes internal logging to a file with a `.log` suffix. Java options configured by the
-user in `env.java.opts`, `env.java.opts.jobmanager`, `env.java.opts.taskmanager`, `env.java.opts.historyserver` and
-`env.java.opts.client` can likewise define log files with
-use of the script variable `FLINK_LOG_PREFIX` and by enclosing the options in double quotes for late evaluation. Log files
-using `FLINK_LOG_PREFIX` are rotated along with the default `.out` and `.log` files.
+## 使用 Apache Flink 自定义日志概述
 
-## Profiling with Java Flight Recorder
+每个独立的 JobManager,TaskManager,HistoryServer,ZooKeeper 后台进程都将 `stdout` 和 `stderr` 重定向到 `.out` 文件名后缀的文件,并将其内部的日志记录写入到 `.log` 后缀的文件。用户可以在 `env.java.opts`,`env.java.opts.jobmanager`,`env.java.opts.taskmanager`,`env.java.opts.historyserver` 和 `env.java.opts.client` 配置项中配置 Java 选项(包括 log 相关的选项),同样也可以使用脚本变量 `FLINK_LOG_PREFIX` 定义日志文件,并将选项括在双引号中以供后期使用。日志文件将使用 `FLINK_LOG_PREFIX` 与默认的 `.out` 和 `.log` 后缀一起滚动。
 
-Java Flight Recorder is a profiling and event collection framework built into the Oracle JDK.
-[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html)
-is an advanced set of tools that enables efficient and detailed analysis of the extensive of data collected by Java
-Flight Recorder. Example configuration:
+<a name="profiling-with-java-flight-recorder"></a>
+
+## 使用 Java Flight Recorder 分析
+
+Java Flight Recorder 是 Oracle JDK 内置的分析和事件收集框架。[Java Mission Control](http://www.oracle.com/technetwork/java/javaseproducts/mission-control/java-mission-control-1998576.html) 是一套先进的工具,可以对 Java Flight Recorder 收集的大量数据进行高效和详细的分析。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockCommercialFeatures -XX:+UnlockDiagnosticVMOptions -XX:+FlightRecorder -XX:+DebugNonSafepoints -XX:FlightRecorderOptions=defaultrecording=true,dumponexit=true,dumponexitpath=${FLINK_LOG_PREFIX}.jfr"
 {% endhighlight %}
 
-## Profiling with JITWatch
+<a name="profiling-with-jitwatch"></a>
+
+## 使用 JITWatch 分析
 
-[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) is a log analyser and visualizer for the Java HotSpot JIT
-compiler used to inspect inlining decisions, hot methods, bytecode, and assembly. Example configuration:
+[JITWatch](https://github.com/AdoptOpenJDK/jitwatch/wiki) Java HotSpot JIT 编译器的日志分析器和可视化工具,用于检查内联决策,热方法,字节码和汇编。配置示例:
 
 {% highlight yaml %}
 env.java.opts: "-XX:+UnlockDiagnosticVMOptions -XX:+TraceClassLoading -XX:+LogCompilation -XX:LogFile=${FLINK_LOG_PREFIX}.jit -XX:+PrintAssembly"
 {% endhighlight %}
 
-## Analyzing Out of Memory Problems
+<a name="analyzing-out-of-memory-problems"></a>
 
-If you encounter `OutOfMemoryExceptions` with your Flink application, then it is a good idea to enable heap dumps on out of memory errors.
+## 分析内存不足问题(Out of Memory Problems)
+
+如果你的 Flink 应用程序遇到 `OutOfMemoryExceptions` ,那么启用在内存不足错误时堆转储是一个好主意。
 
 {% highlight yaml %}
 env.java.opts: "-XX:+HeapDumpOnOutOfMemoryError -XX:HeapDumpPath=${FLINK_LOG_PREFIX}.hprof"
 {% endhighlight %}
 
-The heap dump will allow you to analyze potential memory leaks in your user code.
-If the memory leak should be caused by Flink, then please reach out to the [dev mailing list](mailto:dev@flink.apache.org).
+堆转储将使你能够方便地分析用户代码中潜在的内存泄漏问题。如果内存泄漏是由 Flink 引起的,那么请联系[开发人员邮件列表](mailto:dev@flink.apache.org)。
+
+<a name="analyzing-memory--garbage-collection-behaviour"></a>
 
-## Analyzing Memory & Garbage Collection Behaviour
+## 分析内存和 Garbage Collection
 
-Memory usage and garbage collection can have a profound impact on your application.
-The effects can range from slight performance degradation to a complete cluster failure if the GC pauses are too long.
-If you want to better understand the memory and GC behaviour of your application, then you can enable memory logging on the `TaskManagers`.
+内存使用和 garbage collection 会对你的应用程序产生巨大的影响。如果 GC 停顿时间过长,其影响范围可能从轻微的性能下降到完全的集群故障。如果你想更好地理解应用程序的内存和 GC 行为,那么可以在 `TaskManagers` 上启用内存日志记录。

Review comment:
       * 其影响范围可能从轻微的性能下降到完全的集群故障 -> 其影响力小到性能下降,大到集群全面瘫痪
   * ~~那么~~




----------------------------------------------------------------
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 #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


   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 96c1c36cfd2ee8926f97dd48fa88d6fe3e0bdaba (Tue Aug 25 04:40:09 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 #13235: [FLINK-19036][docs-zh] Translate page 'Application Profiling & Debugging' of 'Debugging & Monitoring' into Chinese

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


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

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


   ping @wuchong @dianfu @alpinegizmo 


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