You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by gu...@apache.org on 2023/05/17 10:47:58 UTC

[flink] branch master updated: [hotfix] Fix typos of comment

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

guoweijie pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git


The following commit(s) were added to refs/heads/master by this push:
     new 2c252922723 [hotfix] Fix typos of comment
2c252922723 is described below

commit 2c25292272306a6eb094be40be0a0fa5fc3cf644
Author: Huston <hu...@gmail.com>
AuthorDate: Fri Apr 14 01:29:34 2023 +0800

    [hotfix] Fix typos of comment
---
 .../generated/yarn_config_configuration.html       |  2 +-
 .../flink/api/common/state/OperatorStateStore.java |  4 +--
 .../apache/flink/optimizer/dag/OptimizerNode.java  |  2 +-
 .../slotmanager/ResourceTracker.java               |  2 +-
 .../checkpoint/CheckpointStatsCountsTest.java      |  2 +-
 .../api/datastream/AllWindowedStream.java          | 24 ++++++-------
 .../streaming/api/datastream/WindowedStream.java   | 24 ++++++-------
 .../streaming/api/scala/AllWindowedStream.scala    | 26 +++++++-------
 .../flink/streaming/api/scala/KeyedStream.scala    | 40 +++++++++++-----------
 .../flink/streaming/api/scala/WindowedStream.scala | 26 +++++++-------
 .../yarn/configuration/YarnConfigOptions.java      |  2 +-
 11 files changed, 75 insertions(+), 79 deletions(-)

diff --git a/docs/layouts/shortcodes/generated/yarn_config_configuration.html b/docs/layouts/shortcodes/generated/yarn_config_configuration.html
index 13037ab8575..77fe8dd978b 100644
--- a/docs/layouts/shortcodes/generated/yarn_config_configuration.html
+++ b/docs/layouts/shortcodes/generated/yarn_config_configuration.html
@@ -36,7 +36,7 @@
             <td><h5>yarn.application-attempts</h5></td>
             <td style="word-wrap: break-word;">(none)</td>
             <td>String</td>
-            <td>Number of ApplicationMaster restarts. By default, the value will be set to 1. If high availability is enabled, then the default value will be 2. The restart number is also limited by YARN (configured via <a href="https://hadoop.apache.org/docs/stable/hadoop-yarn/hadoop-yarn-common/yarn-default.xml">yarn.resourcemanager.am.max-attempts</a>). Note that that the entire Flink cluster will restart and the YARN Client will lose the connection.</td>
+            <td>Number of ApplicationMaster restarts. By default, the value will be set to 1. If high availability is enabled, then the default value will be 2. The restart number is also limited by YARN (configured via <a href="https://hadoop.apache.org/docs/stable/hadoop-yarn/hadoop-yarn-common/yarn-default.xml">yarn.resourcemanager.am.max-attempts</a>). Note that the entire Flink cluster will restart and the YARN Client will lose the connection.</td>
         </tr>
         <tr>
             <td><h5>yarn.application-master.port</h5></td>
diff --git a/flink-core/src/main/java/org/apache/flink/api/common/state/OperatorStateStore.java b/flink-core/src/main/java/org/apache/flink/api/common/state/OperatorStateStore.java
index 4c24f09b834..cb005c64319 100644
--- a/flink-core/src/main/java/org/apache/flink/api/common/state/OperatorStateStore.java
+++ b/flink-core/src/main/java/org/apache/flink/api/common/state/OperatorStateStore.java
@@ -60,7 +60,7 @@ public interface OperatorStateStore {
      *
      * <p>Note the semantic differences between an operator list state and a keyed list state (see
      * {@link KeyedStateStore#getListState(ListStateDescriptor)}). Under the context of operator
-     * state, the list is a collection of state items that are independent from each other and
+     * state, the list is a collection of state items that are independent of each other and
      * eligible for redistribution across operator instances in case of changed operator
      * parallelism. In other words, these state items are the finest granularity at which non-keyed
      * state can be redistributed, and should not be correlated with each other.
@@ -83,7 +83,7 @@ public interface OperatorStateStore {
      *
      * <p>Note the semantic differences between an operator list state and a keyed list state (see
      * {@link KeyedStateStore#getListState(ListStateDescriptor)}). Under the context of operator
-     * state, the list is a collection of state items that are independent from each other and
+     * state, the list is a collection of state items that are independent of each other and
      * eligible for redistribution across operator instances in case of changed operator
      * parallelism. In other words, these state items are the finest granularity at which non-keyed
      * state can be redistributed, and should not be correlated with each other.
diff --git a/flink-optimizer/src/main/java/org/apache/flink/optimizer/dag/OptimizerNode.java b/flink-optimizer/src/main/java/org/apache/flink/optimizer/dag/OptimizerNode.java
index 12b3955f9f1..a8f38c9f18b 100644
--- a/flink-optimizer/src/main/java/org/apache/flink/optimizer/dag/OptimizerNode.java
+++ b/flink-optimizer/src/main/java/org/apache/flink/optimizer/dag/OptimizerNode.java
@@ -878,7 +878,7 @@ public abstract class OptimizerNode
         // add the cheapest plan
         if (cheapest != null) {
             plans.add(cheapest);
-            cheapest.setPruningMarker(); // remember that that plan is in the set
+            cheapest.setPruningMarker(); // remember that the plan is in the set
         }
 
         // add all others, which are optimal for some interesting properties
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/resourcemanager/slotmanager/ResourceTracker.java b/flink-runtime/src/main/java/org/apache/flink/runtime/resourcemanager/slotmanager/ResourceTracker.java
index 073c7405785..c4ee0e70724 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/resourcemanager/slotmanager/ResourceTracker.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/resourcemanager/slotmanager/ResourceTracker.java
@@ -31,7 +31,7 @@ public interface ResourceTracker {
     /**
      * Notifies the tracker about a new or updated {@link ResourceRequirements}.
      *
-     * @param jobId the job that that the resource requirements belongs to
+     * @param jobId the job that the resource requirements belongs to
      * @param resourceRequirements new resource requirements
      */
     void notifyResourceRequirements(
diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/checkpoint/CheckpointStatsCountsTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/checkpoint/CheckpointStatsCountsTest.java
index 5d60810db7a..62d9faaead8 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/checkpoint/CheckpointStatsCountsTest.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/checkpoint/CheckpointStatsCountsTest.java
@@ -99,7 +99,7 @@ public class CheckpointStatsCountsTest {
                 counts.getNumberOfInProgressCheckpoints() >= 0);
     }
 
-    /** Tests that that taking snapshots of the state are independent from the parent. */
+    /** Tests that taking snapshots of the state are independent of the parent. */
     @Test
     public void testCreateSnapshot() {
         CheckpointStatsCounts counts = new CheckpointStatsCounts();
diff --git a/flink-streaming-java/src/main/java/org/apache/flink/streaming/api/datastream/AllWindowedStream.java b/flink-streaming-java/src/main/java/org/apache/flink/streaming/api/datastream/AllWindowedStream.java
index 9303218ce0e..33df648bab0 100644
--- a/flink-streaming-java/src/main/java/org/apache/flink/streaming/api/datastream/AllWindowedStream.java
+++ b/flink-streaming-java/src/main/java/org/apache/flink/streaming/api/datastream/AllWindowedStream.java
@@ -1231,8 +1231,8 @@ public class AllWindowedStream<T, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the minimum value of every window of the data stream
-     * at the given position.
+     * Applies an aggregation that gives the minimum value of every window of the data stream at the
+     * given position.
      *
      * @param positionToMin The position to minimize
      * @return The transformed DataStream.
@@ -1247,7 +1247,7 @@ public class AllWindowedStream<T, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the minimum value of the pojo data stream at the given
+     * Applies an aggregation that gives the minimum value of the pojo data stream at the given
      * field expression for every window.
      *
      * <p>A field expression is either the name of a public field or a getter method with
@@ -1312,10 +1312,10 @@ public class AllWindowedStream<T, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the minimum element of the pojo data stream by the
-     * given field expression for every window. A field expression is either the name of a public
-     * field or a getter method with parentheses of the {@link DataStream DataStreams} underlying
-     * type. A dot can be used to drill down into objects, as in {@code "field1.getInnerField2()" }.
+     * Applies an aggregation that gives the minimum element of the pojo data stream by the given
+     * field expression for every window. A field expression is either the name of a public field or
+     * a getter method with parentheses of the {@link DataStream DataStreams} underlying type. A dot
+     * can be used to drill down into objects, as in {@code "field1.getInnerField2()" }.
      *
      * @param field The field expression based on which the aggregation will be applied.
      * @param first If True then in case of field equality the first object will be returned
@@ -1348,7 +1348,7 @@ public class AllWindowedStream<T, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the maximum value of the pojo data stream at the given
+     * Applies an aggregation that gives the maximum value of the pojo data stream at the given
      * field expression for every window. A field expression is either the name of a public field or
      * a getter method with parentheses of the {@link DataStream DataStreams} underlying type. A dot
      * can be used to drill down into objects, as in {@code "field1.getInnerField2()" }.
@@ -1411,10 +1411,10 @@ public class AllWindowedStream<T, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the maximum element of the pojo data stream by the
-     * given field expression for every window. A field expression is either the name of a public
-     * field or a getter method with parentheses of the {@link DataStream}S underlying type. A dot
-     * can be used to drill down into objects, as in {@code "field1.getInnerField2()" }.
+     * Applies an aggregation that gives the maximum element of the pojo data stream by the given
+     * field expression for every window. A field expression is either the name of a public field or
+     * a getter method with parentheses of the {@link DataStream}S underlying type. A dot can be
+     * used to drill down into objects, as in {@code "field1.getInnerField2()" }.
      *
      * @param field The field expression based on which the aggregation will be applied.
      * @param first If True then in case of field equality the first object will be returned
diff --git a/flink-streaming-java/src/main/java/org/apache/flink/streaming/api/datastream/WindowedStream.java b/flink-streaming-java/src/main/java/org/apache/flink/streaming/api/datastream/WindowedStream.java
index efec5718abe..283b14a53d8 100644
--- a/flink-streaming-java/src/main/java/org/apache/flink/streaming/api/datastream/WindowedStream.java
+++ b/flink-streaming-java/src/main/java/org/apache/flink/streaming/api/datastream/WindowedStream.java
@@ -698,8 +698,8 @@ public class WindowedStream<T, K, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the minimum value of every window of the data stream
-     * at the given position.
+     * Applies an aggregation that gives the minimum value of every window of the data stream at the
+     * given position.
      *
      * @param positionToMin The position to minimize
      * @return The transformed DataStream.
@@ -714,7 +714,7 @@ public class WindowedStream<T, K, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the minimum value of the pojo data stream at the given
+     * Applies an aggregation that gives the minimum value of the pojo data stream at the given
      * field expression for every window.
      *
      * <p>A field * expression is either the name of a public field or a getter method with
@@ -779,10 +779,10 @@ public class WindowedStream<T, K, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the minimum element of the pojo data stream by the
-     * given field expression for every window. A field expression is either the name of a public
-     * field or a getter method with parentheses of the {@link DataStream DataStreams} underlying
-     * type. A dot can be used to drill down into objects, as in {@code "field1.getInnerField2()" }.
+     * Applies an aggregation that gives the minimum element of the pojo data stream by the given
+     * field expression for every window. A field expression is either the name of a public field or
+     * a getter method with parentheses of the {@link DataStream DataStreams} underlying type. A dot
+     * can be used to drill down into objects, as in {@code "field1.getInnerField2()" }.
      *
      * @param field The field expression based on which the aggregation will be applied.
      * @param first If True then in case of field equality the first object will be returned
@@ -815,7 +815,7 @@ public class WindowedStream<T, K, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the maximum value of the pojo data stream at the given
+     * Applies an aggregation that gives the maximum value of the pojo data stream at the given
      * field expression for every window. A field expression is either the name of a public field or
      * a getter method with parentheses of the {@link DataStream DataStreams} underlying type. A dot
      * can be used to drill down into objects, as in {@code "field1.getInnerField2()" }.
@@ -878,10 +878,10 @@ public class WindowedStream<T, K, W extends Window> {
     }
 
     /**
-     * Applies an aggregation that that gives the maximum element of the pojo data stream by the
-     * given field expression for every window. A field expression is either the name of a public
-     * field or a getter method with parentheses of the {@link DataStream}S underlying type. A dot
-     * can be used to drill down into objects, as in {@code "field1.getInnerField2()" }.
+     * Applies an aggregation that gives the maximum element of the pojo data stream by the given
+     * field expression for every window. A field expression is either the name of a public field or
+     * a getter method with parentheses of the {@link DataStream}S underlying type. A dot can be
+     * used to drill down into objects, as in {@code "field1.getInnerField2()" }.
      *
      * @param field The field expression based on which the aggregation will be applied.
      * @param first If True then in case of field equality the first object will be returned
diff --git a/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/AllWindowedStream.scala b/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/AllWindowedStream.scala
index 3f812056f9f..715a107aad8 100644
--- a/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/AllWindowedStream.scala
+++ b/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/AllWindowedStream.scala
@@ -550,26 +550,24 @@ class AllWindowedStream[T, W <: Window](javaStream: JavaAllWStream[T, W]) {
   // ------------------------------------------------------------------------
 
   /**
-   * Applies an aggregation that that gives the maximum of the elements in the window at the given
+   * Applies an aggregation that gives the maximum of the elements in the window at the given
    * position.
    */
   def max(position: Int): DataStream[T] = aggregate(AggregationType.MAX, position)
 
   /**
-   * Applies an aggregation that that gives the maximum of the elements in the window at the given
-   * field.
+   * Applies an aggregation that gives the maximum of the elements in the window at the given field.
    */
   def max(field: String): DataStream[T] = aggregate(AggregationType.MAX, field)
 
   /**
-   * Applies an aggregation that that gives the minimum of the elements in the window at the given
+   * Applies an aggregation that gives the minimum of the elements in the window at the given
    * position.
    */
   def min(position: Int): DataStream[T] = aggregate(AggregationType.MIN, position)
 
   /**
-   * Applies an aggregation that that gives the minimum of the elements in the window at the given
-   * field.
+   * Applies an aggregation that gives the minimum of the elements in the window at the given field.
    */
   def min(field: String): DataStream[T] = aggregate(AggregationType.MIN, field)
 
@@ -580,26 +578,26 @@ class AllWindowedStream[T, W <: Window](javaStream: JavaAllWStream[T, W]) {
   def sum(field: String): DataStream[T] = aggregate(AggregationType.SUM, field)
 
   /**
-   * Applies an aggregation that that gives the maximum element of the window by the given position.
-   * When equality, returns the first.
+   * Applies an aggregation that gives the maximum element of the window by the given position. When
+   * equality, returns the first.
    */
   def maxBy(position: Int): DataStream[T] = aggregate(AggregationType.MAXBY, position)
 
   /**
-   * Applies an aggregation that that gives the maximum element of the window by the given field.
-   * When equality, returns the first.
+   * Applies an aggregation that gives the maximum element of the window by the given field. When
+   * equality, returns the first.
    */
   def maxBy(field: String): DataStream[T] = aggregate(AggregationType.MAXBY, field)
 
   /**
-   * Applies an aggregation that that gives the minimum element of the window by the given position.
-   * When equality, returns the first.
+   * Applies an aggregation that gives the minimum element of the window by the given position. When
+   * equality, returns the first.
    */
   def minBy(position: Int): DataStream[T] = aggregate(AggregationType.MINBY, position)
 
   /**
-   * Applies an aggregation that that gives the minimum element of the window by the given field.
-   * When equality, returns the first.
+   * Applies an aggregation that gives the minimum element of the window by the given field. When
+   * equality, returns the first.
    */
   def minBy(field: String): DataStream[T] = aggregate(AggregationType.MINBY, field)
 
diff --git a/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/KeyedStream.scala b/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/KeyedStream.scala
index 1f61f795d85..68d70152f7c 100644
--- a/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/KeyedStream.scala
+++ b/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/KeyedStream.scala
@@ -340,8 +340,8 @@ class KeyedStream[T, K](javaStream: KeyedJavaStream[T, K]) extends DataStream[T]
   }
 
   /**
-   * Applies an aggregation that that gives the current maximum of the data stream at the given
-   * position by the given key. An independent aggregate is kept per key.
+   * Applies an aggregation that gives the current maximum of the data stream at the given position
+   * by the given key. An independent aggregate is kept per key.
    *
    * @param position
    *   The field position in the data points to minimize. This is applicable to Tuple types, Scala
@@ -350,8 +350,8 @@ class KeyedStream[T, K](javaStream: KeyedJavaStream[T, K]) extends DataStream[T]
   def max(position: Int): DataStream[T] = aggregate(AggregationType.MAX, position)
 
   /**
-   * Applies an aggregation that that gives the current maximum of the data stream at the given
-   * field by the given key. An independent aggregate is kept per key.
+   * Applies an aggregation that gives the current maximum of the data stream at the given field by
+   * the given key. An independent aggregate is kept per key.
    *
    * @param field
    *   In case of a POJO, Scala case class, or Tuple type, the name of the (public) field on which
@@ -362,8 +362,8 @@ class KeyedStream[T, K](javaStream: KeyedJavaStream[T, K]) extends DataStream[T]
   def max(field: String): DataStream[T] = aggregate(AggregationType.MAX, field)
 
   /**
-   * Applies an aggregation that that gives the current minimum of the data stream at the given
-   * position by the given key. An independent aggregate is kept per key.
+   * Applies an aggregation that gives the current minimum of the data stream at the given position
+   * by the given key. An independent aggregate is kept per key.
    *
    * @param position
    *   The field position in the data points to minimize. This is applicable to Tuple types, Scala
@@ -372,8 +372,8 @@ class KeyedStream[T, K](javaStream: KeyedJavaStream[T, K]) extends DataStream[T]
   def min(position: Int): DataStream[T] = aggregate(AggregationType.MIN, position)
 
   /**
-   * Applies an aggregation that that gives the current minimum of the data stream at the given
-   * field by the given key. An independent aggregate is kept per key.
+   * Applies an aggregation that gives the current minimum of the data stream at the given field by
+   * the given key. An independent aggregate is kept per key.
    *
    * @param field
    *   In case of a POJO, Scala case class, or Tuple type, the name of the (public) field on which
@@ -406,9 +406,9 @@ class KeyedStream[T, K](javaStream: KeyedJavaStream[T, K]) extends DataStream[T]
   def sum(field: String): DataStream[T] = aggregate(AggregationType.SUM, field)
 
   /**
-   * Applies an aggregation that that gives the current minimum element of the data stream by the
-   * given position by the given key. An independent aggregate is kept per key. When equality, the
-   * first element is returned with the minimal value.
+   * Applies an aggregation that gives the current minimum element of the data stream by the given
+   * position by the given key. An independent aggregate is kept per key. When equality, the first
+   * element is returned with the minimal value.
    *
    * @param position
    *   The field position in the data points to minimize. This is applicable to Tuple types, Scala
@@ -417,9 +417,9 @@ class KeyedStream[T, K](javaStream: KeyedJavaStream[T, K]) extends DataStream[T]
   def minBy(position: Int): DataStream[T] = aggregate(AggregationType.MINBY, position)
 
   /**
-   * Applies an aggregation that that gives the current minimum element of the data stream by the
-   * given field by the given key. An independent aggregate is kept per key. When equality, the
-   * first element is returned with the minimal value.
+   * Applies an aggregation that gives the current minimum element of the data stream by the given
+   * field by the given key. An independent aggregate is kept per key. When equality, the first
+   * element is returned with the minimal value.
    *
    * @param field
    *   In case of a POJO, Scala case class, or Tuple type, the name of the (public) field on which
@@ -430,9 +430,9 @@ class KeyedStream[T, K](javaStream: KeyedJavaStream[T, K]) extends DataStream[T]
   def minBy(field: String): DataStream[T] = aggregate(AggregationType.MINBY, field)
 
   /**
-   * Applies an aggregation that that gives the current maximum element of the data stream by the
-   * given position by the given key. An independent aggregate is kept per key. When equality, the
-   * first element is returned with the maximal value.
+   * Applies an aggregation that gives the current maximum element of the data stream by the given
+   * position by the given key. An independent aggregate is kept per key. When equality, the first
+   * element is returned with the maximal value.
    *
    * @param position
    *   The field position in the data points to minimize. This is applicable to Tuple types, Scala
@@ -442,9 +442,9 @@ class KeyedStream[T, K](javaStream: KeyedJavaStream[T, K]) extends DataStream[T]
     aggregate(AggregationType.MAXBY, position)
 
   /**
-   * Applies an aggregation that that gives the current maximum element of the data stream by the
-   * given field by the given key. An independent aggregate is kept per key. When equality, the
-   * first element is returned with the maximal value.
+   * Applies an aggregation that gives the current maximum element of the data stream by the given
+   * field by the given key. An independent aggregate is kept per key. When equality, the first
+   * element is returned with the maximal value.
    *
    * @param field
    *   In case of a POJO, Scala case class, or Tuple type, the name of the (public) field on which
diff --git a/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/WindowedStream.scala b/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/WindowedStream.scala
index c0699b950c8..6f373642415 100644
--- a/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/WindowedStream.scala
+++ b/flink-streaming-scala/src/main/scala/org/apache/flink/streaming/api/scala/WindowedStream.scala
@@ -532,26 +532,24 @@ class WindowedStream[T, K, W <: Window](javaStream: JavaWStream[T, K, W]) {
   // ------------------------------------------------------------------------
 
   /**
-   * Applies an aggregation that that gives the maximum of the elements in the window at the given
+   * Applies an aggregation that gives the maximum of the elements in the window at the given
    * position.
    */
   def max(position: Int): DataStream[T] = aggregate(AggregationType.MAX, position)
 
   /**
-   * Applies an aggregation that that gives the maximum of the elements in the window at the given
-   * field.
+   * Applies an aggregation that gives the maximum of the elements in the window at the given field.
    */
   def max(field: String): DataStream[T] = aggregate(AggregationType.MAX, field)
 
   /**
-   * Applies an aggregation that that gives the minimum of the elements in the window at the given
+   * Applies an aggregation that gives the minimum of the elements in the window at the given
    * position.
    */
   def min(position: Int): DataStream[T] = aggregate(AggregationType.MIN, position)
 
   /**
-   * Applies an aggregation that that gives the minimum of the elements in the window at the given
-   * field.
+   * Applies an aggregation that gives the minimum of the elements in the window at the given field.
    */
   def min(field: String): DataStream[T] = aggregate(AggregationType.MIN, field)
 
@@ -562,26 +560,26 @@ class WindowedStream[T, K, W <: Window](javaStream: JavaWStream[T, K, W]) {
   def sum(field: String): DataStream[T] = aggregate(AggregationType.SUM, field)
 
   /**
-   * Applies an aggregation that that gives the maximum element of the window by the given position.
-   * When equality, returns the first.
+   * Applies an aggregation that gives the maximum element of the window by the given position. When
+   * equality, returns the first.
    */
   def maxBy(position: Int): DataStream[T] = aggregate(AggregationType.MAXBY, position)
 
   /**
-   * Applies an aggregation that that gives the maximum element of the window by the given field.
-   * When equality, returns the first.
+   * Applies an aggregation that gives the maximum element of the window by the given field. When
+   * equality, returns the first.
    */
   def maxBy(field: String): DataStream[T] = aggregate(AggregationType.MAXBY, field)
 
   /**
-   * Applies an aggregation that that gives the minimum element of the window by the given position.
-   * When equality, returns the first.
+   * Applies an aggregation that gives the minimum element of the window by the given position. When
+   * equality, returns the first.
    */
   def minBy(position: Int): DataStream[T] = aggregate(AggregationType.MINBY, position)
 
   /**
-   * Applies an aggregation that that gives the minimum element of the window by the given field.
-   * When equality, returns the first.
+   * Applies an aggregation that gives the minimum element of the window by the given field. When
+   * equality, returns the first.
    */
   def minBy(field: String): DataStream[T] = aggregate(AggregationType.MINBY, field)
 
diff --git a/flink-yarn/src/main/java/org/apache/flink/yarn/configuration/YarnConfigOptions.java b/flink-yarn/src/main/java/org/apache/flink/yarn/configuration/YarnConfigOptions.java
index 01df007510a..ad510dda2a3 100644
--- a/flink-yarn/src/main/java/org/apache/flink/yarn/configuration/YarnConfigOptions.java
+++ b/flink-yarn/src/main/java/org/apache/flink/yarn/configuration/YarnConfigOptions.java
@@ -97,7 +97,7 @@ public class YarnConfigOptions {
                                             "Number of ApplicationMaster restarts. By default, the value will be set to 1. "
                                                     + "If high availability is enabled, then the default value will be 2. "
                                                     + "The restart number is also limited by YARN (configured via %s). "
-                                                    + "Note that that the entire Flink cluster will restart and the YARN Client will lose the connection.",
+                                                    + "Note that the entire Flink cluster will restart and the YARN Client will lose the connection.",
                                             link(
                                                     "https://hadoop.apache.org/docs/stable/hadoop-yarn/hadoop-yarn-common/yarn-default.xml",
                                                     "yarn.resourcemanager.am.max-attempts"))