You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by fh...@apache.org on 2015/10/29 13:22:41 UTC

[08/13] flink git commit: [FLINK-2559] Clean up JavaDocs

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/relational/WebLogAnalysis.java
----------------------------------------------------------------------
diff --git a/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/relational/WebLogAnalysis.java b/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/relational/WebLogAnalysis.java
index 9425291..79944ae 100644
--- a/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/relational/WebLogAnalysis.java
+++ b/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/relational/WebLogAnalysis.java
@@ -35,7 +35,7 @@ import org.apache.flink.examples.java.relational.util.WebLogDataGenerator;
  * This program processes web logs and relational data. 
  * It implements the following relational query:
  *
- * <code><pre>
+ * <pre>{@code
  * SELECT 
  *       r.pageURL, 
  *       r.pageRank, 
@@ -50,13 +50,13 @@ import org.apache.flink.examples.java.relational.util.WebLogDataGenerator;
  *              WHERE v.destUrl = d.url 
  *                    AND v.visitDate < [date]
  *           );
- * </pre></code>
+ * }</pre>
  *
  * <p>
  * Input files are plain text CSV files using the pipe character ('|') as field separator.
  * The tables referenced in the query can be generated using the {@link WebLogDataGenerator} and 
  * have the following schemas
- * <code><pre>
+ * <pre>{@code
  * CREATE TABLE Documents (
  *                url VARCHAR(100) PRIMARY KEY,
  *                contents TEXT );
@@ -76,7 +76,7 @@ import org.apache.flink.examples.java.relational.util.WebLogDataGenerator;
  *                languageCode VARCHAR(6),
  *                searchWord VARCHAR(32),
  *                duration INT );
- * </pre></code>
+ * }</pre>
  * 
  * <p>
  * Usage: <code>WebLogAnalysis &lt;documents path&gt; &lt;ranks path&gt; &lt;visits path&gt; &lt;result path&gt;</code><br>

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/PojoExample.java
----------------------------------------------------------------------
diff --git a/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/PojoExample.java b/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/PojoExample.java
index b001d12..0a8595f 100644
--- a/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/PojoExample.java
+++ b/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/PojoExample.java
@@ -112,7 +112,7 @@ public class PojoExample {
 	/**
 	 * Implements the string tokenizer that splits sentences into words as a user-defined
 	 * FlatMapFunction. The function takes a line (String) and splits it into 
-	 * multiple pairs in the form of "(word,1)" (Tuple2<String, Integer>).
+	 * multiple pairs in the form of "(word,1)" ({@code Tuple2<String, Integer>}).
 	 */
 	public static final class Tokenizer implements FlatMapFunction<String, Word> {
 		private static final long serialVersionUID = 1L;

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCount.java
----------------------------------------------------------------------
diff --git a/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCount.java b/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCount.java
index e6b8418..c677160 100644
--- a/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCount.java
+++ b/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCount.java
@@ -90,7 +90,7 @@ public class WordCount {
 	/**
 	 * Implements the string tokenizer that splits sentences into words as a user-defined
 	 * FlatMapFunction. The function takes a line (String) and splits it into 
-	 * multiple pairs in the form of "(word,1)" (Tuple2<String, Integer>).
+	 * multiple pairs in the form of "(word,1)" ({@code Tuple2<String, Integer>}).
 	 */
 	public static final class Tokenizer implements FlatMapFunction<String, Tuple2<String, Integer>> {
 

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCountMeta.java
----------------------------------------------------------------------
diff --git a/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCountMeta.java b/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCountMeta.java
index b8bd7c1..200fd0f 100644
--- a/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCountMeta.java
+++ b/flink-examples/flink-java-examples/src/main/java/org/apache/flink/examples/java/wordcount/WordCountMeta.java
@@ -22,7 +22,7 @@ import org.apache.flink.api.common.ProgramDescription;
 import org.apache.flink.examples.java.wordcount.util.WordCountData;
 
 /**
- * Same as {@link WorkCount} but implements {@link ProgramDescription} interface.
+ * Same as {@link WordCount} but implements {@link ProgramDescription} interface.
  * 
  * <p>
  * The input is a plain text file with lines separated by newline characters.
@@ -35,7 +35,7 @@ import org.apache.flink.examples.java.wordcount.util.WordCountData;
  * This example shows:
  * <ul>
  * <li>how to provide additional information (using {@link ProgramDescription} interface}, that can be displayed by
- * Flink clients, ie, {@link bin/flink} and WebClient</li>
+ * Flink clients, ie, bin/flink and WebClient</li>
  * </ul>
  * 
  */

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/DataSet.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/DataSet.java b/flink-java/src/main/java/org/apache/flink/api/java/DataSet.java
index 3101f35..81a747e 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/DataSet.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/DataSet.java
@@ -92,7 +92,7 @@ import java.util.ArrayList;
 import java.util.List;
 
 /**
- * A DataSet represents a collection of elements of the same type.<br/>
+ * A DataSet represents a collection of elements of the same type.<br>
  * A DataSet can be transformed into another DataSet by applying a transformation as for example 
  * <ul>
  *   <li>{@link DataSet#map(org.apache.flink.api.common.functions.MapFunction)},</li>
@@ -193,7 +193,7 @@ public abstract class DataSet<T> {
 	// --------------------------------------------------------------------------------------------
 	
 	/**
-	 * Applies a Map transformation on this DataSet.<br/>
+	 * Applies a Map transformation on this DataSet.<br>
 	 * The transformation calls a {@link org.apache.flink.api.common.functions.MapFunction} for each element of the DataSet.
 	 * Each MapFunction call returns exactly one element.
 	 * 
@@ -244,7 +244,7 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Applies a FlatMap transformation on a {@link DataSet}.<br/>
+	 * Applies a FlatMap transformation on a {@link DataSet}.<br>
 	 * The transformation calls a {@link org.apache.flink.api.common.functions.RichFlatMapFunction} for each element of the DataSet.
 	 * Each FlatMapFunction call can return any number of elements including none.
 	 * 
@@ -266,7 +266,7 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Applies a Filter transformation on a {@link DataSet}.<br/>
+	 * Applies a Filter transformation on a {@link DataSet}.<br>
 	 * The transformation calls a {@link org.apache.flink.api.common.functions.RichFilterFunction} for each element of the DataSet
 	 * and retains only those element for which the function returns true. Elements for 
 	 * which the function returns false are filtered. 
@@ -291,9 +291,9 @@ public abstract class DataSet<T> {
 	// --------------------------------------------------------------------------------------------
 	
 	/**
-	 * Applies a Project transformation on a {@link Tuple} {@link DataSet}.<br/>
-	 * <b>Note: Only Tuple DataSets can be projected using field indexes.</b><br/>
-	 * The transformation projects each Tuple of the DataSet onto a (sub)set of fields.<br/>
+	 * Applies a Project transformation on a {@link Tuple} {@link DataSet}.<br>
+	 * <b>Note: Only Tuple DataSets can be projected using field indexes.</b><br>
+	 * The transformation projects each Tuple of the DataSet onto a (sub)set of fields.<br>
 	 * Additional fields can be added to the projection by calling {@link ProjectOperator#project(int[])}.
 	 *
 	 * <b>Note: With the current implementation, the Project transformation looses type information.</b>
@@ -315,7 +315,7 @@ public abstract class DataSet<T> {
 	// --------------------------------------------------------------------------------------------
 	
 	/**
-	 * Applies an Aggregate transformation on a non-grouped {@link Tuple} {@link DataSet}.<br/>
+	 * Applies an Aggregate transformation on a non-grouped {@link Tuple} {@link DataSet}.<br>
 	 * <b>Note: Only Tuple DataSets can be aggregated.</b>
 	 * The transformation applies a built-in {@link Aggregations Aggregation} on a specified field 
 	 *   of a Tuple DataSet. Additional aggregation functions can be added to the resulting 
@@ -424,7 +424,7 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Applies a Reduce transformation on a non-grouped {@link DataSet}.<br/>
+	 * Applies a Reduce transformation on a non-grouped {@link DataSet}.<br>
 	 * The transformation consecutively calls a {@link org.apache.flink.api.common.functions.RichReduceFunction}
 	 *   until only a single element remains which is the result of the transformation.
 	 * A ReduceFunction combines two elements into one new element of the same type.
@@ -444,7 +444,7 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Applies a GroupReduce transformation on a non-grouped {@link DataSet}.<br/>
+	 * Applies a GroupReduce transformation on a non-grouped {@link DataSet}.<br>
 	 * The transformation calls a {@link org.apache.flink.api.common.functions.RichGroupReduceFunction} once with the full DataSet.
 	 * The GroupReduceFunction can iterate over all elements of the DataSet and emit any
 	 *   number of output elements including none.
@@ -561,7 +561,7 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Returns a new set containing the first n elements in this {@link DataSet}.<br/>
+	 * Returns a new set containing the first n elements in this {@link DataSet}.<br>
 	 * @param n The desired number of elements.
 	 * @return A ReduceGroupOperator that represents the DataSet containing the elements.
 	*/
@@ -640,7 +640,7 @@ public abstract class DataSet<T> {
 	/**
 	 * Groups a {@link DataSet} using a {@link KeySelector} function. 
 	 * The KeySelector function is called for each element of the DataSet and extracts a single 
-	 *   key value on which the DataSet is grouped. <br/>
+	 *   key value on which the DataSet is grouped. <br>
 	 * This method returns an {@link UnsortedGrouping} on which one of the following grouping transformation 
 	 *   can be applied. 
 	 * <ul>
@@ -666,8 +666,8 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Groups a {@link Tuple} {@link DataSet} using field position keys.<br/> 
-	 * <b>Note: Field position keys only be specified for Tuple DataSets.</b><br/>
+	 * Groups a {@link Tuple} {@link DataSet} using field position keys.<br> 
+	 * <b>Note: Field position keys only be specified for Tuple DataSets.</b><br>
 	 * The field position keys specify the fields of Tuples on which the DataSet is grouped.
 	 * This method returns an {@link UnsortedGrouping} on which one of the following grouping transformation 
 	 *   can be applied. 
@@ -724,10 +724,10 @@ public abstract class DataSet<T> {
 	// --------------------------------------------------------------------------------------------
 	
 	/**
-	 * Initiates a Join transformation. <br/>
+	 * Initiates a Join transformation. <br>
 	 * A Join transformation joins the elements of two 
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine 
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * 
 	 * This method returns a {@link JoinOperatorSets} on which one of the {@code where} methods
 	 * can be called to define the join key of the first joining (i.e., this) DataSet.
@@ -743,10 +743,10 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Initiates a Join transformation. <br/>
+	 * Initiates a Join transformation. <br>
 	 * A Join transformation joins the elements of two 
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine 
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * 
 	 * This method returns a {@link JoinOperatorSets} on which one of the {@code where} methods
 	 * can be called to define the join key of the first joining (i.e., this) DataSet.
@@ -764,12 +764,12 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Initiates a Join transformation. <br/>
+	 * Initiates a Join transformation. <br>
 	 * A Join transformation joins the elements of two 
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine 
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * This method also gives the hint to the optimizer that the second DataSet to join is much
-	 *   smaller than the first one.<br/>
+	 *   smaller than the first one.<br>
 	 * This method returns a {@link JoinOperatorSets} on which
 	 *   {@link JoinOperatorSets#where(String...)} needs to be called to define the join key of the first
 	 *   joining (i.e., this) DataSet.
@@ -785,12 +785,12 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Initiates a Join transformation.<br/>
+	 * Initiates a Join transformation.<br>
 	 * A Join transformation joins the elements of two 
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine 
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * This method also gives the hint to the optimizer that the second DataSet to join is much
-	 *   larger than the first one.<br/>
+	 *   larger than the first one.<br>
 	 * This method returns a {@link JoinOperatorSets} on which one of the {@code where} methods
 	 * can be called to define the join key of the first joining (i.e., this) DataSet.
 	 *  
@@ -805,10 +805,10 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Initiates a Left Outer Join transformation.<br/>
+	 * Initiates a Left Outer Join transformation.<br>
 	 * An Outer Join transformation joins two elements of two
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * Elements of the <b>left</b> DataSet (i.e. {@code this}) that do not have a matching
 	 *   element on the other side are joined with {@code null} and emitted to the
 	 *   resulting DataSet.
@@ -824,10 +824,10 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Initiates a Left Outer Join transformation.<br/>
+	 * Initiates a Left Outer Join transformation.<br>
 	 * An Outer Join transformation joins two elements of two
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * Elements of the <b>left</b> DataSet (i.e. {@code this}) that do not have a matching
 	 *   element on the other side are joined with {@code null} and emitted to the
 	 *   resulting DataSet.
@@ -854,10 +854,10 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Initiates a Right Outer Join transformation.<br/>
+	 * Initiates a Right Outer Join transformation.<br>
 	 * An Outer Join transformation joins two elements of two
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * Elements of the <b>right</b> DataSet (i.e. {@code other}) that do not have a matching
 	 *   element on {@code this} side are joined with {@code null} and emitted to the
 	 *   resulting DataSet.
@@ -873,10 +873,10 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Initiates a Right Outer Join transformation.<br/>
+	 * Initiates a Right Outer Join transformation.<br>
 	 * An Outer Join transformation joins two elements of two
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * Elements of the <b>right</b> DataSet (i.e. {@code other}) that do not have a matching
 	 *   element on {@code this} side are joined with {@code null} and emitted to the
 	 *   resulting DataSet.
@@ -902,10 +902,10 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Initiates a Full Outer Join transformation.<br/>
+	 * Initiates a Full Outer Join transformation.<br>
 	 * An Outer Join transformation joins two elements of two
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * Elements of <b>both</b> DataSets that do not have a matching
 	 *   element on the opposing side are joined with {@code null} and emitted to the
 	 *   resulting DataSet.
@@ -921,10 +921,10 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Initiates a Full Outer Join transformation.<br/>
+	 * Initiates a Full Outer Join transformation.<br>
 	 * An Outer Join transformation joins two elements of two
 	 *   {@link DataSet DataSets} on key equality and provides multiple ways to combine
-	 *   joining elements into one DataSet.<br/>
+	 *   joining elements into one DataSet.<br>
 	 * Elements of <b>both</b> DataSets that do not have a matching
 	 *   element on the opposing side are joined with {@code null} and emitted to the
 	 *   resulting DataSet.
@@ -953,14 +953,14 @@ public abstract class DataSet<T> {
 	// --------------------------------------------------------------------------------------------
 
 	/**
-	 * Initiates a CoGroup transformation.<br/>
+	 * Initiates a CoGroup transformation.<br>
 	 * A CoGroup transformation combines the elements of
 	 *   two {@link DataSet DataSets} into one DataSet. It groups each DataSet individually on a key and 
 	 *   gives groups of both DataSets with equal keys together into a {@link org.apache.flink.api.common.functions.RichCoGroupFunction}.
 	 *   If a DataSet has a group with no matching key in the other DataSet, the CoGroupFunction
-	 *   is called with an empty group for the non-existing group.<br/>
+	 *   is called with an empty group for the non-existing group.<br>
 	 * The CoGroupFunction can iterate over the elements of both groups and return any number 
-	 *   of elements including none.<br/>
+	 *   of elements including none.<br>
 	 * This method returns a {@link CoGroupOperatorSets} on which one of the {@code where} methods
 	 * can be called to define the join key of the first joining (i.e., this) DataSet.
 	 * 
@@ -981,8 +981,8 @@ public abstract class DataSet<T> {
 
 	/**
 	 * Continues a Join transformation and defines the {@link Tuple} fields of the second join 
-	 * {@link DataSet} that should be used as join keys.<br/>
-	 * <b>Note: Fields can only be selected as join keys on Tuple DataSets.</b><br/>
+	 * {@link DataSet} that should be used as join keys.<br>
+	 * <b>Note: Fields can only be selected as join keys on Tuple DataSets.</b><br>
 	 * 
 	 * The resulting {@link DefaultJoin} wraps each pair of joining elements into a {@link Tuple2}, with 
 	 * the element of the first input being the first field of the tuple and the element of the 
@@ -993,7 +993,7 @@ public abstract class DataSet<T> {
 	 */
 	
 	/**
-	 * Initiates a Cross transformation.<br/>
+	 * Initiates a Cross transformation.<br>
 	 * A Cross transformation combines the elements of two 
 	 *   {@link DataSet DataSets} into one DataSet. It builds all pair combinations of elements of 
 	 *   both DataSets, i.e., it builds a Cartesian product.
@@ -1006,7 +1006,7 @@ public abstract class DataSet<T> {
 	 * <p>
 	 * Call {@link org.apache.flink.api.java.operators.CrossOperator.DefaultCross#with(org.apache.flink.api.common.functions.CrossFunction)} to define a
 	 * {@link org.apache.flink.api.common.functions.CrossFunction} which is called for
-	 * each pair of crossed elements. The CrossFunction returns a exactly one element for each pair of input elements.<br/>
+	 * each pair of crossed elements. The CrossFunction returns a exactly one element for each pair of input elements.<br>
 	 * 
 	 * @param other The other DataSet with which this DataSet is crossed. 
 	 * @return A DefaultCross that returns a Tuple2 for each pair of crossed elements.
@@ -1021,7 +1021,7 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Initiates a Cross transformation.<br/>
+	 * Initiates a Cross transformation.<br>
 	 * A Cross transformation combines the elements of two 
 	 *   {@link DataSet DataSets} into one DataSet. It builds all pair combinations of elements of 
 	 *   both DataSets, i.e., it builds a Cartesian product.
@@ -1036,7 +1036,7 @@ public abstract class DataSet<T> {
 	 * <p>
 	 * Call {@link org.apache.flink.api.java.operators.CrossOperator.DefaultCross#with(org.apache.flink.api.common.functions.CrossFunction)} to define a
 	 * {@link org.apache.flink.api.common.functions.CrossFunction} which is called for
-	 * each pair of crossed elements. The CrossFunction returns a exactly one element for each pair of input elements.<br/>
+	 * each pair of crossed elements. The CrossFunction returns a exactly one element for each pair of input elements.<br>
 	 * 
 	 * @param other The other DataSet with which this DataSet is crossed. 
 	 * @return A DefaultCross that returns a Tuple2 for each pair of crossed elements.
@@ -1051,7 +1051,7 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Initiates a Cross transformation.<br/>
+	 * Initiates a Cross transformation.<br>
 	 * A Cross transformation combines the elements of two 
 	 *   {@link DataSet DataSets} into one DataSet. It builds all pair combinations of elements of 
 	 *   both DataSets, i.e., it builds a Cartesian product.
@@ -1066,7 +1066,7 @@ public abstract class DataSet<T> {
 	 * <p>
 	 * Call {@link org.apache.flink.api.java.operators.CrossOperator.DefaultCross#with(org.apache.flink.api.common.functions.CrossFunction)} to define a
 	 * {@link org.apache.flink.api.common.functions.CrossFunction} which is called for
-	 * each pair of crossed elements. The CrossFunction returns a exactly one element for each pair of input elements.<br/>
+	 * each pair of crossed elements. The CrossFunction returns a exactly one element for each pair of input elements.<br>
 	 * 
 	 * @param other The other DataSet with which this DataSet is crossed. 
 	 * @return A DefaultCross that returns a Tuple2 for each pair of crossed elements.
@@ -1343,7 +1343,7 @@ public abstract class DataSet<T> {
 	// --------------------------------------------------------------------------------------------
 	
 	/**
-	 * Writes a DataSet as a text file to the specified location.<br/>
+	 * Writes a DataSet as a text file to the specified location.<br>
 	 * For each element of the DataSet the result of {@link Object#toString()} is written.  
 	 * 
 	 * @param filePath The path pointing to the location the text file is written to.
@@ -1356,7 +1356,7 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Writes a DataSet as a text file to the specified location.<br/>
+	 * Writes a DataSet as a text file to the specified location.<br>
 	 * For each element of the DataSet the result of {@link Object#toString()} is written.  
 	 * 
 	 * @param filePath The path pointing to the location the text file is written to.
@@ -1372,7 +1372,7 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Writes a DataSet as a text file to the specified location.<br/>
+	 * Writes a DataSet as a text file to the specified location.<br>
 	 * For each element of the DataSet the result of {@link TextFormatter#format(Object)} is written.
 	 *
 	 * @param filePath The path pointing to the location the text file is written to.
@@ -1386,7 +1386,7 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Writes a DataSet as a text file to the specified location.<br/>
+	 * Writes a DataSet as a text file to the specified location.<br>
 	 * For each element of the DataSet the result of {@link TextFormatter#format(Object)} is written.
 	 *
 	 * @param filePath The path pointing to the location the text file is written to.
@@ -1401,10 +1401,10 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Writes a {@link Tuple} DataSet as a CSV file to the specified location.<br/>
-	 * <b>Note: Only a Tuple DataSet can written as a CSV file.</b><br/>
+	 * Writes a {@link Tuple} DataSet as a CSV file to the specified location.<br>
+	 * <b>Note: Only a Tuple DataSet can written as a CSV file.</b><br>
 	 * For each Tuple field the result of {@link Object#toString()} is written.
-	 * Tuple fields are separated by the default field delimiter {@code "comma" (,)}.<br/>
+	 * Tuple fields are separated by the default field delimiter {@code "comma" (,)}.<br>
 	 * Tuples are are separated by the newline character ({@code \n}).
 	 * 
 	 * @param filePath The path pointing to the location the CSV file is written to.
@@ -1418,10 +1418,10 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Writes a {@link Tuple} DataSet as a CSV file to the specified location.<br/>
-	 * <b>Note: Only a Tuple DataSet can written as a CSV file.</b><br/>
+	 * Writes a {@link Tuple} DataSet as a CSV file to the specified location.<br>
+	 * <b>Note: Only a Tuple DataSet can written as a CSV file.</b><br>
 	 * For each Tuple field the result of {@link Object#toString()} is written.
-	 * Tuple fields are separated by the default field delimiter {@code "comma" (,)}.<br/>
+	 * Tuple fields are separated by the default field delimiter {@code "comma" (,)}.<br>
 	 * Tuples are are separated by the newline character ({@code \n}).
 	 * 
 	 * @param filePath The path pointing to the location the CSV file is written to.
@@ -1436,8 +1436,8 @@ public abstract class DataSet<T> {
 	}
 	
 	/**
-	 * Writes a {@link Tuple} DataSet as a CSV file to the specified location with the specified field and line delimiters.<br/>
-	 * <b>Note: Only a Tuple DataSet can written as a CSV file.</b><br/>
+	 * Writes a {@link Tuple} DataSet as a CSV file to the specified location with the specified field and line delimiters.<br>
+	 * <b>Note: Only a Tuple DataSet can written as a CSV file.</b><br>
 	 * For each Tuple field the result of {@link Object#toString()} is written.
 	 * 
 	 * @param filePath The path pointing to the location the CSV file is written to.
@@ -1452,9 +1452,9 @@ public abstract class DataSet<T> {
 	}
 
 	/**
-	 * Writes a {@link Tuple} DataSet as a CSV file to the specified location with the specified field and line delimiters.<br/>
-	 * <b>Note: Only a Tuple DataSet can written as a CSV file.</b><br/>
-	 * For each Tuple field the result of {@link Object#toString()} is written.
+	 * Writes a {@link Tuple} DataSet as a CSV file to the specified location with the specified field and line delimiters.<br>
+	 * <b>Note: Only a Tuple DataSet can written as a CSV file.</b><br>
+ยง	 * For each Tuple field the result of {@link Object#toString()} is written.
 	 * 
 	 * @param filePath The path pointing to the location the CSV file is written to.
 	 * @param rowDelimiter The row delimiter to separate Tuples.

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/Utils.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/Utils.java b/flink-java/src/main/java/org/apache/flink/api/java/Utils.java
index 45a14a3..bf9ca4c 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/Utils.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/Utils.java
@@ -63,7 +63,6 @@ public final class Utils {
 	 * Returns all GenericTypeInfos contained in a composite type.
 	 *
 	 * @param typeInfo
-	 * @return
 	 */
 	public static void getContainedGenericTypes(CompositeType typeInfo, List<GenericTypeInfo<?>> target) {
 		for(int i = 0; i < typeInfo.getArity(); i++) {

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/functions/FunctionAnnotation.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/functions/FunctionAnnotation.java b/flink-java/src/main/java/org/apache/flink/api/java/functions/FunctionAnnotation.java
index bfc1bf0..a92560e 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/functions/FunctionAnnotation.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/functions/FunctionAnnotation.java
@@ -33,8 +33,8 @@ import org.apache.flink.api.common.InvalidProgramException;
  * Semantic annotations can help the Flink optimizer to generate more efficient execution plans for Flink programs.
  * For example, a <i>ForwardedFields</i> assertion for a map-type function can be declared as:
  *
- * <pre><blockquote>
- * \@ForwardedFields({"f0; f1->f2"})
+ * <pre>{@code
+ * {@literal @}ForwardedFields({"f0; f1->f2"})
  * public class MyMapper extends MapFunction<Tuple3<String, String, Integer>, Tuple3<String, Integer, Integer>>
  * {
  *     public Tuple3<String, Integer, Integer> map(Tuple3<String, String, Integer> val) {
@@ -42,7 +42,7 @@ import org.apache.flink.api.common.InvalidProgramException;
  *         return new Tuple3<String, Integer, Integer>(val.f0, val.f2, 1);
  *     }
  * }
- * </blockquote></pre>
+ * }</pre>
  *
  * <p>
  * All annotations take Strings with expressions that refer to (nested) value fields of the input and output types of a function.
@@ -84,17 +84,17 @@ public class FunctionAnnotation {
 	 *
 	 * Fields that are forwarded at the same position can be specified by their position.
 	 * The specified position must be valid for the input and output data type and have the same type.
-	 * For example <code>\@ForwardedFields({"f2"})</code> declares that the third field of a Java input tuple is
+	 * For example {@code {@literal @}ForwardedFields({"f2"})} declares that the third field of a Java input tuple is
 	 * copied to the third field of an output tuple.
 	 *
 	 * Fields which are unchanged copied to another position in the output are declared by specifying the
 	 * source field expression in the input and the target field expression in the output.
-	 * <code>\@ForwardedFields({"f0->f2"})</code> denotes that the first field of the Java input tuple is
+	 * {@code {@literal @}ForwardedFields({"f0->f2"})} denotes that the first field of the Java input tuple is
 	 * unchanged copied to the third field of the Java output tuple. When using the wildcard ("*") ensure that
 	 * the number of declared fields and their types in input and output type match.
 	 *
-	 * Multiple forwarded fields can be annotated in one (<code>\@ForwardedFields({"f2; f3->f0; f4"})</code>)
-	 * or separate Strings (<code>\@ForwardedFields({"f2", "f3->f0", "f4"})</code>).
+	 * Multiple forwarded fields can be annotated in one ({@code {@literal @}ForwardedFields({"f2; f3->f0; f4"})})
+	 * or separate Strings ({@code {@literal @}ForwardedFields({"f2", "f3->f0", "f4"})}).
 	 *
 	 * <b>NOTE: The use of the ForwardedFields annotation is optional.
 	 * If used correctly, it can help the Flink optimizer to generate more efficient execution plans.
@@ -119,17 +119,17 @@ public class FunctionAnnotation {
 	 *
 	 * Fields that are forwarded from the first input at the same position in the output can be
 	 * specified by their position. The specified position must be valid for the input and output data type and have the same type.
-	 * For example <code>\@ForwardedFieldsFirst({"f2"})</code> declares that the third field of a Java input tuple at the first input is
+	 * For example {@code {@literal @}ForwardedFieldsFirst({"f2"})} declares that the third field of a Java input tuple at the first input is
 	 * copied to the third field of an output tuple.
 	 *
 	 * Fields which are unchanged copied to another position in the output are declared by specifying the
 	 * source field expression in the input and the target field expression in the output.
-	 * <code>\@ForwardedFieldsFirst({"f0->f2"})</code> denotes that the first field of the Java input tuple at the first input is
+	 * {@code {@literal @}ForwardedFieldsFirst({"f0->f2"})} denotes that the first field of the Java input tuple at the first input is
 	 * unchanged copied to the third field of the Java output tuple. When using the wildcard ("*") ensure that
 	 * the number of declared fields and their types in input and output type match.
 	 *
-	 * Multiple forwarded fields can be annotated in one (<code>\@ForwardedFieldsFirst({"f2; f3->f0; f4"})</code>)
-	 * or separate Strings (<code>\@ForwardedFieldsFirst({"f2", "f3->f0", "f4"})</code>).
+	 * Multiple forwarded fields can be annotated in one ({@code {@literal @}ForwardedFieldsFirst({"f2; f3->f0; f4"})})
+	 * or separate Strings ({@code {@literal @}ForwardedFieldsFirst({"f2", "f3->f0", "f4"})}).
 	 *
 	 * <b>NOTE: The use of the ForwardedFieldsFirst annotation is optional.
 	 * If used correctly, it can help the Flink optimizer to generate more efficient execution plans.
@@ -157,17 +157,17 @@ public class FunctionAnnotation {
 	 *
 	 * Fields that are forwarded from the second input at the same position in the output can be
 	 * specified by their position. The specified position must be valid for the input and output data type and have the same type.
-	 * For example <code>\@ForwardedFieldsSecond({"f2"})</code> declares that the third field of a Java input tuple at the second input is
+	 * For example {@code {@literal @}ForwardedFieldsSecond({"f2"})} declares that the third field of a Java input tuple at the second input is
 	 * copied to the third field of an output tuple.
 	 *
 	 * Fields which are unchanged copied to another position in the output are declared by specifying the
 	 * source field expression in the input and the target field expression in the output.
-	 * <code>\@ForwardedFieldsSecond({"f0->f2"})</code> denotes that the first field of the Java input tuple at the second input is
+	 * {@code {@literal @}ForwardedFieldsSecond({"f0->f2"})} denotes that the first field of the Java input tuple at the second input is
 	 * unchanged copied to the third field of the Java output tuple. When using the wildcard ("*") ensure that
 	 * the number of declared fields and their types in input and output type match.
 	 *
-	 * Multiple forwarded fields can be annotated in one (<code>\@ForwardedFieldsSecond({"f2; f3->f0; f4"})</code>)
-	 * or separate Strings (<code>\@ForwardedFieldsSecond({"f2", "f3->f0", "f4"})</code>).
+	 * Multiple forwarded fields can be annotated in one ({@code {@literal @}ForwardedFieldsSecond({"f2; f3->f0; f4"})})
+	 * or separate Strings ({@code {@literal @}ForwardedFieldsSecond({"f2", "f3->f0", "f4"})}).
 	 *
 	 * <b>NOTE: The use of the ForwardedFieldsSecond annotation is optional.
 	 * If used correctly, it can help the Flink optimizer to generate more efficient execution plans.

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopInputFormat.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopInputFormat.java b/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopInputFormat.java
index 126b629..967f8c4 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopInputFormat.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopInputFormat.java
@@ -30,7 +30,7 @@ import org.apache.hadoop.mapred.JobConf;
 /**
  * Wrapper for using HadoopInputFormats (mapred-variant) with Flink.
  *
- * The IF is returning a Tuple2<K,V>.
+ * The IF is returning a {@code Tuple2<K,V>}.
  *
  * @param <K> Type of the key
  * @param <V> Type of the value.

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopOutputFormat.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopOutputFormat.java b/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopOutputFormat.java
index 9c4c6d7..b406dae 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopOutputFormat.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/hadoop/mapred/HadoopOutputFormat.java
@@ -27,7 +27,7 @@ import org.apache.hadoop.mapred.OutputCommitter;
 /**
  * Wrapper for using HadoopOutputFormats (mapred-variant) with Flink.
  *
- * The IF is returning a Tuple2<K,V>.
+ * The IF is returning a {@code Tuple2<K,V>}.
  *
  * @param <K> Type of the key
  * @param <V> Type of the value.

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/io/SplitDataProperties.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/io/SplitDataProperties.java b/flink-java/src/main/java/org/apache/flink/api/java/io/SplitDataProperties.java
index 04d9953..56d2a64 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/io/SplitDataProperties.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/io/SplitDataProperties.java
@@ -95,7 +95,7 @@ public class SplitDataProperties<T> implements GenericDataSourceBase.SplitDataPr
 	 * </b>
 	 *
 	 * @param partitionFields The field positions of the partitioning keys.
-	 * @result This SplitDataProperties object.
+	 * @return This SplitDataProperties object.
 	 */
 	public SplitDataProperties<T> splitsPartitionedBy(int... partitionFields) {
 		return this.splitsPartitionedBy(null, partitionFields);
@@ -112,7 +112,7 @@ public class SplitDataProperties<T> implements GenericDataSourceBase.SplitDataPr
 	 *
 	 * @param partitionMethodId An ID for the method that was used to partition the data across splits.
 	 * @param partitionFields The field positions of the partitioning keys.
-	 * @result This SplitDataProperties object.
+	 * @return This SplitDataProperties object.
 	 */
 	public SplitDataProperties<T> splitsPartitionedBy(String partitionMethodId, int... partitionFields) {
 
@@ -142,7 +142,7 @@ public class SplitDataProperties<T> implements GenericDataSourceBase.SplitDataPr
 	 * </b>
 	 *
 	 * @param partitionFields The field expressions of the partitioning keys.
-	 * @result This SplitDataProperties object.
+	 * @return This SplitDataProperties object.
 	 */
 	public SplitDataProperties<T> splitsPartitionedBy(String partitionFields) {
 		return this.splitsPartitionedBy(null, partitionFields);
@@ -160,7 +160,7 @@ public class SplitDataProperties<T> implements GenericDataSourceBase.SplitDataPr
 	 *
 	 * @param partitionMethodId An ID for the method that was used to partition the data across splits.
 	 * @param partitionFields The field expressions of the partitioning keys.
-	 * @result This SplitDataProperties object.
+	 * @return This SplitDataProperties object.
 	 */
 	public SplitDataProperties<T> splitsPartitionedBy(String partitionMethodId, String partitionFields) {
 
@@ -194,7 +194,7 @@ public class SplitDataProperties<T> implements GenericDataSourceBase.SplitDataPr
 	 * </b>
 	 *
 	 * @param groupFields The field positions of the grouping keys.
-	 * @result This SplitDataProperties object.
+	 * @return This SplitDataProperties object.
 	 */
 	public SplitDataProperties<T> splitsGroupedBy(int... groupFields) {
 
@@ -224,7 +224,7 @@ public class SplitDataProperties<T> implements GenericDataSourceBase.SplitDataPr
 	 * </b>
 	 *
 	 * @param groupFields The field expressions of the grouping keys.
-	 * @result This SplitDataProperties object.
+	 * @return This SplitDataProperties object.
 	 */
 	public SplitDataProperties<T> splitsGroupedBy(String groupFields) {
 
@@ -257,7 +257,7 @@ public class SplitDataProperties<T> implements GenericDataSourceBase.SplitDataPr
 	 *
 	 * @param orderFields The field positions of the grouping keys.
 	 * @param orders The orders of the fields.
-	 * @result This SplitDataProperties object.
+	 * @return This SplitDataProperties object.
 	 */
 	public SplitDataProperties<T> splitsOrderedBy(int[] orderFields, Order[] orders) {
 
@@ -306,7 +306,7 @@ public class SplitDataProperties<T> implements GenericDataSourceBase.SplitDataPr
 	 *
 	 * @param orderFields The field expressions of the grouping key.
 	 * @param orders The orders of the fields.
-	 * @result This SplitDataProperties object.
+	 * @return This SplitDataProperties object.
 	 */
 	public SplitDataProperties<T> splitsOrderedBy(String orderFields, Order[] orders) {
 

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/operators/CoGroupOperator.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/operators/CoGroupOperator.java b/flink-java/src/main/java/org/apache/flink/api/java/operators/CoGroupOperator.java
index 36378b9..328dff9 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/operators/CoGroupOperator.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/operators/CoGroupOperator.java
@@ -420,7 +420,7 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 	// --------------------------------------------------------------------------------------------
 
 	/**
-	 * Intermediate step of a CoGroup transformation. <br/>
+	 * Intermediate step of a CoGroup transformation. <br>
 	 * To continue the CoGroup transformation, select the grouping key of the first input {@link DataSet} by calling 
 	 * {@link org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets#where(int...)} or {@link org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets#where(KeySelector)}.
 	 *
@@ -442,9 +442,9 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 		}
 
 		/**
-		 * Continues a CoGroup transformation. <br/>
-		 * Defines the {@link Tuple} fields of the first co-grouped {@link DataSet} that should be used as grouping keys.<br/>
-		 * <b>Note: Fields can only be selected as grouping keys on Tuple DataSets.</b><br/>
+		 * Continues a CoGroup transformation. <br>
+		 * Defines the {@link Tuple} fields of the first co-grouped {@link DataSet} that should be used as grouping keys.<br>
+		 * <b>Note: Fields can only be selected as grouping keys on Tuple DataSets.</b><br>
 		 *
 		 *
 		 * @param fields The indexes of the Tuple fields of the first co-grouped DataSets that should be used as keys.
@@ -459,7 +459,7 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 		}
 
 		/**
-		 * Continues a CoGroup transformation. <br/>
+		 * Continues a CoGroup transformation. <br>
 		 * Defines the fields of the first co-grouped {@link DataSet} that should be used as grouping keys. Fields
 		 * are the names of member fields of the underlying type of the data set.
 		 *
@@ -476,9 +476,9 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 		}
 
 		/**
-		 * Continues a CoGroup transformation and defines a {@link KeySelector} function for the first co-grouped {@link DataSet}.</br>
+		 * Continues a CoGroup transformation and defines a {@link KeySelector} function for the first co-grouped {@link DataSet}.<br>
 		 * The KeySelector function is called for each element of the first DataSet and extracts a single 
-		 * key value on which the DataSet is grouped. </br>
+		 * key value on which the DataSet is grouped. <br>
 		 * 
 		 * @param keyExtractor The KeySelector function which extracts the key values from the DataSet on which it is grouped.
 		 * @return An incomplete CoGroup transformation. 
@@ -495,7 +495,7 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 		// ----------------------------------------------------------------------------------------
 
 		/**
-		 * Intermediate step of a CoGroup transformation. <br/>
+		 * Intermediate step of a CoGroup transformation. <br>
 		 * To continue the CoGroup transformation, select the grouping key of the second input {@link DataSet} by calling 
 		 * {@link org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate#equalTo(int...)} or {@link org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate#equalTo(KeySelector)}.
 		 *
@@ -518,8 +518,8 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 
 			/**
 			 * Continues a CoGroup transformation and defines the {@link Tuple} fields of the second co-grouped 
-			 * {@link DataSet} that should be used as grouping keys.<br/>
-			 * <b>Note: Fields can only be selected as grouping keys on Tuple DataSets.</b><br/>
+			 * {@link DataSet} that should be used as grouping keys.<br>
+			 * <b>Note: Fields can only be selected as grouping keys on Tuple DataSets.</b><br>
 			 *
 			 *
 			 * @param fields The indexes of the Tuple fields of the second co-grouped DataSet that should be used as keys.
@@ -532,7 +532,7 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 
 			/**
 			 * Continues a CoGroup transformation and defines the fields of the second co-grouped
-			 * {@link DataSet} that should be used as grouping keys.<br/>
+			 * {@link DataSet} that should be used as grouping keys.<br>
 			 *
 			 *
 			 * @param fields The  fields of the first co-grouped DataSets that should be used as keys.
@@ -544,9 +544,9 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 			}
 
 			/**
-			 * Continues a CoGroup transformation and defines a {@link KeySelector} function for the second co-grouped {@link DataSet}.</br>
+			 * Continues a CoGroup transformation and defines a {@link KeySelector} function for the second co-grouped {@link DataSet}.<br>
 			 * The KeySelector function is called for each element of the second DataSet and extracts a single 
-			 * key value on which the DataSet is grouped. </br>
+			 * key value on which the DataSet is grouped. <br>
 			 * 
 			 * @param keyExtractor The KeySelector function which extracts the key values from the second DataSet on which it is grouped.
 			 * @return An incomplete CoGroup transformation. 
@@ -558,7 +558,7 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 			}
 
 			/**
-			 * Intermediate step of a CoGroup transformation. <br/>
+			 * Intermediate step of a CoGroup transformation. <br>
 			 * To continue the CoGroup transformation, provide a {@link org.apache.flink.api.common.functions.RichCoGroupFunction} by calling
 			 * {@link org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction#with(org.apache.flink.api.common.functions.CoGroupFunction)}.
 			 *
@@ -634,7 +634,7 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 				}
 
 				/**
-				 * Finalizes a CoGroup transformation by applying a {@link org.apache.flink.api.common.functions.RichCoGroupFunction} to groups of elements with identical keys.<br/>
+				 * Finalizes a CoGroup transformation by applying a {@link org.apache.flink.api.common.functions.RichCoGroupFunction} to groups of elements with identical keys.<br>
 				 * Each CoGroupFunction call returns an arbitrary number of keys. 
 				 * 
 				 * @param function The CoGroupFunction that is called for all groups of elements with identical keys.
@@ -660,8 +660,8 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 				
 				/**
 				 * Sorts {@link org.apache.flink.api.java.tuple.Tuple} elements within a group in the first input on the
-				 * specified field in the specified {@link Order}.</br>
-				 * <b>Note: Only groups of Tuple elements and Pojos can be sorted.</b><br/>
+				 * specified field in the specified {@link Order}.<br>
+				 * <b>Note: Only groups of Tuple elements and Pojos can be sorted.</b><br>
 				 * Groups can be sorted by multiple fields by chaining {@link #sortFirstGroup(int, Order)} calls.
 				 * 
 				 * @param field The Tuple field on which the group is sorted.
@@ -690,8 +690,8 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 				
 				/**
 				 * Sorts {@link org.apache.flink.api.java.tuple.Tuple} elements within a group in the second input on the
-				 * specified field in the specified {@link Order}.</br>
-				 * <b>Note: Only groups of Tuple elements and Pojos can be sorted.</b><br/>
+				 * specified field in the specified {@link Order}.<br>
+				 * <b>Note: Only groups of Tuple elements and Pojos can be sorted.</b><br>
 				 * Groups can be sorted by multiple fields by chaining {@link #sortSecondGroup(int, Order)} calls.
 				 * 
 				 * @param field The Tuple field on which the group is sorted.
@@ -720,7 +720,7 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 				
 				/**
 				 * Sorts Pojo or {@link org.apache.flink.api.java.tuple.Tuple} elements within a group in the first input on the
-				 * specified field in the specified {@link Order}.</br>
+				 * specified field in the specified {@link Order}.<br>
 				 * Groups can be sorted by multiple fields by chaining {@link #sortFirstGroup(String, Order)} calls.
 				 * 
 				 * @param fieldExpression The expression to the field on which the group is to be sorted.
@@ -745,7 +745,7 @@ public class CoGroupOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OU
 				
 				/**
 				 * Sorts Pojo or {@link org.apache.flink.api.java.tuple.Tuple} elements within a group in the second input on the
-				 * specified field in the specified {@link Order}.</br>
+				 * specified field in the specified {@link Order}.<br>
 				 * Groups can be sorted by multiple fields by chaining {@link #sortSecondGroup(String, Order)} calls.
 				 * 
 				 * @param fieldExpression The expression to the field on which the group is to be sorted.

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/operators/CrossOperator.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/operators/CrossOperator.java b/flink-java/src/main/java/org/apache/flink/api/java/operators/CrossOperator.java
index ae990ce..17cd423 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/operators/CrossOperator.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/operators/CrossOperator.java
@@ -108,7 +108,7 @@ public class CrossOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OUT,
 	// --------------------------------------------------------------------------------------------
 
 	/**
-	 * A Cross transformation that wraps pairs of crossed elements into {@link Tuple2}.<br/>
+	 * A Cross transformation that wraps pairs of crossed elements into {@link Tuple2}.<br>
 	 * It also represents the {@link DataSet} that is the result of a Cross transformation. 
 	 * 
 	 * @param <I1> The type of the first input DataSet of the Cross transformation.
@@ -137,7 +137,7 @@ public class CrossOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OUT,
 		}
 
 		/**
-		 * Finalizes a Cross transformation by applying a {@link CrossFunction} to each pair of crossed elements.<br/>
+		 * Finalizes a Cross transformation by applying a {@link CrossFunction} to each pair of crossed elements.<br>
 		 * Each CrossFunction call returns exactly one element. 
 		 * 
 		 * @param function The CrossFunction that is called for each pair of crossed elements.
@@ -157,9 +157,9 @@ public class CrossOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OUT,
 		}
 		
 		/**
-		 * Initiates a ProjectCross transformation and projects the first cross input<br/>
+		 * Initiates a ProjectCross transformation and projects the first cross input<br>
 		 * If the first cross input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the first cross input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the first cross input is not a Tuple DataSet, no parameters should be passed.<br>
 		 *
 		 * Fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.CrossOperator.ProjectCross#projectFirst(int...)} and
@@ -182,9 +182,9 @@ public class CrossOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OUT,
 		}
 		
 		/**
-		 * Initiates a ProjectCross transformation and projects the second cross input<br/>
+		 * Initiates a ProjectCross transformation and projects the second cross input<br>
 		 * If the second cross input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the second cross input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the second cross input is not a Tuple DataSet, no parameters should be passed.<br>
 		 *
 		 * Fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.CrossOperator.ProjectCross#projectFirst(int...)} and
@@ -210,7 +210,7 @@ public class CrossOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OUT,
 
 	/**
 	 * A Cross transformation that projects crossing elements or fields of crossing {@link Tuple Tuples}
-	 * into result {@link Tuple Tuples}. <br/>
+	 * into result {@link Tuple Tuples}. <br>
 	 * It also represents the {@link DataSet} that is the result of a Cross transformation.
 	 *
 	 * @param <I1> The type of the first input DataSet of the Cross transformation.
@@ -250,9 +250,9 @@ public class CrossOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OUT,
 		}
 		
 		/**
-		 * Continues a ProjectCross transformation and adds fields of the first cross input to the projection.<br/>
+		 * Continues a ProjectCross transformation and adds fields of the first cross input to the projection.<br>
 		 * If the first cross input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the first cross input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the first cross input is not a Tuple DataSet, no parameters should be passed.<br>
 		 *
 		 * Additional fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.CrossOperator.ProjectCross#projectFirst(int...)} and
@@ -277,9 +277,9 @@ public class CrossOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OUT,
 		}
 
 		/**
-		 * Continues a ProjectCross transformation and adds fields of the second cross input to the projection.<br/>
+		 * Continues a ProjectCross transformation and adds fields of the second cross input to the projection.<br>
 		 * If the second cross input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the second cross input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the second cross input is not a Tuple DataSet, no parameters should be passed.<br>
 		 *
 		 * Additional fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.CrossOperator.ProjectCross#projectFirst(int...)} and
@@ -493,9 +493,9 @@ public class CrossOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OUT,
 		}
 
 		/**
-		 * Continues a ProjectCross transformation and adds fields of the first cross input.<br/>
+		 * Continues a ProjectCross transformation and adds fields of the first cross input.<br>
 		 * If the first cross input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the first cross input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the first cross input is not a Tuple DataSet, no parameters should be passed.<br>
 		 *
 		 * Fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.CrossOperator.CrossProjection#projectFirst(int...)} and
@@ -559,9 +559,9 @@ public class CrossOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1, I2, OUT,
 		}
 
 		/**
-		 * Continues a ProjectCross transformation and adds fields of the second cross input.<br/>
+		 * Continues a ProjectCross transformation and adds fields of the second cross input.<br>
 		 * If the second cross input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the second cross input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the second cross input is not a Tuple DataSet, no parameters should be passed.<br>
 		 *
 		 * Fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.CrossOperator.CrossProjection#projectFirst(int...)} and

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/operators/DataSink.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/operators/DataSink.java b/flink-java/src/main/java/org/apache/flink/api/java/operators/DataSink.java
index 5b5b031..48209cf 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/operators/DataSink.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/operators/DataSink.java
@@ -95,8 +95,8 @@ public class DataSink<T> {
 
 	/**
 	 * Sorts each local partition of a {@link org.apache.flink.api.java.tuple.Tuple} data set
-	 * on the specified field in the specified {@link Order} before it is emitted by the output format.</br>
-	 * <b>Note: Only tuple data sets can be sorted using integer field indices.</b><br/>
+	 * on the specified field in the specified {@link Order} before it is emitted by the output format.<br>
+	 * <b>Note: Only tuple data sets can be sorted using integer field indices.</b><br>
 	 * The tuple data set can be sorted on multiple fields in different orders
 	 * by chaining {@link #sortLocalOutput(int, Order)} calls.
 	 *
@@ -149,9 +149,9 @@ public class DataSink<T> {
 
 	/**
 	 * Sorts each local partition of a data set on the field(s) specified by the field expression
-	 * in the specified {@link Order} before it is emitted by the output format.</br>
+	 * in the specified {@link Order} before it is emitted by the output format.<br>
 	 * <b>Note: Non-composite types can only be sorted on the full element which is specified by
-	 * a wildcard expression ("*" or "_").</b><br/>
+	 * a wildcard expression ("*" or "_").</b><br>
 	 * Data sets of composite types (Tuple or Pojo) can be sorted on multiple fields in different orders
 	 * by chaining {@link #sortLocalOutput(String, Order)} calls.
 	 *

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/operators/Grouping.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/operators/Grouping.java b/flink-java/src/main/java/org/apache/flink/api/java/operators/Grouping.java
index 3c0d07f..59811b6 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/operators/Grouping.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/operators/Grouping.java
@@ -23,7 +23,7 @@ import org.apache.flink.api.common.functions.Partitioner;
 import org.apache.flink.api.java.DataSet;
 
 /**
- * Grouping is an intermediate step for a transformation on a grouped DataSet.<br/>
+ * Grouping is an intermediate step for a transformation on a grouped DataSet.<br>
  * The following transformation can be applied on Grouping:
  * <ul>
  * 	<li>{@link UnsortedGrouping#reduce(org.apache.flink.api.common.functions.ReduceFunction)},</li>

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/operators/JoinOperator.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/operators/JoinOperator.java b/flink-java/src/main/java/org/apache/flink/api/java/operators/JoinOperator.java
index 3679b87..99a1957 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/operators/JoinOperator.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/operators/JoinOperator.java
@@ -184,7 +184,7 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 	// --------------------------------------------------------------------------------------------
 	
 	/**
-	 * A Join transformation that applies a {@link JoinFunction} on each pair of joining elements.<br/>
+	 * A Join transformation that applies a {@link JoinFunction} on each pair of joining elements.<br>
 	 * It also represents the {@link DataSet} that is the result of a Join transformation. 
 	 * 
 	 * @param <I1> The type of the first input DataSet of the Join transformation.
@@ -525,7 +525,7 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 	}
 	
 	/**
-	 * A Join transformation that wraps pairs of joining elements into {@link Tuple2}.<br/>
+	 * A Join transformation that wraps pairs of joining elements into {@link Tuple2}.<br>
 	 * It also represents the {@link DataSet} that is the result of a Join transformation. 
 	 * 
 	 * @param <I1> The type of the first input DataSet of the Join transformation.
@@ -545,7 +545,7 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 		}
 
 		/**
-		 * Finalizes a Join transformation by applying a {@link org.apache.flink.api.common.functions.RichFlatJoinFunction} to each pair of joined elements.<br/>
+		 * Finalizes a Join transformation by applying a {@link org.apache.flink.api.common.functions.RichFlatJoinFunction} to each pair of joined elements.<br>
 		 * Each JoinFunction call returns exactly one element. 
 		 * 
 		 * @param function The JoinFunction that is called for each pair of joined elements.
@@ -587,9 +587,9 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 		}
 
 		/**
-		 * Applies a ProjectJoin transformation and projects the first join input<br/>
+		 * Applies a ProjectJoin transformation and projects the first join input<br>
 		 * If the first join input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the first join input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the first join input is not a Tuple DataSet, no parameters should be passed.<br>
 		 * 
 		 * Fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.JoinOperator.ProjectJoin#projectFirst(int...)} and
@@ -613,9 +613,9 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 		}
 		
 		/**
-		 * Applies a ProjectJoin transformation and projects the second join input<br/>
+		 * Applies a ProjectJoin transformation and projects the second join input<br>
 		 * If the second join input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the second join input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the second join input is not a Tuple DataSet, no parameters should be passed.<br>
 		 * 
 		 * Fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.JoinOperator.ProjectJoin#projectFirst(int...)} and
@@ -657,7 +657,7 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 	
 	/**
 	 * A Join transformation that projects joining elements or fields of joining {@link Tuple Tuples} 
-	 * into result {@link Tuple Tuples}. <br/>
+	 * into result {@link Tuple Tuples}. <br>
 	 * It also represents the {@link DataSet} that is the result of a Join transformation. 
 	 * 
 	 * @param <I1> The type of the first input DataSet of the Join transformation.
@@ -693,9 +693,9 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 		}
 
 		/**
-		 * Continues a ProjectJoin transformation and adds fields of the first join input to the projection.<br/>
+		 * Continues a ProjectJoin transformation and adds fields of the first join input to the projection.<br>
 		 * If the first join input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the first join input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the first join input is not a Tuple DataSet, no parameters should be passed.<br>
 		 *
 		 * Additional fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.JoinOperator.ProjectJoin#projectFirst(int...)} and
@@ -720,9 +720,9 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 		}
 
 		/**
-		 * Continues a ProjectJoin transformation and adds fields of the second join input to the projection.<br/>
+		 * Continues a ProjectJoin transformation and adds fields of the second join input to the projection.<br>
 		 * If the second join input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the second join input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the second join input is not a Tuple DataSet, no parameters should be passed.<br>
 		 *
 		 * Additional fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.JoinOperator.ProjectJoin#projectFirst(int...)} and
@@ -846,7 +846,7 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 //	}
 
 	/**
-	 * Intermediate step of a Join transformation. <br/>
+	 * Intermediate step of a Join transformation. <br>
 	 * To continue the Join transformation, select the join key of the first input {@link DataSet} by calling
 	 * {@link JoinOperatorSets#where(int...)} or
 	 * {@link JoinOperatorSets#where(org.apache.flink.api.java.functions.KeySelector)}.
@@ -906,7 +906,7 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 
 
 		/**
-		 * Intermediate step of a Join transformation. <br/>
+		 * Intermediate step of a Join transformation. <br>
 		 * To continue the Join transformation, select the join key of the second input {@link DataSet} by calling
 		 * {@link org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate#equalTo(int...)} or
 		 * {@link org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate#equalTo(KeySelector)}.
@@ -919,9 +919,9 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 
 			/**
 			 * Continues a Join transformation and defines the {@link Tuple} fields of the second join
-			 * {@link DataSet} that should be used as join keys.<br/>
-			 * <b>Note: Fields can only be selected as join keys on Tuple DataSets.</b><br/>
-			 * <p/>
+			 * {@link DataSet} that should be used as join keys.<br>
+			 * <b>Note: Fields can only be selected as join keys on Tuple DataSets.</b><br>
+			 * <p>
 			 * The resulting {@link DefaultJoin} wraps each pair of joining elements into a {@link Tuple2}, with
 			 * the element of the first input being the first field of the tuple and the element of the
 			 * second input being the second field of the tuple.
@@ -936,8 +936,8 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 
 			/**
 			 * Continues a Join transformation and defines the fields of the second join
-			 * {@link DataSet} that should be used as join keys.<br/>
-			 * <p/>
+			 * {@link DataSet} that should be used as join keys.<br>
+			 * <p>
 			 * The resulting {@link DefaultJoin} wraps each pair of joining elements into a {@link Tuple2}, with
 			 * the element of the first input being the first field of the tuple and the element of the
 			 * second input being the second field of the tuple.
@@ -951,10 +951,10 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 			}
 
 			/**
-			 * Continues a Join transformation and defines a {@link KeySelector} function for the second join {@link DataSet}.</br>
+			 * Continues a Join transformation and defines a {@link KeySelector} function for the second join {@link DataSet}.<br>
 			 * The KeySelector function is called for each element of the second DataSet and extracts a single
-			 * key value on which the DataSet is joined. </br>
-			 * <p/>
+			 * key value on which the DataSet is joined. <br>
+			 * <p>
 			 * The resulting {@link DefaultJoin} wraps each pair of joining elements into a {@link Tuple2}, with
 			 * the element of the first input being the first field of the tuple and the element of the
 			 * second input being the second field of the tuple.
@@ -1143,9 +1143,9 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 		}
 		
 		/**
-		 * Continues a ProjectJoin transformation and adds fields of the first join input.<br/>
+		 * Continues a ProjectJoin transformation and adds fields of the first join input.<br>
 		 * If the first join input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the first join input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the first join input is not a Tuple DataSet, no parameters should be passed.<br>
 		 * 
 		 * Fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.JoinOperator.JoinProjection#projectFirst(int...)} and 
@@ -1207,9 +1207,9 @@ public abstract class JoinOperator<I1, I2, OUT> extends TwoInputUdfOperator<I1,
 		}
 		
 		/**
-		 * Continues a ProjectJoin transformation and adds fields of the second join input.<br/>
+		 * Continues a ProjectJoin transformation and adds fields of the second join input.<br>
 		 * If the second join input is a {@link Tuple} {@link DataSet}, fields can be selected by their index.
-		 * If the second join input is not a Tuple DataSet, no parameters should be passed.<br/>
+		 * If the second join input is not a Tuple DataSet, no parameters should be passed.<br>
 		 * 
 		 * Fields of the first and second input can be added by chaining the method calls of
 		 * {@link org.apache.flink.api.java.operators.JoinOperator.JoinProjection#projectFirst(int...)} and

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/operators/SingleInputUdfOperator.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/operators/SingleInputUdfOperator.java b/flink-java/src/main/java/org/apache/flink/api/java/operators/SingleInputUdfOperator.java
index 9301e1a..63fb804 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/operators/SingleInputUdfOperator.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/operators/SingleInputUdfOperator.java
@@ -125,14 +125,14 @@ public abstract class SingleInputUdfOperator<IN, OUT, O extends SingleInputUdfOp
 	 * <p>
 	 * Fields which are unchanged copied to another position in the output are declared by specifying the
 	 * source field reference in the input and the target field reference in the output.
-	 * <code>withForwardedFields("f0->f2")</code> denotes that the first field of the Java input tuple is
+	 * {@code withForwardedFields("f0->f2")} denotes that the first field of the Java input tuple is
 	 * unchanged copied to the third field of the Java output tuple. When using a wildcard ("*") ensure that
 	 * the number of declared fields and their types in input and output type match.
 	 * </p>
 	 *
 	 * <p>
-	 * Multiple forwarded fields can be annotated in one (<code>withForwardedFields("f2; f3->f0; f4")</code>)
-	 * or separate Strings (<code>withForwardedFields("f2", "f3->f0", "f4")</code>).
+	 * Multiple forwarded fields can be annotated in one ({@code withForwardedFields("f2; f3->f0; f4")})
+	 * or separate Strings ({@code withForwardedFields("f2", "f3->f0", "f4")}).
 	 * Please refer to the JavaDoc of {@link org.apache.flink.api.common.functions.Function} or Flink's documentation for
 	 * details on field references such as nested fields and wildcard.
 	 * </p>

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/operators/SortedGrouping.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/operators/SortedGrouping.java b/flink-java/src/main/java/org/apache/flink/api/java/operators/SortedGrouping.java
index 4532424..2fa2467 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/operators/SortedGrouping.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/operators/SortedGrouping.java
@@ -38,7 +38,7 @@ import org.apache.flink.api.java.typeutils.TypeExtractor;
 import com.google.common.base.Preconditions;
 
 /**
- * SortedGrouping is an intermediate step for a transformation on a grouped and sorted DataSet.<br/>
+ * SortedGrouping is an intermediate step for a transformation on a grouped and sorted DataSet.<br>
  * The following transformation can be applied on sorted groups:
  * <ul>
  * 	<li>{@link SortedGrouping#reduceGroup(org.apache.flink.api.common.functions.GroupReduceFunction)},</li>
@@ -145,7 +145,7 @@ public class SortedGrouping<T> extends Grouping<T> {
 	}
 
 	/**
-	 * Applies a GroupReduce transformation on a grouped and sorted {@link DataSet}.<br/>
+	 * Applies a GroupReduce transformation on a grouped and sorted {@link DataSet}.<br>
 	 * The transformation calls a {@link org.apache.flink.api.common.functions.RichGroupReduceFunction} for each group of the DataSet.
 	 * A GroupReduceFunction can iterate over all elements of a group and emit any
 	 *   number of output elements including none.
@@ -189,7 +189,7 @@ public class SortedGrouping<T> extends Grouping<T> {
 
 	
 	/**
-	 * Returns a new set containing the first n elements in this grouped and sorted {@link DataSet}.<br/>
+	 * Returns a new set containing the first n elements in this grouped and sorted {@link DataSet}.<br>
 	 * @param n The desired number of elements for each group.
 	 * @return A GroupReduceOperator that represents the DataSet containing the elements.
 	*/
@@ -206,8 +206,8 @@ public class SortedGrouping<T> extends Grouping<T> {
 	// --------------------------------------------------------------------------------------------
 	
 	/**
-	 * Sorts {@link org.apache.flink.api.java.tuple.Tuple} elements within a group on the specified field in the specified {@link Order}.</br>
-	 * <b>Note: Only groups of Tuple or Pojo elements can be sorted.</b><br/>
+	 * Sorts {@link org.apache.flink.api.java.tuple.Tuple} elements within a group on the specified field in the specified {@link Order}.<br>
+	 * <b>Note: Only groups of Tuple or Pojo elements can be sorted.</b><br>
 	 * Groups can be sorted by multiple fields by chaining {@link #sortGroup(int, Order)} calls.
 	 * 
 	 * @param field The Tuple field on which the group is sorted.
@@ -235,8 +235,8 @@ public class SortedGrouping<T> extends Grouping<T> {
 	}
 
 	/**
-	 * Sorts {@link org.apache.flink.api.java.tuple.Tuple} or POJO elements within a group on the specified field in the specified {@link Order}.</br>
-	 * <b>Note: Only groups of Tuple or Pojo elements can be sorted.</b><br/>
+	 * Sorts {@link org.apache.flink.api.java.tuple.Tuple} or POJO elements within a group on the specified field in the specified {@link Order}.<br>
+	 * <b>Note: Only groups of Tuple or Pojo elements can be sorted.</b><br>
 	 * Groups can be sorted by multiple fields by chaining {@link #sortGroup(String, Order)} calls.
 	 *
 	 * @param field The Tuple or Pojo field on which the group is sorted.

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/operators/TwoInputUdfOperator.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/operators/TwoInputUdfOperator.java b/flink-java/src/main/java/org/apache/flink/api/java/operators/TwoInputUdfOperator.java
index d23dd56..55a8343 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/operators/TwoInputUdfOperator.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/operators/TwoInputUdfOperator.java
@@ -127,14 +127,14 @@ public abstract class TwoInputUdfOperator<IN1, IN2, OUT, O extends TwoInputUdfOp
 	 * <p>
 	 * Fields which are unchanged copied from the first input to another position in the output are declared
 	 * by specifying the source field reference in the first input and the target field reference in the output.
-	 * <code>withForwardedFieldsFirst("f0->f2")</code> denotes that the first field of the first input Java tuple is
+	 * {@code withForwardedFieldsFirst("f0->f2")} denotes that the first field of the first input Java tuple is
 	 * unchanged copied to the third field of the Java output tuple. When using a wildcard ("*") ensure that
 	 * the number of declared fields and their types in first input and output type match.
 	 * </p>
 	 *
 	 * <p>
-	 * Multiple forwarded fields can be annotated in one (<code>withForwardedFieldsFirst("f2; f3->f0; f4")</code>)
-	 * or separate Strings (<code>withForwardedFieldsFirst("f2", "f3->f0", "f4")</code>).
+	 * Multiple forwarded fields can be annotated in one ({@code withForwardedFieldsFirst("f2; f3->f0; f4")})
+	 * or separate Strings ({@code withForwardedFieldsFirst("f2", "f3->f0", "f4")}).
 	 * Please refer to the JavaDoc of {@link org.apache.flink.api.common.functions.Function} or Flink's documentation for
 	 * details on field references such as nested fields and wildcard.
 	 * </p>
@@ -202,14 +202,14 @@ public abstract class TwoInputUdfOperator<IN1, IN2, OUT, O extends TwoInputUdfOp
 	 * <p>
 	 * Fields which are unchanged copied from the second input to another position in the output are declared
 	 * by specifying the source field reference in the second input and the target field reference in the output.
-	 * <code>withForwardedFieldsSecond("f0->f2")</code> denotes that the first field of the second input Java tuple is
+	 * {@code withForwardedFieldsSecond("f0->f2")} denotes that the first field of the second input Java tuple is
 	 * unchanged copied to the third field of the Java output tuple. When using a wildcard ("*") ensure that
 	 * the number of declared fields and their types in second input and output type match.
 	 * </p>
 	 *
 	 * <p>
-	 * Multiple forwarded fields can be annotated in one (<code>withForwardedFieldsSecond("f2; f3->f0; f4")</code>)
-	 * or separate Strings (<code>withForwardedFieldsSecond("f2", "f3->f0", "f4")</code>).
+	 * Multiple forwarded fields can be annotated in one ({@code withForwardedFieldsSecond("f2; f3->f0; f4")})
+	 * or separate Strings ({@code withForwardedFieldsSecond("f2", "f3->f0", "f4")}).
 	 * Please refer to the JavaDoc of {@link org.apache.flink.api.common.functions.Function} or Flink's documentation for
 	 * details on field references such as nested fields and wildcard.
 	 * </p>

http://git-wip-us.apache.org/repos/asf/flink/blob/680b5a90/flink-java/src/main/java/org/apache/flink/api/java/operators/UnsortedGrouping.java
----------------------------------------------------------------------
diff --git a/flink-java/src/main/java/org/apache/flink/api/java/operators/UnsortedGrouping.java b/flink-java/src/main/java/org/apache/flink/api/java/operators/UnsortedGrouping.java
index 32ae19c..c74e918 100644
--- a/flink-java/src/main/java/org/apache/flink/api/java/operators/UnsortedGrouping.java
+++ b/flink-java/src/main/java/org/apache/flink/api/java/operators/UnsortedGrouping.java
@@ -62,7 +62,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
 	// --------------------------------------------------------------------------------------------
 	
 	/**
-	 * Applies an Aggregate transformation on a grouped {@link org.apache.flink.api.java.tuple.Tuple} {@link DataSet}.<br/>
+	 * Applies an Aggregate transformation on a grouped {@link org.apache.flink.api.java.tuple.Tuple} {@link DataSet}.<br>
 	 * <b>Note: Only Tuple DataSets can be aggregated.</b>
 	 * The transformation applies a built-in {@link Aggregations Aggregation} on a specified field 
 	 *   of a Tuple group. Additional aggregation functions can be added to the resulting 
@@ -120,7 +120,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
 	}
 	
 	/**
-	 * Applies a Reduce transformation on a grouped {@link DataSet}.<br/>
+	 * Applies a Reduce transformation on a grouped {@link DataSet}.<br>
 	 * For each group, the transformation consecutively calls a {@link org.apache.flink.api.common.functions.RichReduceFunction}
 	 *   until only a single element for each group remains. 
 	 * A ReduceFunction combines two elements into one new element of the same type.
@@ -140,7 +140,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
 	}
 	
 	/**
-	 * Applies a GroupReduce transformation on a grouped {@link DataSet}.<br/>
+	 * Applies a GroupReduce transformation on a grouped {@link DataSet}.<br>
 	 * The transformation calls a {@link org.apache.flink.api.common.functions.RichGroupReduceFunction} for each group of the DataSet.
 	 * A GroupReduceFunction can iterate over all elements of a group and emit any
 	 *   number of output elements including none.
@@ -183,7 +183,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
 	}
 
 	/**
-	 * Returns a new set containing the first n elements in this grouped {@link DataSet}.<br/>
+	 * Returns a new set containing the first n elements in this grouped {@link DataSet}.<br>
 	 * @param n The desired number of elements for each group.
 	 * @return A GroupReduceOperator that represents the DataSet containing the elements.
 	*/
@@ -196,7 +196,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
 	}
 
 	/**
-	 * Applies a special case of a reduce transformation (minBy) on a grouped {@link DataSet}.<br/>
+	 * Applies a special case of a reduce transformation (minBy) on a grouped {@link DataSet}.<br>
 	 * The transformation consecutively calls a {@link ReduceFunction} 
 	 * until only a single element remains which is the result of the transformation.
 	 * A ReduceFunction combines two elements into one new element of the same type.
@@ -217,7 +217,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
 	}
 	
 	/**
-	 * Applies a special case of a reduce transformation (maxBy) on a grouped {@link DataSet}.<br/>
+	 * Applies a special case of a reduce transformation (maxBy) on a grouped {@link DataSet}.<br>
 	 * The transformation consecutively calls a {@link ReduceFunction} 
 	 * until only a single element remains which is the result of the transformation.
 	 * A ReduceFunction combines two elements into one new element of the same type.
@@ -241,8 +241,8 @@ public class UnsortedGrouping<T> extends Grouping<T> {
 	// --------------------------------------------------------------------------------------------
 	
 	/**
-	 * Sorts {@link org.apache.flink.api.java.tuple.Tuple} elements within a group on the specified field in the specified {@link Order}.</br>
-	 * <b>Note: Only groups of Tuple elements and Pojos can be sorted.</b><br/>
+	 * Sorts {@link org.apache.flink.api.java.tuple.Tuple} elements within a group on the specified field in the specified {@link Order}.<br>
+	 * <b>Note: Only groups of Tuple elements and Pojos can be sorted.</b><br>
 	 * Groups can be sorted by multiple fields by chaining {@link #sortGroup(int, Order)} calls.
 	 * 
 	 * @param field The Tuple field on which the group is sorted.
@@ -263,8 +263,8 @@ public class UnsortedGrouping<T> extends Grouping<T> {
 	}
 	
 	/**
-	 * Sorts Pojos within a group on the specified field in the specified {@link Order}.</br>
-	 * <b>Note: Only groups of Tuple elements and Pojos can be sorted.</b><br/>
+	 * Sorts Pojos within a group on the specified field in the specified {@link Order}.<br>
+	 * <b>Note: Only groups of Tuple elements and Pojos can be sorted.</b><br>
 	 * Groups can be sorted by multiple fields by chaining {@link #sortGroup(String, Order)} calls.
 	 * 
 	 * @param field The Tuple or Pojo field on which the group is sorted.
@@ -285,7 +285,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
 
 	/**
 	 * Sorts elements within a group on a key extracted by the specified {@link org.apache.flink.api.java.functions.KeySelector}
-	 * in the specified {@link Order}.</br>
+	 * in the specified {@link Order}.<br>
 	 * Chaining {@link #sortGroup(KeySelector, Order)} calls is not supported.
 	 *
 	 * @param keySelector The KeySelector with which the group is sorted.