You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by al...@apache.org on 2016/06/27 15:50:36 UTC

[3/4] flink git commit: Fixing typos in the javadocs.

Fixing typos in the javadocs.


Project: http://git-wip-us.apache.org/repos/asf/flink/repo
Commit: http://git-wip-us.apache.org/repos/asf/flink/commit/8803d15e
Tree: http://git-wip-us.apache.org/repos/asf/flink/tree/8803d15e
Diff: http://git-wip-us.apache.org/repos/asf/flink/diff/8803d15e

Branch: refs/heads/master
Commit: 8803d15e886dac1f747a04573c03e4aa19cfe91f
Parents: 819fb27
Author: kl0u <kk...@gmail.com>
Authored: Wed Jun 22 17:37:46 2016 +0200
Committer: Aljoscha Krettek <al...@gmail.com>
Committed: Mon Jun 27 17:16:12 2016 +0200

----------------------------------------------------------------------
 .../runtime/io/network/partition/consumer/InputGate.java  |  4 +++-
 .../streaming/runtime/io/CheckpointBarrierHandler.java    | 10 +++++-----
 .../flink/streaming/runtime/io/StreamInputProcessor.java  |  4 +---
 .../runtime/operators/windowing/MergingWindowSet.java     |  9 ++++-----
 .../streamrecord/MultiplexingStreamRecordSerializer.java  |  4 ++--
 5 files changed, 15 insertions(+), 16 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/8803d15e/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/partition/consumer/InputGate.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/partition/consumer/InputGate.java b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/partition/consumer/InputGate.java
index d49b27e..1cd5fc5 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/partition/consumer/InputGate.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/partition/consumer/InputGate.java
@@ -61,7 +61,9 @@ import java.io.IOException;
  *
  * <p> In the above example, two map subtasks produce the intermediate result in parallel, resulting
  * in two partitions (Partition 1 and 2). Each of these partitions is further partitioned into two
- * subpartitions -- one for each parallel reduce subtask.
+ * subpartitions -- one for each parallel reduce subtask. As shown in the Figure, each reduce task
+ * will have an input gate attached to it. This will provide its input, which will consist of one
+ * subpartition from each partition of the intermediate result.
  */
 public interface InputGate {
 

http://git-wip-us.apache.org/repos/asf/flink/blob/8803d15e/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/CheckpointBarrierHandler.java
----------------------------------------------------------------------
diff --git a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/CheckpointBarrierHandler.java b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/CheckpointBarrierHandler.java
index ef277a6..5aa2030 100644
--- a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/CheckpointBarrierHandler.java
+++ b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/CheckpointBarrierHandler.java
@@ -35,12 +35,12 @@ public interface CheckpointBarrierHandler {
 
 	/**
 	 * Returns the next {@link BufferOrEvent} that the operator may consume.
-	 * This call blocks until the next BufferOrEvent is available, ir until the stream
+	 * This call blocks until the next BufferOrEvent is available, or until the stream
 	 * has been determined to be finished.
 	 * 
 	 * @return The next BufferOrEvent, or {@code null}, if the stream is finished.
-	 * @throws java.io.IOException Thrown, if the network or local disk I/O fails.
-	 * @throws java.lang.InterruptedException Thrown, if the thread is interrupted while blocking during
+	 * @throws java.io.IOException Thrown if the network or local disk I/O fails.
+	 * @throws java.lang.InterruptedException Thrown if the thread is interrupted while blocking during
 	 *                                        waiting for the next BufferOrEvent to become available.
 	 */
 	BufferOrEvent getNextNonBlocked() throws IOException, InterruptedException;
@@ -55,13 +55,13 @@ public interface CheckpointBarrierHandler {
 	/**
 	 * Cleans up all internally held resources.
 	 * 
-	 * @throws IOException Thrown, if the cleanup of I/O resources failed.
+	 * @throws IOException Thrown if the cleanup of I/O resources failed.
 	 */
 	void cleanup() throws IOException;
 
 	/**
 	 * Checks if the barrier handler has buffered any data internally.
-	 * @return True, if no data is buffered internally, false otherwise.
+	 * @return {@code True}, if no data is buffered internally, {@code false} otherwise.
 	 */
 	boolean isEmpty();
 }

http://git-wip-us.apache.org/repos/asf/flink/blob/8803d15e/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/StreamInputProcessor.java
----------------------------------------------------------------------
diff --git a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/StreamInputProcessor.java b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/StreamInputProcessor.java
index 657d973..5578365 100644
--- a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/StreamInputProcessor.java
+++ b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/io/StreamInputProcessor.java
@@ -76,8 +76,6 @@ public class StreamInputProcessor<IN> {
 
 	private boolean isFinished;
 
-
-
 	private final long[] watermarks;
 	private long lastEmittedWatermark;
 
@@ -101,7 +99,7 @@ public class StreamInputProcessor<IN> {
 			this.barrierHandler = new BarrierTracker(inputGate);
 		}
 		else {
-			throw new IllegalArgumentException("Unrecognized CheckpointingMode: " + checkpointMode);
+			throw new IllegalArgumentException("Unrecognized Checkpointing Mode: " + checkpointMode);
 		}
 		
 		if (checkpointListener != null) {

http://git-wip-us.apache.org/repos/asf/flink/blob/8803d15e/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/operators/windowing/MergingWindowSet.java
----------------------------------------------------------------------
diff --git a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/operators/windowing/MergingWindowSet.java b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/operators/windowing/MergingWindowSet.java
index 49a2017..d02a348 100644
--- a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/operators/windowing/MergingWindowSet.java
+++ b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/operators/windowing/MergingWindowSet.java
@@ -41,8 +41,8 @@ import java.util.Map;
  * {@link #getStateWindow(Window)}.
  *
  * <p>A new window can be added to the set of in-flight windows using
- * {@link #addWindow(Window, MergeFunction)}, this might merge other windows and the caller
- * must react accordingly in {@link MergeFunction#merge(Object, Collection, Object, Collection)
+ * {@link #addWindow(Window, MergeFunction)}. This might merge other windows and the caller
+ * must react accordingly in the {@link MergeFunction#merge(Object, Collection, Object, Collection)
  * and adjust the outside view of windows and state.
  *
  * <p>Windows can be removed from the set of windows using {@link #retireWindow(Window)}.
@@ -70,7 +70,6 @@ public class MergingWindowSet<W extends Window> {
 	 */
 	public MergingWindowSet(MergingWindowAssigner<?, W> windowAssigner) {
 		this.windowAssigner = windowAssigner;
-
 		windows = new HashMap<>();
 	}
 
@@ -127,12 +126,12 @@ public class MergingWindowSet<W extends Window> {
 	 * {@link MergeFunction} is called.
 	 *
 	 * <p>This returns the window that is the representative of the added window after adding.
-	 * This can either be the new window itself, if no merge occured, or the newly merged
+	 * This can either be the new window itself, if no merge occurred, or the newly merged
 	 * window. Adding an element to a window or calling trigger functions should only
 	 * happen on the returned representative. This way, we never have to deal with a new window
 	 * that is immediately swallowed up by another window.
 	 *
-	 * <p>If the new window is merged the {@code MergeFunction} callback arguments also don't
+	 * <p>If the new window is merged, the {@code MergeFunction} callback arguments also don't
 	 * contain the new window as part of the list of merged windows.
 	 *
 	 * @param newWindow The new {@code Window} to add.

http://git-wip-us.apache.org/repos/asf/flink/blob/8803d15e/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/streamrecord/MultiplexingStreamRecordSerializer.java
----------------------------------------------------------------------
diff --git a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/streamrecord/MultiplexingStreamRecordSerializer.java b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/streamrecord/MultiplexingStreamRecordSerializer.java
index af6349b..832c4b6 100644
--- a/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/streamrecord/MultiplexingStreamRecordSerializer.java
+++ b/flink-streaming-java/src/main/java/org/apache/flink/streaming/runtime/streamrecord/MultiplexingStreamRecordSerializer.java
@@ -30,8 +30,8 @@ import static java.util.Objects.requireNonNull;
 
 /**
  * Serializer for {@link StreamRecord} and {@link Watermark}. This does not behave like a normal
- * {@link TypeSerializer}, instead, this is only used at the stream task/opertator level for
- * transmitting StreamRecords} and Watermarks.
+ * {@link TypeSerializer}, instead, this is only used at the stream task/operator level for
+ * transmitting StreamRecords and Watermarks.
  *
  * @param <T> The type of value in the StreamRecord
  */