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 2021/10/30 08:57:03 UTC

[GitHub] [flink] GOODBOY008 opened a new pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

GOODBOY008 opened a new pull request #16627:
URL: https://github.com/apache/flink/pull/16627


   …uffle" into Chinese
   
   <!--
   *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 internal page "https://ci.apache.org/projects/flink/flink-docs-master/zh/docs/ops/batch/blocking_shuffle/" into Chinese.
   
   The doc located in "flink/docs/content.zh/docs/ops/batch/blocking_shuffle.md"
   
   ## Brief change log
   
   Translate  the doc located in "flink/docs/content.zh/docs/ops/batch/blocking_shuffle.md"
   
   ## Verifying this change
   
   This change is a trivial rework / code cleanup without any test coverage.
   
   ## 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, ZooKeeper: (no )
     - The S3 file system connector: (no)
   
   ## Documentation
   
     - Does this pull request introduce a new feature? (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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] GOODBOY008 commented on a change in pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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



##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink 在使用 [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持批处理执行模式,这用于任务处理有界输入流。使用此模式通过 blocking shuffle 来网络传输。不同于在流式应用使用管道 shuffle,阻塞交换的数据并存储.然后下游任务通过网络获取这些值。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 

Review comment:
       "不同于在流式应用使用管道 shuffle,阻塞交换的数据并存储.然后下游任务通过网络获取这些值。"->"与流式应用使用管道 shuffle 阻塞交换的数据并存储,然后下游任务通过网络获取这些值的方式不同。"




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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] gaoyunhaii commented on a change in pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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



##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持通过批处理执行模式处理有界输入。此模式是通过 blocking shuffle 进行网络传输。与流式应用使用管道 shuffle 阻塞交换的数据并存储,然后下游任务通过网络获取这些值的方式不同。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+总的来说,Flink 提供了两种不同类型的 blocking shuffles ; `Hash shuffle` 和 `Sort shuffle`。

Review comment:
       `;` -> `:` ?

##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持通过批处理执行模式处理有界输入。此模式是通过 blocking shuffle 进行网络传输。与流式应用使用管道 shuffle 阻塞交换的数据并存储,然后下游任务通过网络获取这些值的方式不同。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+总的来说,Flink 提供了两种不同类型的 blocking shuffles ; `Hash shuffle` 和 `Sort shuffle`。
 
-They will be detailed in the following sections.
+在下面章节会详细说明它们。
 
 ## Hash Shuffle
 
-The default blocking shuffle implementation, `Hash Shuffle`, has each upstream task persist its results in a separate file for each downstream task on the local disk of the TaskManager. When the downstream tasks run, they will request partitions from the upstream TaskManager's, which read the files and transmit data via the network.
+`Hash Shuffle` 是 blocking shuffle 的默认实现,它为每个下游任务将每个上游任务的结果以单独文件的方式保存在 TaskManager 本地磁盘上。当下游任务运行时会向上游的 TaskManager 请求分片,TaskManager 读取文件之后通过网络传输(给下游任务)。
 
-`Hash Shuffle` provides different mechanisms for writing and reading files:
+`Hash Shuffle` 为读写文件提供了不同的机制:
 
-- `file`: Writes files with the normal File IO, reads and transmits files with Netty `FileRegion`. `FileRegion` relies on `sendfile` system call to reduce the number of data copies and memory consumption.
-- `mmap`: Writes and reads files with `mmap` system call.
-- `Auto`: Writes files with the normal File IO, for file reading, it falls back to normal `file` option on 32 bit machine and use `mmap` on 64 bit machine. This is to avoid file size limitation of java `mmap` implementation on 32 bit machine.
+- `file`: 通过标准文件 IO 写文件,读取和传输文件需要通过 Netty 的 `FileRegion`。`FileRegion` 依靠系统调用 `sendfile` 来减少数据拷贝和内存消耗。
+- `mmap`: 通过系统调用 `mmap` 来读写文件。
+- `Auto`: 通过标准文件 IO 写文件,对于文件读取,在 32 位机器上降级到 `file` 选项并且在 64 位机器上使用 `mmap` 。这是为了避免在 32 位机器上 java 实现 `mmap` 的文件大小限制。
 
-The different mechanism could be chosen via [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}).
+可通过设置 [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}) 选择不同的机制。
 
 {{< hint warning >}}
-This option is experimental and might be changed future.
+这个选项是实验性的,将来或许会有改动。
 {{< /hint >}}
 
 {{< hint warning >}}
-If [SSL]({{< ref "docs/deployment/security/security-ssl" >}}) is enabled, the `file` mechanism can not use `FileRegion` and instead uses an un-pooled buffer to cache data before transmitting. This might [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981). Additionally, since the synchronous file reading might block Netty threads for some time, the [SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) needs to be increased to avoid [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416).
+如果开启 [SSL]({{< ref "docs/deployment/security/security-ssl" >}}),`file` 机制不能使用 `FileRegion` 而是在传输之前使用非池化的缓存去缓存数据。这可能会 [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981)。此外,因为同步读取文件有时会造成 netty 线程阻塞,[SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) 配置需要调大以防 [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416)。
 {{< /hint >}}
 
 {{< hint info >}}
-The memory usage of `mmap` is not accounted for by configured memory limits, but some resource frameworks like Yarn will track this memory usage and kill the container if memory exceeds some threshold.
+`mmap`使用的内存不计算进已有配置的内存限制中,但是一些资源管理框架比如 yarn 将追踪这块内存使用,并且如果容器使用内存超过阈值会被杀掉。
 {{< /hint >}}
 
-To further improve the performance, for most jobs we also recommend [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) unless the data is hard to compress.
+为了进一步的提升性能,对于绝大多数的任务我们推荐 [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) 除非数据很难被压缩。
 
-`Hash Shuffle` works well for small scale jobs with SSD, but it also have some disadvantages:
+`Hash Shuffle` 在小规模运行在固态硬盘的任务情况下效果显著,但是依旧有一些问题:
 
-1. If the job scale is large, it might create too many files, and it requires a large write buffer to write these files at the same time.
-2. On HDD, when multiple downstream tasks fetch their data simultaneously, it might incur the issue of random IO.
+1. 如果任务的规模庞大将会创建很多文件,并且要求同时对这些文件进行大量的写操作。
+2. 在机械硬盘情况下,当大量的下游任务同时读取数据,可能会导致随机读写问题。
 
 ## Sort Shuffle
 
-`Sort Shuffle` is another blocking shuffle implementation introduced in version 1.13. Different from `Hash Shuffle`, sort shuffle writes only one file for each result partition. When the result partition is read by multiple downstream tasks concurrently, the data file is opened only once and shared by all readers. As a result, the cluster uses fewer resources like inode and file descriptors, which improves stability. Furthermore, by writing fewer files and making a best effort to read data sequentially, sort shuffle can achieve better performance than hash shuffle, especially on HDD. Additionally, `sort shuffle` uses extra managed memory as data reading buffer and does not rely on `sendfile` or `mmap` mechanism, thus it also works well with [SSL]({{< ref "docs/deployment/security/security-ssl" >}}). Please refer to [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) and [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614) for more details about sort shuffle.
+`Sort Shuffle` 是 1.13 版中引入的另一种 blocking shuffle 实现。不同于 `Hash Shuffle`,sort shuffle 将每个分区结果写入到一个文件。当多个下游任务同时读取结果分片,数据文件只会被打开一次并共享给所有的读请求。因此,集群使用更少的资源。例如:节点和文件描述符以提升稳定性。此外,通过写更少的文件和尽可能线性的读取文件,尤其是在使用机械硬盘情况下 sort shuffle 可以获得比 hash shuffle 更好的性能。另外,`sort shuffle` 使用额外管理的内存作为读数据缓存并不依赖 `sendfile` 或 `mmap` 机制,因此也适用于 [SSL]({{< ref "docs/deployment/security/security-ssl" >}})。关于 sort shuffle 的更多细节请参考 [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) 和 [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614)。
 
-There are several config options that might need adjustment when using sort blocking shuffle:
-- [taskmanager.network.blocking-shuffle.compression.enabled]({{< ref "docs/deployment/config" >}}#taskmanager-network-blocking-shuffle-compression-enabled): Config option for shuffle data compression. it is suggested to enable it for most jobs except that the compression ratio of your data is low.
-- [taskmanager.network.sort-shuffle.min-parallelism]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-parallelism): Config option to enable sort shuffle depending on the parallelism of downstream tasks. If parallelism is lower than the configured value, `hash shuffle` will be used, otherwise `sort shuffle` will be used.
-- [taskmanager.network.sort-shuffle.min-buffers]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-buffers): Config option to control data writing buffer size. For large scale jobs, you may need to increase this value, usually, several hundreds of megabytes memory is enough.
-- [taskmanager.memory.framework.off-heap.batch-shuffle.size]({{< ref "docs/deployment/config" >}}#taskmanager-memory-framework-off-heap-batch-shuffle-size): Config option to control data reading buffer size. For large scale jobs, you may need to increase this value, usually, several hundreds of megabytes memory is enough.
+当使用sort blocking shuffle的时候有些配置需要适配:
+- [taskmanager.network.blocking-shuffle.compression.enabled]({{< ref "docs/deployment/config" >}}#taskmanager-network-blocking-shuffle-compression-enabled): 配置该选项以启用 shuffle data 压缩,大部分任务建议开启除非你的数据压缩比率比较低。
+- [taskmanager.network.sort-shuffle.min-parallelism]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-parallelism): 根据下游任务的并行度配置该选项以启用 sort shuffle。如果并行度低于设置的值,则使用 `hash shuffle`,否则 `sort shuffle`。
+- [taskmanager.network.sort-shuffle.min-buffers]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-buffers): 配置该选项以控制数据写缓存大小。对于大规模的任务而言,你可能需要调大这个值,正常几百兆内存就足够了。
+- [taskmanager.memory.framework.off-heap.batch-shuffle.size]({{< ref "docs/deployment/config" >}}#taskmanager-memory-framework-off-heap-batch-shuffle-size): 配置该选项以控制数据读取缓存大小。对于大规模的任务而言,你可能需要调大这个值,正常几百兆内存就足够了。
 
 {{< hint info >}}
-Currently `sort shuffle` only sort records by partition index instead of the records themselves, that is to say, the `sort` is only used as a data clustering algorithm.
+目前 `sort shuffle` 只通过分区索引来排序而不是记录本身,也就是说 `sort` 只是被当成数据聚类算法使用。
 {{< /hint >}}
 
-## Choices of Blocking Shuffle
+## 如何选择 Blocking Shuffle
 
-As a summary,
+总结,

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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * a4b275ac26d19b38e9b723ee51532ca3b58b19b8 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125) 
   
   <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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   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 bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 (Sat Aug 28 13:06:22 UTC 2021)
   
   **Warnings:**
    * No documentation files were touched! Remember to keep the Flink docs up to date!
   
   
   <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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] wuchong commented on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


    @gaoyunhaii could you help to review this? I think you should be familiar with this part as you contributed the original English docs. 


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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] gaoyunhaii commented on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   Very thanks for the update! I'll have a look as soon as possible~


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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] gaoyunhaii commented on a change in pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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



##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持通过批处理执行模式处理有界输入。此模式是通过 blocking shuffle 进行网络传输。与流式应用使用管道 shuffle 阻塞交换的数据并存储,然后下游任务通过网络获取这些值的方式不同。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+总的来说,Flink 提供了两种不同类型的 blocking shuffles ; `Hash shuffle` 和 `Sort shuffle`。

Review comment:
       `;` -> `:` ?

##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持通过批处理执行模式处理有界输入。此模式是通过 blocking shuffle 进行网络传输。与流式应用使用管道 shuffle 阻塞交换的数据并存储,然后下游任务通过网络获取这些值的方式不同。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+总的来说,Flink 提供了两种不同类型的 blocking shuffles ; `Hash shuffle` 和 `Sort shuffle`。
 
-They will be detailed in the following sections.
+在下面章节会详细说明它们。
 
 ## Hash Shuffle
 
-The default blocking shuffle implementation, `Hash Shuffle`, has each upstream task persist its results in a separate file for each downstream task on the local disk of the TaskManager. When the downstream tasks run, they will request partitions from the upstream TaskManager's, which read the files and transmit data via the network.
+`Hash Shuffle` 是 blocking shuffle 的默认实现,它为每个下游任务将每个上游任务的结果以单独文件的方式保存在 TaskManager 本地磁盘上。当下游任务运行时会向上游的 TaskManager 请求分片,TaskManager 读取文件之后通过网络传输(给下游任务)。
 
-`Hash Shuffle` provides different mechanisms for writing and reading files:
+`Hash Shuffle` 为读写文件提供了不同的机制:
 
-- `file`: Writes files with the normal File IO, reads and transmits files with Netty `FileRegion`. `FileRegion` relies on `sendfile` system call to reduce the number of data copies and memory consumption.
-- `mmap`: Writes and reads files with `mmap` system call.
-- `Auto`: Writes files with the normal File IO, for file reading, it falls back to normal `file` option on 32 bit machine and use `mmap` on 64 bit machine. This is to avoid file size limitation of java `mmap` implementation on 32 bit machine.
+- `file`: 通过标准文件 IO 写文件,读取和传输文件需要通过 Netty 的 `FileRegion`。`FileRegion` 依靠系统调用 `sendfile` 来减少数据拷贝和内存消耗。
+- `mmap`: 通过系统调用 `mmap` 来读写文件。
+- `Auto`: 通过标准文件 IO 写文件,对于文件读取,在 32 位机器上降级到 `file` 选项并且在 64 位机器上使用 `mmap` 。这是为了避免在 32 位机器上 java 实现 `mmap` 的文件大小限制。
 
-The different mechanism could be chosen via [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}).
+可通过设置 [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}) 选择不同的机制。
 
 {{< hint warning >}}
-This option is experimental and might be changed future.
+这个选项是实验性的,将来或许会有改动。
 {{< /hint >}}
 
 {{< hint warning >}}
-If [SSL]({{< ref "docs/deployment/security/security-ssl" >}}) is enabled, the `file` mechanism can not use `FileRegion` and instead uses an un-pooled buffer to cache data before transmitting. This might [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981). Additionally, since the synchronous file reading might block Netty threads for some time, the [SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) needs to be increased to avoid [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416).
+如果开启 [SSL]({{< ref "docs/deployment/security/security-ssl" >}}),`file` 机制不能使用 `FileRegion` 而是在传输之前使用非池化的缓存去缓存数据。这可能会 [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981)。此外,因为同步读取文件有时会造成 netty 线程阻塞,[SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) 配置需要调大以防 [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416)。
 {{< /hint >}}
 
 {{< hint info >}}
-The memory usage of `mmap` is not accounted for by configured memory limits, but some resource frameworks like Yarn will track this memory usage and kill the container if memory exceeds some threshold.
+`mmap`使用的内存不计算进已有配置的内存限制中,但是一些资源管理框架比如 yarn 将追踪这块内存使用,并且如果容器使用内存超过阈值会被杀掉。
 {{< /hint >}}
 
-To further improve the performance, for most jobs we also recommend [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) unless the data is hard to compress.
+为了进一步的提升性能,对于绝大多数的任务我们推荐 [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) 除非数据很难被压缩。
 
-`Hash Shuffle` works well for small scale jobs with SSD, but it also have some disadvantages:
+`Hash Shuffle` 在小规模运行在固态硬盘的任务情况下效果显著,但是依旧有一些问题:
 
-1. If the job scale is large, it might create too many files, and it requires a large write buffer to write these files at the same time.
-2. On HDD, when multiple downstream tasks fetch their data simultaneously, it might incur the issue of random IO.
+1. 如果任务的规模庞大将会创建很多文件,并且要求同时对这些文件进行大量的写操作。
+2. 在机械硬盘情况下,当大量的下游任务同时读取数据,可能会导致随机读写问题。
 
 ## Sort Shuffle
 
-`Sort Shuffle` is another blocking shuffle implementation introduced in version 1.13. Different from `Hash Shuffle`, sort shuffle writes only one file for each result partition. When the result partition is read by multiple downstream tasks concurrently, the data file is opened only once and shared by all readers. As a result, the cluster uses fewer resources like inode and file descriptors, which improves stability. Furthermore, by writing fewer files and making a best effort to read data sequentially, sort shuffle can achieve better performance than hash shuffle, especially on HDD. Additionally, `sort shuffle` uses extra managed memory as data reading buffer and does not rely on `sendfile` or `mmap` mechanism, thus it also works well with [SSL]({{< ref "docs/deployment/security/security-ssl" >}}). Please refer to [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) and [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614) for more details about sort shuffle.
+`Sort Shuffle` 是 1.13 版中引入的另一种 blocking shuffle 实现。不同于 `Hash Shuffle`,sort shuffle 将每个分区结果写入到一个文件。当多个下游任务同时读取结果分片,数据文件只会被打开一次并共享给所有的读请求。因此,集群使用更少的资源。例如:节点和文件描述符以提升稳定性。此外,通过写更少的文件和尽可能线性的读取文件,尤其是在使用机械硬盘情况下 sort shuffle 可以获得比 hash shuffle 更好的性能。另外,`sort shuffle` 使用额外管理的内存作为读数据缓存并不依赖 `sendfile` 或 `mmap` 机制,因此也适用于 [SSL]({{< ref "docs/deployment/security/security-ssl" >}})。关于 sort shuffle 的更多细节请参考 [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) 和 [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614)。
 
-There are several config options that might need adjustment when using sort blocking shuffle:
-- [taskmanager.network.blocking-shuffle.compression.enabled]({{< ref "docs/deployment/config" >}}#taskmanager-network-blocking-shuffle-compression-enabled): Config option for shuffle data compression. it is suggested to enable it for most jobs except that the compression ratio of your data is low.
-- [taskmanager.network.sort-shuffle.min-parallelism]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-parallelism): Config option to enable sort shuffle depending on the parallelism of downstream tasks. If parallelism is lower than the configured value, `hash shuffle` will be used, otherwise `sort shuffle` will be used.
-- [taskmanager.network.sort-shuffle.min-buffers]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-buffers): Config option to control data writing buffer size. For large scale jobs, you may need to increase this value, usually, several hundreds of megabytes memory is enough.
-- [taskmanager.memory.framework.off-heap.batch-shuffle.size]({{< ref "docs/deployment/config" >}}#taskmanager-memory-framework-off-heap-batch-shuffle-size): Config option to control data reading buffer size. For large scale jobs, you may need to increase this value, usually, several hundreds of megabytes memory is enough.
+当使用sort blocking shuffle的时候有些配置需要适配:
+- [taskmanager.network.blocking-shuffle.compression.enabled]({{< ref "docs/deployment/config" >}}#taskmanager-network-blocking-shuffle-compression-enabled): 配置该选项以启用 shuffle data 压缩,大部分任务建议开启除非你的数据压缩比率比较低。
+- [taskmanager.network.sort-shuffle.min-parallelism]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-parallelism): 根据下游任务的并行度配置该选项以启用 sort shuffle。如果并行度低于设置的值,则使用 `hash shuffle`,否则 `sort shuffle`。
+- [taskmanager.network.sort-shuffle.min-buffers]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-buffers): 配置该选项以控制数据写缓存大小。对于大规模的任务而言,你可能需要调大这个值,正常几百兆内存就足够了。
+- [taskmanager.memory.framework.off-heap.batch-shuffle.size]({{< ref "docs/deployment/config" >}}#taskmanager-memory-framework-off-heap-batch-shuffle-size): 配置该选项以控制数据读取缓存大小。对于大规模的任务而言,你可能需要调大这个值,正常几百兆内存就足够了。
 
 {{< hint info >}}
-Currently `sort shuffle` only sort records by partition index instead of the records themselves, that is to say, the `sort` is only used as a data clustering algorithm.
+目前 `sort shuffle` 只通过分区索引来排序而不是记录本身,也就是说 `sort` 只是被当成数据聚类算法使用。
 {{< /hint >}}
 
-## Choices of Blocking Shuffle
+## 如何选择 Blocking Shuffle
 
-As a summary,
+总结,

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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] gaoyunhaii commented on a change in pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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



##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持通过批处理执行模式处理有界输入。此模式是通过 blocking shuffle 进行网络传输。与流式应用使用管道 shuffle 阻塞交换的数据并存储,然后下游任务通过网络获取这些值的方式不同。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+总的来说,Flink 提供了两种不同类型的 blocking shuffles ; `Hash shuffle` 和 `Sort shuffle`。

Review comment:
       `;` -> `:` ?

##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持通过批处理执行模式处理有界输入。此模式是通过 blocking shuffle 进行网络传输。与流式应用使用管道 shuffle 阻塞交换的数据并存储,然后下游任务通过网络获取这些值的方式不同。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+总的来说,Flink 提供了两种不同类型的 blocking shuffles ; `Hash shuffle` 和 `Sort shuffle`。
 
-They will be detailed in the following sections.
+在下面章节会详细说明它们。
 
 ## Hash Shuffle
 
-The default blocking shuffle implementation, `Hash Shuffle`, has each upstream task persist its results in a separate file for each downstream task on the local disk of the TaskManager. When the downstream tasks run, they will request partitions from the upstream TaskManager's, which read the files and transmit data via the network.
+`Hash Shuffle` 是 blocking shuffle 的默认实现,它为每个下游任务将每个上游任务的结果以单独文件的方式保存在 TaskManager 本地磁盘上。当下游任务运行时会向上游的 TaskManager 请求分片,TaskManager 读取文件之后通过网络传输(给下游任务)。
 
-`Hash Shuffle` provides different mechanisms for writing and reading files:
+`Hash Shuffle` 为读写文件提供了不同的机制:
 
-- `file`: Writes files with the normal File IO, reads and transmits files with Netty `FileRegion`. `FileRegion` relies on `sendfile` system call to reduce the number of data copies and memory consumption.
-- `mmap`: Writes and reads files with `mmap` system call.
-- `Auto`: Writes files with the normal File IO, for file reading, it falls back to normal `file` option on 32 bit machine and use `mmap` on 64 bit machine. This is to avoid file size limitation of java `mmap` implementation on 32 bit machine.
+- `file`: 通过标准文件 IO 写文件,读取和传输文件需要通过 Netty 的 `FileRegion`。`FileRegion` 依靠系统调用 `sendfile` 来减少数据拷贝和内存消耗。
+- `mmap`: 通过系统调用 `mmap` 来读写文件。
+- `Auto`: 通过标准文件 IO 写文件,对于文件读取,在 32 位机器上降级到 `file` 选项并且在 64 位机器上使用 `mmap` 。这是为了避免在 32 位机器上 java 实现 `mmap` 的文件大小限制。
 
-The different mechanism could be chosen via [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}).
+可通过设置 [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}) 选择不同的机制。
 
 {{< hint warning >}}
-This option is experimental and might be changed future.
+这个选项是实验性的,将来或许会有改动。
 {{< /hint >}}
 
 {{< hint warning >}}
-If [SSL]({{< ref "docs/deployment/security/security-ssl" >}}) is enabled, the `file` mechanism can not use `FileRegion` and instead uses an un-pooled buffer to cache data before transmitting. This might [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981). Additionally, since the synchronous file reading might block Netty threads for some time, the [SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) needs to be increased to avoid [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416).
+如果开启 [SSL]({{< ref "docs/deployment/security/security-ssl" >}}),`file` 机制不能使用 `FileRegion` 而是在传输之前使用非池化的缓存去缓存数据。这可能会 [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981)。此外,因为同步读取文件有时会造成 netty 线程阻塞,[SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) 配置需要调大以防 [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416)。
 {{< /hint >}}
 
 {{< hint info >}}
-The memory usage of `mmap` is not accounted for by configured memory limits, but some resource frameworks like Yarn will track this memory usage and kill the container if memory exceeds some threshold.
+`mmap`使用的内存不计算进已有配置的内存限制中,但是一些资源管理框架比如 yarn 将追踪这块内存使用,并且如果容器使用内存超过阈值会被杀掉。
 {{< /hint >}}
 
-To further improve the performance, for most jobs we also recommend [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) unless the data is hard to compress.
+为了进一步的提升性能,对于绝大多数的任务我们推荐 [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) 除非数据很难被压缩。
 
-`Hash Shuffle` works well for small scale jobs with SSD, but it also have some disadvantages:
+`Hash Shuffle` 在小规模运行在固态硬盘的任务情况下效果显著,但是依旧有一些问题:
 
-1. If the job scale is large, it might create too many files, and it requires a large write buffer to write these files at the same time.
-2. On HDD, when multiple downstream tasks fetch their data simultaneously, it might incur the issue of random IO.
+1. 如果任务的规模庞大将会创建很多文件,并且要求同时对这些文件进行大量的写操作。
+2. 在机械硬盘情况下,当大量的下游任务同时读取数据,可能会导致随机读写问题。
 
 ## Sort Shuffle
 
-`Sort Shuffle` is another blocking shuffle implementation introduced in version 1.13. Different from `Hash Shuffle`, sort shuffle writes only one file for each result partition. When the result partition is read by multiple downstream tasks concurrently, the data file is opened only once and shared by all readers. As a result, the cluster uses fewer resources like inode and file descriptors, which improves stability. Furthermore, by writing fewer files and making a best effort to read data sequentially, sort shuffle can achieve better performance than hash shuffle, especially on HDD. Additionally, `sort shuffle` uses extra managed memory as data reading buffer and does not rely on `sendfile` or `mmap` mechanism, thus it also works well with [SSL]({{< ref "docs/deployment/security/security-ssl" >}}). Please refer to [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) and [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614) for more details about sort shuffle.
+`Sort Shuffle` 是 1.13 版中引入的另一种 blocking shuffle 实现。不同于 `Hash Shuffle`,sort shuffle 将每个分区结果写入到一个文件。当多个下游任务同时读取结果分片,数据文件只会被打开一次并共享给所有的读请求。因此,集群使用更少的资源。例如:节点和文件描述符以提升稳定性。此外,通过写更少的文件和尽可能线性的读取文件,尤其是在使用机械硬盘情况下 sort shuffle 可以获得比 hash shuffle 更好的性能。另外,`sort shuffle` 使用额外管理的内存作为读数据缓存并不依赖 `sendfile` 或 `mmap` 机制,因此也适用于 [SSL]({{< ref "docs/deployment/security/security-ssl" >}})。关于 sort shuffle 的更多细节请参考 [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) 和 [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614)。
 
-There are several config options that might need adjustment when using sort blocking shuffle:
-- [taskmanager.network.blocking-shuffle.compression.enabled]({{< ref "docs/deployment/config" >}}#taskmanager-network-blocking-shuffle-compression-enabled): Config option for shuffle data compression. it is suggested to enable it for most jobs except that the compression ratio of your data is low.
-- [taskmanager.network.sort-shuffle.min-parallelism]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-parallelism): Config option to enable sort shuffle depending on the parallelism of downstream tasks. If parallelism is lower than the configured value, `hash shuffle` will be used, otherwise `sort shuffle` will be used.
-- [taskmanager.network.sort-shuffle.min-buffers]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-buffers): Config option to control data writing buffer size. For large scale jobs, you may need to increase this value, usually, several hundreds of megabytes memory is enough.
-- [taskmanager.memory.framework.off-heap.batch-shuffle.size]({{< ref "docs/deployment/config" >}}#taskmanager-memory-framework-off-heap-batch-shuffle-size): Config option to control data reading buffer size. For large scale jobs, you may need to increase this value, usually, several hundreds of megabytes memory is enough.
+当使用sort blocking shuffle的时候有些配置需要适配:
+- [taskmanager.network.blocking-shuffle.compression.enabled]({{< ref "docs/deployment/config" >}}#taskmanager-network-blocking-shuffle-compression-enabled): 配置该选项以启用 shuffle data 压缩,大部分任务建议开启除非你的数据压缩比率比较低。
+- [taskmanager.network.sort-shuffle.min-parallelism]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-parallelism): 根据下游任务的并行度配置该选项以启用 sort shuffle。如果并行度低于设置的值,则使用 `hash shuffle`,否则 `sort shuffle`。
+- [taskmanager.network.sort-shuffle.min-buffers]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-buffers): 配置该选项以控制数据写缓存大小。对于大规模的任务而言,你可能需要调大这个值,正常几百兆内存就足够了。
+- [taskmanager.memory.framework.off-heap.batch-shuffle.size]({{< ref "docs/deployment/config" >}}#taskmanager-memory-framework-off-heap-batch-shuffle-size): 配置该选项以控制数据读取缓存大小。对于大规模的任务而言,你可能需要调大这个值,正常几百兆内存就足够了。
 
 {{< hint info >}}
-Currently `sort shuffle` only sort records by partition index instead of the records themselves, that is to say, the `sort` is only used as a data clustering algorithm.
+目前 `sort shuffle` 只通过分区索引来排序而不是记录本身,也就是说 `sort` 只是被当成数据聚类算法使用。
 {{< /hint >}}
 
-## Choices of Blocking Shuffle
+## 如何选择 Blocking Shuffle
 
-As a summary,
+总结,

Review comment:
       总结 -> 一般来说  或者  总的来说?

##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持通过批处理执行模式处理有界输入。此模式是通过 blocking shuffle 进行网络传输。与流式应用使用管道 shuffle 阻塞交换的数据并存储,然后下游任务通过网络获取这些值的方式不同。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+总的来说,Flink 提供了两种不同类型的 blocking shuffles ; `Hash shuffle` 和 `Sort shuffle`。

Review comment:
       `;` -> `:` ?

##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持通过批处理执行模式处理有界输入。此模式是通过 blocking shuffle 进行网络传输。与流式应用使用管道 shuffle 阻塞交换的数据并存储,然后下游任务通过网络获取这些值的方式不同。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+总的来说,Flink 提供了两种不同类型的 blocking shuffles ; `Hash shuffle` 和 `Sort shuffle`。
 
-They will be detailed in the following sections.
+在下面章节会详细说明它们。
 
 ## Hash Shuffle
 
-The default blocking shuffle implementation, `Hash Shuffle`, has each upstream task persist its results in a separate file for each downstream task on the local disk of the TaskManager. When the downstream tasks run, they will request partitions from the upstream TaskManager's, which read the files and transmit data via the network.
+`Hash Shuffle` 是 blocking shuffle 的默认实现,它为每个下游任务将每个上游任务的结果以单独文件的方式保存在 TaskManager 本地磁盘上。当下游任务运行时会向上游的 TaskManager 请求分片,TaskManager 读取文件之后通过网络传输(给下游任务)。
 
-`Hash Shuffle` provides different mechanisms for writing and reading files:
+`Hash Shuffle` 为读写文件提供了不同的机制:
 
-- `file`: Writes files with the normal File IO, reads and transmits files with Netty `FileRegion`. `FileRegion` relies on `sendfile` system call to reduce the number of data copies and memory consumption.
-- `mmap`: Writes and reads files with `mmap` system call.
-- `Auto`: Writes files with the normal File IO, for file reading, it falls back to normal `file` option on 32 bit machine and use `mmap` on 64 bit machine. This is to avoid file size limitation of java `mmap` implementation on 32 bit machine.
+- `file`: 通过标准文件 IO 写文件,读取和传输文件需要通过 Netty 的 `FileRegion`。`FileRegion` 依靠系统调用 `sendfile` 来减少数据拷贝和内存消耗。
+- `mmap`: 通过系统调用 `mmap` 来读写文件。
+- `Auto`: 通过标准文件 IO 写文件,对于文件读取,在 32 位机器上降级到 `file` 选项并且在 64 位机器上使用 `mmap` 。这是为了避免在 32 位机器上 java 实现 `mmap` 的文件大小限制。
 
-The different mechanism could be chosen via [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}).
+可通过设置 [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}) 选择不同的机制。
 
 {{< hint warning >}}
-This option is experimental and might be changed future.
+这个选项是实验性的,将来或许会有改动。
 {{< /hint >}}
 
 {{< hint warning >}}
-If [SSL]({{< ref "docs/deployment/security/security-ssl" >}}) is enabled, the `file` mechanism can not use `FileRegion` and instead uses an un-pooled buffer to cache data before transmitting. This might [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981). Additionally, since the synchronous file reading might block Netty threads for some time, the [SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) needs to be increased to avoid [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416).
+如果开启 [SSL]({{< ref "docs/deployment/security/security-ssl" >}}),`file` 机制不能使用 `FileRegion` 而是在传输之前使用非池化的缓存去缓存数据。这可能会 [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981)。此外,因为同步读取文件有时会造成 netty 线程阻塞,[SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) 配置需要调大以防 [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416)。
 {{< /hint >}}
 
 {{< hint info >}}
-The memory usage of `mmap` is not accounted for by configured memory limits, but some resource frameworks like Yarn will track this memory usage and kill the container if memory exceeds some threshold.
+`mmap`使用的内存不计算进已有配置的内存限制中,但是一些资源管理框架比如 yarn 将追踪这块内存使用,并且如果容器使用内存超过阈值会被杀掉。
 {{< /hint >}}
 
-To further improve the performance, for most jobs we also recommend [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) unless the data is hard to compress.
+为了进一步的提升性能,对于绝大多数的任务我们推荐 [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) 除非数据很难被压缩。
 
-`Hash Shuffle` works well for small scale jobs with SSD, but it also have some disadvantages:
+`Hash Shuffle` 在小规模运行在固态硬盘的任务情况下效果显著,但是依旧有一些问题:
 
-1. If the job scale is large, it might create too many files, and it requires a large write buffer to write these files at the same time.
-2. On HDD, when multiple downstream tasks fetch their data simultaneously, it might incur the issue of random IO.
+1. 如果任务的规模庞大将会创建很多文件,并且要求同时对这些文件进行大量的写操作。
+2. 在机械硬盘情况下,当大量的下游任务同时读取数据,可能会导致随机读写问题。
 
 ## Sort Shuffle
 
-`Sort Shuffle` is another blocking shuffle implementation introduced in version 1.13. Different from `Hash Shuffle`, sort shuffle writes only one file for each result partition. When the result partition is read by multiple downstream tasks concurrently, the data file is opened only once and shared by all readers. As a result, the cluster uses fewer resources like inode and file descriptors, which improves stability. Furthermore, by writing fewer files and making a best effort to read data sequentially, sort shuffle can achieve better performance than hash shuffle, especially on HDD. Additionally, `sort shuffle` uses extra managed memory as data reading buffer and does not rely on `sendfile` or `mmap` mechanism, thus it also works well with [SSL]({{< ref "docs/deployment/security/security-ssl" >}}). Please refer to [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) and [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614) for more details about sort shuffle.
+`Sort Shuffle` 是 1.13 版中引入的另一种 blocking shuffle 实现。不同于 `Hash Shuffle`,sort shuffle 将每个分区结果写入到一个文件。当多个下游任务同时读取结果分片,数据文件只会被打开一次并共享给所有的读请求。因此,集群使用更少的资源。例如:节点和文件描述符以提升稳定性。此外,通过写更少的文件和尽可能线性的读取文件,尤其是在使用机械硬盘情况下 sort shuffle 可以获得比 hash shuffle 更好的性能。另外,`sort shuffle` 使用额外管理的内存作为读数据缓存并不依赖 `sendfile` 或 `mmap` 机制,因此也适用于 [SSL]({{< ref "docs/deployment/security/security-ssl" >}})。关于 sort shuffle 的更多细节请参考 [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) 和 [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614)。
 
-There are several config options that might need adjustment when using sort blocking shuffle:
-- [taskmanager.network.blocking-shuffle.compression.enabled]({{< ref "docs/deployment/config" >}}#taskmanager-network-blocking-shuffle-compression-enabled): Config option for shuffle data compression. it is suggested to enable it for most jobs except that the compression ratio of your data is low.
-- [taskmanager.network.sort-shuffle.min-parallelism]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-parallelism): Config option to enable sort shuffle depending on the parallelism of downstream tasks. If parallelism is lower than the configured value, `hash shuffle` will be used, otherwise `sort shuffle` will be used.
-- [taskmanager.network.sort-shuffle.min-buffers]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-buffers): Config option to control data writing buffer size. For large scale jobs, you may need to increase this value, usually, several hundreds of megabytes memory is enough.
-- [taskmanager.memory.framework.off-heap.batch-shuffle.size]({{< ref "docs/deployment/config" >}}#taskmanager-memory-framework-off-heap-batch-shuffle-size): Config option to control data reading buffer size. For large scale jobs, you may need to increase this value, usually, several hundreds of megabytes memory is enough.
+当使用sort blocking shuffle的时候有些配置需要适配:
+- [taskmanager.network.blocking-shuffle.compression.enabled]({{< ref "docs/deployment/config" >}}#taskmanager-network-blocking-shuffle-compression-enabled): 配置该选项以启用 shuffle data 压缩,大部分任务建议开启除非你的数据压缩比率比较低。
+- [taskmanager.network.sort-shuffle.min-parallelism]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-parallelism): 根据下游任务的并行度配置该选项以启用 sort shuffle。如果并行度低于设置的值,则使用 `hash shuffle`,否则 `sort shuffle`。
+- [taskmanager.network.sort-shuffle.min-buffers]({{< ref "docs/deployment/config" >}}#taskmanager-network-sort-shuffle-min-buffers): 配置该选项以控制数据写缓存大小。对于大规模的任务而言,你可能需要调大这个值,正常几百兆内存就足够了。
+- [taskmanager.memory.framework.off-heap.batch-shuffle.size]({{< ref "docs/deployment/config" >}}#taskmanager-memory-framework-off-heap-batch-shuffle-size): 配置该选项以控制数据读取缓存大小。对于大规模的任务而言,你可能需要调大这个值,正常几百兆内存就足够了。
 
 {{< hint info >}}
-Currently `sort shuffle` only sort records by partition index instead of the records themselves, that is to say, the `sort` is only used as a data clustering algorithm.
+目前 `sort shuffle` 只通过分区索引来排序而不是记录本身,也就是说 `sort` 只是被当成数据聚类算法使用。
 {{< /hint >}}
 
-## Choices of Blocking Shuffle
+## 如何选择 Blocking Shuffle
 
-As a summary,
+总结,

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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   
   <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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098) 
   * 0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1 UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] gaoyunhaii edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   Hi @GOODBOY008 very thanks for updating the PR! LGTM % one above small comment. If you also agree with that, I'll merge the PR without that modification~


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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] GOODBOY008 commented on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   @gaoyunhaii Thanks for your review,I have apply your suggestion.Please cc.


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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * a4b275ac26d19b38e9b723ee51532ca3b58b19b8 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125) 
   
   <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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] GOODBOY008 commented on a change in pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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



##########
File path: docs/content/docs/ops/batch/blocking_shuffle.md
##########
@@ -31,7 +31,7 @@ under the License.
 
 Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+As a whole, Flink provides two different types of blocking shuffles: `Hash shuffle` and `Sort shuffle`.

Review comment:
       ok,I fix it now.




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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] gaoyunhaii commented on a change in pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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



##########
File path: docs/content/docs/ops/batch/blocking_shuffle.md
##########
@@ -31,7 +31,7 @@ under the License.
 
 Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+As a whole, Flink provides two different types of blocking shuffles: `Hash shuffle` and `Sort shuffle`.

Review comment:
       Hi @GOODBOY008 ~ I think we do not need to modify the english version~ 




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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098) 
   * 0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1 UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] GOODBOY008 commented on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   @gaoyunhaii Please review my pr again.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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] GOODBOY008 commented on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   @wuchong Can you review my pr? And give me some 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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] GOODBOY008 commented on a change in pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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



##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink 在使用 [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持批处理执行模式,这用于任务处理有界输入流。使用此模式通过 blocking shuffle 来网络传输。不同于在流式应用使用管道 shuffle,阻塞交换的数据并存储.然后下游任务通过网络获取这些值。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 

Review comment:
       3 ”使用此模式通过 blocking shuffle 来网络传输“->"此模式是通过 blocking shuffle 进行网络传输。 "




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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] GOODBOY008 commented on a change in pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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



##########
File path: docs/content.zh/docs/ops/batch/blocking_shuffle.md
##########
@@ -27,63 +27,63 @@ under the License.
 
 # Blocking Shuffle
 
-## Overview
+## 总览
 
-Flink supports a batch execution mode in both [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) and [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) for jobs executing across bounded input. In this mode, network exchanges occur via a blocking shuffle. Unlike the pipeline shuffle used for streaming applications, blocking exchanges persists data to some storage. Downstream tasks then fetch these values via the network. Such an exchange reduces the resources required to execute the job as it does not need the upstream and downstream tasks to run simultaneously.
+Flink 在使用 [DataStream API]({{< ref "docs/dev/datastream/execution_mode" >}}) 和 [Table / SQL]({{< ref "/docs/dev/table/overview" >}}) 都支持批处理执行模式,这用于任务处理有界输入流。使用此模式通过 blocking shuffle 来网络传输。不同于在流式应用使用管道 shuffle,阻塞交换的数据并存储.然后下游任务通过网络获取这些值。这种交换减少了执行作业所需的资源,因为它不需要同时运行上游和下游任务。 
 
-As a whole, Flink provides two different types of blocking shuffles; `Hash shuffle` and `Sort shuffle`.
+总的来说,Flink 提供了两种不同类型的 blocking shuffles ; `Hash shuffle` 和 `Sort shuffle`。
 
-They will be detailed in the following sections.
+在下面章节会详细说明它们.
 
 ## Hash Shuffle
 
-The default blocking shuffle implementation, `Hash Shuffle`, has each upstream task persist its results in a separate file for each downstream task on the local disk of the TaskManager. When the downstream tasks run, they will request partitions from the upstream TaskManager's, which read the files and transmit data via the network.
+`Hash Shuffle` 是 blocking shuffle 的默认实现,它为每个下游任务将每个上游任务的结果以单独文件的方式保存在 TaskManager 本地磁盘上。当下游任务运行时会向上游的 TaskManager 请求分片,TaskManager 读取文件之后通过网络传输。
 
-`Hash Shuffle` provides different mechanisms for writing and reading files:
+`Hash Shuffle` 为读写文件提供了不同的机制:
 
-- `file`: Writes files with the normal File IO, reads and transmits files with Netty `FileRegion`. `FileRegion` relies on `sendfile` system call to reduce the number of data copies and memory consumption.
-- `mmap`: Writes and reads files with `mmap` system call.
-- `Auto`: Writes files with the normal File IO, for file reading, it falls back to normal `file` option on 32 bit machine and use `mmap` on 64 bit machine. This is to avoid file size limitation of java `mmap` implementation on 32 bit machine.
+- `file`: 通过标准文件 IO 写文件,读取和传输文件是要通过 Netty 的 `FileRegion`。`FileRegion` 依靠系统调用 `sendfile` 来减少数据拷贝和内存消耗。
+- `mmap`: 通过系统调用 `mmap` 来读写文件。
+- `Auto`: 通过标准文件 IO 写文件,对于文件读取,在32为机器上降级到 `file` 选项 并且 在64位机器上使用 `mmap` 。这是为了避免在 32 位机器上 java 实现 `mmap` 的文件大小限制。
 
-The different mechanism could be chosen via [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}).
+可通过设置 [TaskManager configurations]({{< ref "docs/deployment/config#taskmanager-network-blocking-shuffle-type" >}}) 选择不同的机制。
 
 {{< hint warning >}}
-This option is experimental and might be changed future.
+这个选项是实验性的,将来或许会有改动。
 {{< /hint >}}
 
 {{< hint warning >}}
-If [SSL]({{< ref "docs/deployment/security/security-ssl" >}}) is enabled, the `file` mechanism can not use `FileRegion` and instead uses an un-pooled buffer to cache data before transmitting. This might [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981). Additionally, since the synchronous file reading might block Netty threads for some time, the [SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) needs to be increased to avoid [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416).
+如果开启 [SSL]({{< ref "docs/deployment/security/security-ssl" >}}),`file` 机制不能使用 `FileRegion` 而是在传输之前使用非池化的缓存去缓存数据。这可能会 [cause direct memory OOM](https://issues.apache.org/jira/browse/FLINK-15981)。 此外,因为同步读取文件有时会造成 netty 线程阻塞,[SSL handshake timeout]({{< ref "docs/deployment/config#security-ssl-internal-handshake-timeout" >}}) 配置需要上调以防 [connection reset errors](https://issues.apache.org/jira/browse/FLINK-21416)。
 {{< /hint >}}
 
 {{< hint info >}}
-The memory usage of `mmap` is not accounted for by configured memory limits, but some resource frameworks like Yarn will track this memory usage and kill the container if memory exceeds some threshold.
+`mmap`使用的内存不计算进已有配置的内存限制中, 但是一些资源管理框架比如 yarn 将追踪这块内存使用并且如果容器使用内存超过阈值会被杀掉。
 {{< /hint >}}
 
-To further improve the performance, for most jobs we also recommend [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) unless the data is hard to compress.
+为了进一步的提升性能, 对于绝大多数的任务我们推荐 [enabling compression]({{< ref "docs/deployment/config">}}#taskmanager-network-blocking-shuffle-compression-enabled) 除非数据很难被压缩。
 
-`Hash Shuffle` works well for small scale jobs with SSD, but it also have some disadvantages:
+`Hash Shuffle` 在小规模运行在固态硬盘的任务情况下效果显著,但是依旧有一些挑战:
 
-1. If the job scale is large, it might create too many files, and it requires a large write buffer to write these files at the same time.
-2. On HDD, when multiple downstream tasks fetch their data simultaneously, it might incur the issue of random IO.
+1. 如果任务的规模庞大将会创建很多文件并且要求同时对这些文件进行大量的写操作。
+2. 在机械硬盘情况下,当大量的下游任务同时读取数据,可能会导致随机读写问题。
 
 ## Sort Shuffle
 
-`Sort Shuffle` is another blocking shuffle implementation introduced in version 1.13. Different from `Hash Shuffle`, sort shuffle writes only one file for each result partition. When the result partition is read by multiple downstream tasks concurrently, the data file is opened only once and shared by all readers. As a result, the cluster uses fewer resources like inode and file descriptors, which improves stability. Furthermore, by writing fewer files and making a best effort to read data sequentially, sort shuffle can achieve better performance than hash shuffle, especially on HDD. Additionally, `sort shuffle` uses extra managed memory as data reading buffer and does not rely on `sendfile` or `mmap` mechanism, thus it also works well with [SSL]({{< ref "docs/deployment/security/security-ssl" >}}). Please refer to [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) and [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614) for more details about sort shuffle.
+`Sort Shuffle` 是 1.13 版中引入的另一种 blocking shuffle 实现.不同于 `Hash Shuffle`,sort shuffle 将每个分区结果写入到一个文件。当多个下游任务同时读取结果分片,数据文件只会被打开一次并共享给所有的读请求。总之,集群使用更少的资源例如:节点和文件描述符以提升稳定性。此外,通过写更少的文件和尽可能线性的读取文件,尤其是在使用机械硬盘情况下 sort shuffle 可以获得比 hash shuffle 更好的性能。另外,`sort shuffle` 使用额外管理的内存作为读数据缓存并不依赖 `sendfile` 或 `mmap` 机制, 因此也适用于 [SSL]({{< ref "docs/deployment/security/security-ssl" >}})。关于 sort shuffle 的更多细节请参考 [FLINK-19582](https://issues.apache.org/jira/browse/FLINK-19582) 和 [FLINK-19614](https://issues.apache.org/jira/browse/FLINK-19614) .

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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098) 
   * 0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1 UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * a4b275ac26d19b38e9b723ee51532ca3b58b19b8 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125) 
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     }, {
       "hash" : "0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098) 
   * 0aa0c217888f3c61aeb2ee2e4fc4df9650fe92b1 UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] gaoyunhaii commented on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   No problem, I'll have a look~


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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot commented on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   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 a4b275ac26d19b38e9b723ee51532ca3b58b19b8 (Wed Jul 28 16:01:30 UTC 2021)
   
   **Warnings:**
    * No documentation files were touched! Remember to keep the Flink docs up to date!
   
   
   <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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] gaoyunhaii closed pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   


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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f UNKNOWN
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] gaoyunhaii commented on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   Hi @GOODBOY008 very thanks for opening the PR! LGTM % one above small comment. If you also agree with that, I'll merge the PR without that modification~


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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * a4b275ac26d19b38e9b723ee51532ca3b58b19b8 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125) 
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   
   <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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot commented on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "UNKNOWN",
       "url" : "TBD",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * a4b275ac26d19b38e9b723ee51532ca3b58b19b8 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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] GOODBOY008 closed pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   


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

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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



[GitHub] [flink] flinkbot edited a comment on pull request #16627: [FLINK-23427][chinese-translation] Translate the page of "Blocking Sh…

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


   <!--
   Meta data
   {
     "version" : 1,
     "metaDataEntries" : [ {
       "hash" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "status" : "DELETED",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21125",
       "triggerID" : "a4b275ac26d19b38e9b723ee51532ca3b58b19b8",
       "triggerType" : "PUSH"
     }, {
       "hash" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "status" : "SUCCESS",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261",
       "triggerID" : "bd5918c2cd6093ef02f1ed77727ccc45dcf450e4",
       "triggerType" : "PUSH"
     }, {
       "hash" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "status" : "PENDING",
       "url" : "https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098",
       "triggerID" : "e268b3d35846969830ed7e9fc9ff273f658e595f",
       "triggerType" : "PUSH"
     } ]
   }-->
   ## CI report:
   
   * bd5918c2cd6093ef02f1ed77727ccc45dcf450e4 Azure: [SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=21261) 
   * e268b3d35846969830ed7e9fc9ff273f658e595f Azure: [PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26098) 
   
   <details>
   <summary>Bot commands</summary>
     The @flinkbot bot supports the following commands:
   
    - `@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.

To unsubscribe, e-mail: issues-unsubscribe@flink.apache.org

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