You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by dw...@apache.org on 2018/12/30 14:31:34 UTC

[flink] branch master updated: [hotfix][docs] Fix incorrectly spelled "the" as "teh"

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

dwysakowicz 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 ee81c0f  [hotfix][docs] Fix incorrectly spelled "the" as "teh"
ee81c0f is described below

commit ee81c0f151d32d98308a6a83cd4b59a7813fbfdc
Author: Yangze Guo <ka...@gmail.com>
AuthorDate: Sun Dec 30 22:31:27 2018 +0800

    [hotfix][docs] Fix incorrectly spelled "the" as "teh"
---
 .../main/java/org/apache/flink/api/common/ExecutionConfig.java    | 2 +-
 .../apache/flink/api/common/typeutils/base/ListSerializer.java    | 2 +-
 flink-dist/src/main/resources/flink-conf.yaml                     | 2 +-
 .../src/main/java/org/apache/flink/api/java/ClosureCleaner.java   | 2 +-
 .../main/java/org/apache/flink/optimizer/dag/OptimizerNode.java   | 2 +-
 .../runtime/highavailability/zookeeper/ZooKeeperHaServices.java   | 2 +-
 .../src/main/scala/org/apache/flink/runtime/akka/AkkaUtils.scala  | 2 +-
 .../java/org/apache/flink/runtime/state/StateBackendTestBase.java | 8 ++++----
 .../java/org/apache/flink/streaming/runtime/io/BufferSpiller.java | 2 +-
 .../org/apache/flink/streaming/runtime/io/StreamRecordWriter.java | 2 +-
 10 files changed, 13 insertions(+), 13 deletions(-)

diff --git a/flink-core/src/main/java/org/apache/flink/api/common/ExecutionConfig.java b/flink-core/src/main/java/org/apache/flink/api/common/ExecutionConfig.java
index 3b3132b..16b2adf 100644
--- a/flink-core/src/main/java/org/apache/flink/api/common/ExecutionConfig.java
+++ b/flink-core/src/main/java/org/apache/flink/api/common/ExecutionConfig.java
@@ -554,7 +554,7 @@ public class ExecutionConfig implements Serializable, Archiveable<ArchivedExecut
 	 * is used, Flink will throw an {@code UnsupportedOperationException} whenever it encounters
 	 * a data type that would go through Kryo for serialization.
 	 *
-	 * <p>Disabling generic types can be helpful to eagerly find and eliminate teh use of types
+	 * <p>Disabling generic types can be helpful to eagerly find and eliminate the use of types
 	 * that would go through Kryo serialization during runtime. Rather than checking types
 	 * individually, using this option will throw exceptions eagerly in the places where generic
 	 * types are used.
diff --git a/flink-core/src/main/java/org/apache/flink/api/common/typeutils/base/ListSerializer.java b/flink-core/src/main/java/org/apache/flink/api/common/typeutils/base/ListSerializer.java
index ec2b542..08b3333 100644
--- a/flink-core/src/main/java/org/apache/flink/api/common/typeutils/base/ListSerializer.java
+++ b/flink-core/src/main/java/org/apache/flink/api/common/typeutils/base/ListSerializer.java
@@ -32,7 +32,7 @@ import static org.apache.flink.util.Preconditions.checkNotNull;
 
 /**
  * A serializer for {@link List Lists}. The serializer relies on an element serializer
- * for teh serialization of the list's elements.
+ * for the serialization of the list's elements.
  *
  * <p>The serialization format for the list is as follows: four bytes for the length of the lost,
  * followed by the serialized representation of each element.
diff --git a/flink-dist/src/main/resources/flink-conf.yaml b/flink-dist/src/main/resources/flink-conf.yaml
index efdf33e..25d4435 100644
--- a/flink-dist/src/main/resources/flink-conf.yaml
+++ b/flink-dist/src/main/resources/flink-conf.yaml
@@ -181,7 +181,7 @@ rest.port: 8081
 
 # The amount of memory going to the network stack. These numbers usually need 
 # no tuning. Adjusting them may be necessary in case of an "Insufficient number
-# of network buffers" error. The default min is 64MB, teh default max is 1GB.
+# of network buffers" error. The default min is 64MB, the default max is 1GB.
 # 
 # taskmanager.network.memory.fraction: 0.1
 # taskmanager.network.memory.min: 64mb
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/ClosureCleaner.java b/flink-java/src/main/java/org/apache/flink/api/java/ClosureCleaner.java
index bdc0c67..d4c619d 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/ClosureCleaner.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/ClosureCleaner.java
@@ -56,7 +56,7 @@ public class ClosureCleaner {
 	 *                                 not serializable after the closure cleaning.
 	 *
 	 * @throws RuntimeException A RuntimeException may be thrown, if the code of the class could not
-	 *                          be loaded, in order to process during teh closure cleaning.
+	 *                          be loaded, in order to process during the closure cleaning.
 	 */
 	public static void clean(Object func, boolean checkSerializable) {
 		if (func == null) {
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 cff8f18..fbba03b 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
@@ -1148,7 +1148,7 @@ public abstract class OptimizerNode implements Visitable<OptimizerNode>, Estimat
 		/**
 		 * Creates a new branching descriptor.
 		 *
-		 * @param branchingNode The node where the branch occurred (teh node with multiple outputs).
+		 * @param branchingNode The node where the branch occurred (the node with multiple outputs).
 		 * @param joinedPathsVector A bit vector describing which branches are tracked by this descriptor.
 		 *                          The bit vector is one, where the branch is tracked, zero otherwise.
 		 */
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/highavailability/zookeeper/ZooKeeperHaServices.java b/flink-runtime/src/main/java/org/apache/flink/runtime/highavailability/zookeeper/ZooKeeperHaServices.java
index ea96d7d..114d281 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/highavailability/zookeeper/ZooKeeperHaServices.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/highavailability/zookeeper/ZooKeeperHaServices.java
@@ -44,7 +44,7 @@ import static org.apache.flink.util.Preconditions.checkNotNull;
 
 /**
  * An implementation of the {@link HighAvailabilityServices} using Apache ZooKeeper.
- * The services store data in ZooKeeper's nodes as illustrated by teh following tree structure:
+ * The services store data in ZooKeeper's nodes as illustrated by the following tree structure:
  * 
  * <pre>
  * /flink
diff --git a/flink-runtime/src/main/scala/org/apache/flink/runtime/akka/AkkaUtils.scala b/flink-runtime/src/main/scala/org/apache/flink/runtime/akka/AkkaUtils.scala
index 24448c7..b8c2cdc 100644
--- a/flink-runtime/src/main/scala/org/apache/flink/runtime/akka/AkkaUtils.scala
+++ b/flink-runtime/src/main/scala/org/apache/flink/runtime/akka/AkkaUtils.scala
@@ -841,7 +841,7 @@ object AkkaUtils {
     *
     * @param akkaURL The URL to extract the host and port from.
     * @throws java.lang.Exception Thrown, if the given string does not represent a proper url
-    * @return The InetSocketAddress with teh extracted host and port.
+    * @return The InetSocketAddress with the extracted host and port.
     */
   @throws(classOf[Exception])
   def getInetSocketAddressFromAkkaURL(akkaURL: String): InetSocketAddress = {
diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/state/StateBackendTestBase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/state/StateBackendTestBase.java
index a9bd1f6..f51ab31 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/state/StateBackendTestBase.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/state/StateBackendTestBase.java
@@ -1951,7 +1951,7 @@ public abstract class StateBackendTestBase<B extends AbstractStateBackend> exten
 
 			// populate the different namespaces
 			//  - abc spreads the values over three namespaces
-			//  - def spreads teh values over two namespaces (one empty)
+			//  - def spreads the values over two namespaces (one empty)
 			//  - ghi is empty
 			//  - jkl has all elements already in the target namespace
 			//  - mno has all elements already in one source namespace
@@ -2223,7 +2223,7 @@ public abstract class StateBackendTestBase<B extends AbstractStateBackend> exten
 
 			// populate the different namespaces
 			//  - abc spreads the values over three namespaces
-			//  - def spreads teh values over two namespaces (one empty)
+			//  - def spreads the values over two namespaces (one empty)
 			//  - ghi is empty
 			//  - jkl has all elements already in the target namespace
 			//  - mno has all elements already in one source namespace
@@ -2396,7 +2396,7 @@ public abstract class StateBackendTestBase<B extends AbstractStateBackend> exten
 
 			// populate the different namespaces
 			//  - abc spreads the values over three namespaces
-			//  - def spreads teh values over two namespaces (one empty)
+			//  - def spreads the values over two namespaces (one empty)
 			//  - ghi is empty
 			//  - jkl has all elements already in the target namespace
 			//  - mno has all elements already in one source namespace
@@ -2569,7 +2569,7 @@ public abstract class StateBackendTestBase<B extends AbstractStateBackend> exten
 
 			// populate the different namespaces
 			//  - abc spreads the values over three namespaces
-			//  - def spreads teh values over two namespaces (one empty)
+			//  - def spreads the values over two namespaces (one empty)
 			//  - ghi is empty
 			//  - jkl has all elements already in the target namespace
 			//  - mno has all elements already in one source namespace
diff --git a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/BufferSpiller.java b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/BufferSpiller.java
index ae95408..7000430 100644
--- a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/BufferSpiller.java
+++ b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/BufferSpiller.java
@@ -94,7 +94,7 @@ public class BufferSpiller implements BufferBlocker {
 	/**
 	 * Creates a new buffer spiller, spilling to one of the I/O manager's temp directories.
 	 *
-	 * @param ioManager The I/O manager for access to teh temp directories.
+	 * @param ioManager The I/O manager for access to the temp directories.
 	 * @param pageSize The page size used to re-create spilled buffers.
 	 * @throws IOException Thrown if the temp files for spilling cannot be initialized.
 	 */
diff --git a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/StreamRecordWriter.java b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/StreamRecordWriter.java
index 3f174b0..acda489 100644
--- a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/StreamRecordWriter.java
+++ b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/StreamRecordWriter.java
@@ -36,7 +36,7 @@ import static org.apache.flink.util.Preconditions.checkArgument;
 @Internal
 public class StreamRecordWriter<T extends IOReadableWritable> extends RecordWriter<T> {
 
-	/** Default name for teh output flush thread, if no name with a task reference is given. */
+	/** Default name for the output flush thread, if no name with a task reference is given. */
 	private static final String DEFAULT_OUTPUT_FLUSH_THREAD_NAME = "OutputFlusher";