提交 53c7a894 编写于 作者: S Stephan Ewen

Fix various JavaDoc errors

上级 47a68adc
......@@ -288,7 +288,7 @@ public abstract class DataSet<T> {
* @return A GroupReduceOperator that represents the reduced DataSet.
*
* @see GroupReduceFunction
* @see GroupReduceOperator
* @see ReduceGroupOperator
* @see DataSet
*/
public <R> ReduceGroupOperator<T, R> reduceGroup(GroupReduceFunction<T, R> reducer) {
......@@ -383,9 +383,9 @@ public abstract class DataSet<T> {
* can be applied.
* <ul>
* <li>{@link UnsortedGrouping#sortGroup(int, eu.stratosphere.api.common.operators.Order)} to get a {@link SortedGrouping}.
* <li>{@link Grouping#aggregate(Aggregations, int)} to apply an Aggregate transformation.
* <li>{@link Grouping#reduce(ReduceFunction)} to apply a Reduce transformation.
* <li>{@link Grouping#reduceGroup(GroupReduceFunction)} to apply a GroupReduce transformation.
* <li>{@link UnsortedGrouping#aggregate(Aggregations, int)} to apply an Aggregate transformation.
* <li>{@link UnsortedGrouping#reduce(ReduceFunction)} to apply a Reduce transformation.
* <li>{@link UnsortedGrouping#reduceGroup(GroupReduceFunction)} to apply a GroupReduce transformation.
* </ul>
*
* @param fields One or more field positions on which the DataSet will be grouped.
......@@ -412,9 +412,9 @@ public abstract class DataSet<T> {
* can be applied.
* <ul>
* <li>{@link UnsortedGrouping#sortGroup(int, eu.stratosphere.api.common.operators.Order)} to get a {@link SortedGrouping}.
* <li>{@link Grouping#aggregate(Aggregations, int)} to apply an Aggregate transformation.
* <li>{@link Grouping#reduce(ReduceFunction)} to apply a Reduce transformation.
* <li>{@link Grouping#reduceGroup(GroupReduceFunction)} to apply a GroupReduce transformation.
* <li>{@link UnsortedGrouping#aggregate(Aggregations, int)} to apply an Aggregate transformation.
* <li>{@link UnsortedGrouping#reduce(ReduceFunction)} to apply a Reduce transformation.
* <li>{@link UnsortedGrouping#reduceGroup(GroupReduceFunction)} to apply a GroupReduce transformation.
* </ul>
*
* @param fields One or more field expressions on which the DataSet will be grouped.
......@@ -516,7 +516,7 @@ public abstract class DataSet<T> {
* The CoGroupFunction can iterate over the elements of both groups and return any number
* of elements including none.</br>
* This method returns a {@link CoGroupOperatorSets} on which
* {@link CoGroupOperatorSets#where(} needs to be called to define the grouping key of the first
* {@link CoGroupOperatorSets#where()} needs to be called to define the grouping key of the first
* (i.e., this) DataSet.
*
* @param other The other DataSet of the CoGroup transformation.
......@@ -794,8 +794,8 @@ 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/>
* For each Tuple field the result of {@link Object#toString()} is written.
* Tuple fields are separated by the default field delimiter {@link CsvOutputFormat.DEFAULT_FIELD_DELIMITER}.<br/>
* Tuples are are separated by the default line delimiter {@link CsvOutputFormat.DEFAULT_LINE_DELIMITER}.
* 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.
* @return The DataSink that writes the DataSet.
......
......@@ -16,7 +16,6 @@ package eu.stratosphere.api.java.aggregation;
/**
* @param <R> The type of the running aggregate.
* @param <T> The type to be aggregated.
*/
public abstract class AggregationFunction<T> implements java.io.Serializable {
......
......@@ -177,7 +177,7 @@ public class FunctionAnnotation {
* <p>
* The annotation takes one String array specifying the positions of the input types that do not remain constant.
* When this annotation is used, it is assumed that all other values remain at the same position in input and output.
* To model more complex situations use the {@link @ConstantFields}s annotation.
* To model more complex situations use the {@link ConstantFields}s annotation.
* <p>
* This annotation is mutually exclusive with the {@link ConstantFields} annotation.
* <p>
......@@ -212,7 +212,7 @@ public class FunctionAnnotation {
* <p>
* The annotation takes one String array specifying the positions of the input types that do not remain constant.
* When this annotation is used, it is assumed that all other values remain at the same position in input and output.
* To model more complex situations use the {@link @ConstantFields}s annotation.
* To model more complex situations use the {@link ConstantFields}s annotation.
* <p>
* This annotation is mutually exclusive with the {@link ConstantFieldsFirst}
* <p>
......@@ -249,7 +249,7 @@ public class FunctionAnnotation {
* <p>
* The annotation takes one String array specifying the positions of the input types that do not remain constant.
* When this annotation is used, it is assumed that all other values remain at the same position in input and output.
* To model more complex situations use the {@link @ConstantFields}s annotation.
* To model more complex situations use the {@link ConstantFields}s annotation.
* <p>
* This annotation is mutually exclusive with the {@link ConstantFieldsSecond}
* <p>
......
......@@ -75,8 +75,8 @@ public abstract class JoinFunction<IN1, IN2, OUT> extends AbstractFunction imple
* By default, this method delegates to the method {@link #join(Object, Object)}. If this method
* is overridden, that method will no longer be called.
*
* @param first The element from first input.
* @param second The element from second input.
* @param value1 The element from first input.
* @param value2 The element from second input.
* @param out A collector to emit resulting element (zero, one, or many).
*
* @throws Exception This method may throw exceptions. Throwing an exception will cause the operation
......
......@@ -38,7 +38,7 @@ import eu.stratosphere.api.common.functions.GenericReduce;
* <p>
* Like all functions, the ReduceFunction needs to be serializable, as defined in {@link java.io.Serializable}.
*
* @param <IN> Type of the elements that this function processes.
* @param <T> Type of the elements that this function processes.
*/
public abstract class ReduceFunction<T> extends AbstractFunction implements GenericReduce<T> {
......
......@@ -21,9 +21,9 @@ import eu.stratosphere.api.java.DataSet;
* Grouping is an intermediate step for a transformation on a grouped DataSet.<br/>
* The following transformation can be applied on Grouping:
* <ul>
* <li>{@link Grouping#reduce(ReduceFunction)},</li>
* <li>{@link Grouping#reduceGroup(GroupReduceFunction)}, and</li>
* <li>{@link Grouping#aggregate(Aggregations, int)}.</li>
* <li>{@link UnsortedGrouping#reduce(eu.stratosphere.api.java.functions.ReduceFunction)},</li>
* <li>{@link UnsortedGrouping#reduceGroup(eu.stratosphere.api.java.functions.GroupReduceFunction)}, and</li>
* <li>{@link UnsortedGrouping#aggregate(eu.stratosphere.api.java.aggregation.Aggregations, int)}.</li>
* </ul>
*
* @param <T> The type of the elements of the grouped DataSet.
......
......@@ -25,7 +25,7 @@ import eu.stratosphere.api.java.functions.GroupReduceFunction;
* 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 Grouping#reduce(ReduceFunction)},</li>
* <li>{@link SortedGrouping#reduceGroup(GroupReduceFunction)},</li>
* </ul>
*
* @param <T> The type of the elements of the sorted and grouped DataSet.
......@@ -68,7 +68,7 @@ public class SortedGrouping<T> extends Grouping<T> {
* @return A GroupReduceOperator that represents the reduced DataSet.
*
* @see GroupReduceFunction
* @see GroupReduceOperator
* @see ReduceGroupOperator
* @see DataSet
*/
public <R> ReduceGroupOperator<T, R> reduceGroup(GroupReduceFunction<T, R> reducer) {
......@@ -83,7 +83,7 @@ public class SortedGrouping<T> extends Grouping<T> {
// --------------------------------------------------------------------------------------------
/**
* Sorts {@link Tuple} elements within a group on the specified field in the specified {@link Order}.</br>
* Sorts {@link eu.stratosphere.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 can be sorted.</b><br/>
* Groups can be sorted by multiple fields by chaining {@link #sortGroup(int, Order)} calls.
*
......@@ -91,7 +91,7 @@ public class SortedGrouping<T> extends Grouping<T> {
* @param order The Order in which the specified Tuple field is sorted.
* @return A SortedGrouping with specified order of group element.
*
* @see Tuple
* @see eu.stratosphere.api.java.tuple.Tuple
* @see Order
*/
public SortedGrouping<T> sortGroup(int field, Order order) {
......
......@@ -22,7 +22,8 @@ import eu.stratosphere.configuration.Configuration;
/**
* This interface marks operators as operators that execute user-defined functions (UDFs), such as
* {@link MapFunction}, {@link ReduceFunction} or {@link CoGroupFunction}.
* {@link eu.stratosphere.api.java.functions.MapFunction}, {@link eu.stratosphere.api.java.functions.ReduceFunction},
* or {@link eu.stratosphere.api.java.functions.CoGroupFunction}.
* The UDF operators stand in contrast to operators that execute built-in operations, like aggregations.
*/
public interface UdfOperator<O extends UdfOperator<O>> {
......@@ -33,7 +34,8 @@ public interface UdfOperator<O extends UdfOperator<O>> {
/**
* Gets the configuration parameters that will be passed to the UDF's open method
* {@link AbstractFunction#open(Configuration)}. The configuration is set via the {@link #withParameters(Configuration)}
* {@link eu.stratosphere.api.common.functions.AbstractFunction#open(Configuration)}.
* The configuration is set via the {@link #withParameters(Configuration)}
* method.
*
* @return The configuration parameters for the UDF.
......@@ -62,7 +64,7 @@ public interface UdfOperator<O extends UdfOperator<O>> {
/**
* Sets the configuration parameters for the UDF. These are optional parameters that are passed
* to the UDF in the {@link AbstractFunction#open(Configuration)} method.
* to the UDF in the {@link eu.stratosphere.api.common.functions.AbstractFunction#open(Configuration)} method.
*
* @param parameters The configuration parameters for the UDF.
* @return The operator itself, to allow chaining function calls.
......@@ -72,8 +74,11 @@ public interface UdfOperator<O extends UdfOperator<O>> {
/**
* Adds a certain data set as a broadcast set to this operator. Broadcasted data sets are available at all
* parallel instances of this operator. A broadcast data set is registered under a certain name, and can be
* retrieved under that name from the operators runtime context via {@link RuntimeContext#getBroadcastVariable(String)}.
* The runtime context itself is available in all UDFs via {@link AbstractFunction#getRuntimeContext()}.
* retrieved under that name from the operators runtime context via
* {@link eu.stratosphere.api.common.functions.RuntimeContext#getBroadcastVariable(String)}.
*
* The runtime context itself is available in all UDFs via
* {@link eu.stratosphere.api.common.functions.AbstractFunction#getRuntimeContext()}.
*
* @param data The data set to be broadcasted.
* @param name The name under which the broadcast data set retrieved.
......
......@@ -31,7 +31,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
// --------------------------------------------------------------------------------------------
/**
* Applies an Aggregate transformation on a grouped {@link Tuple} {@link DataSet}.<br/>
* Applies an Aggregate transformation on a grouped {@link eu.stratosphere.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
......@@ -41,7 +41,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
* @param field The index of the Tuple field on which the aggregation function is applied.
* @return An AggregateOperator that represents the aggregated DataSet.
*
* @see Tuple
* @see eu.stratosphere.api.java.tuple.Tuple
* @see Aggregations
* @see AggregateOperator
* @see DataSet
......@@ -128,7 +128,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
// --------------------------------------------------------------------------------------------
/**
* Sorts {@link Tuple} elements within a group on the specified field in the specified {@link Order}.</br>
* Sorts {@link eu.stratosphere.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 can be sorted.</b><br/>
* Groups can be sorted by multiple fields by chaining {@link #sortGroup(int, Order)} calls.
*
......@@ -136,7 +136,7 @@ public class UnsortedGrouping<T> extends Grouping<T> {
* @param order The Order in which the specified Tuple field is sorted.
* @return A SortedGrouping with specified order of group element.
*
* @see Tuple
* @see eu.stratosphere.api.java.tuple.Tuple
* @see Order
*/
public SortedGrouping<T> sortGroup(int field, Order order) {
......
......@@ -21,7 +21,7 @@ import eu.stratosphere.types.Record;
import eu.stratosphere.util.Collector;
/**
* The CoGroupFunction is the base class for functions that are invoked by a {@link CoGroupOperator}.
* The CoGroupFunction is the base class for functions that are invoked by a {@link eu.stratosphere.api.java.operators.CoGroupOperator}.
*/
public abstract class CoGroupFunction extends AbstractFunction implements GenericCoGrouper<Record, Record, Record> {
......
......@@ -19,7 +19,7 @@ import eu.stratosphere.types.Record;
import eu.stratosphere.util.Collector;
/**
* The CrossFunction is the base class for functions that are invoked by a {@link CrossOperator}.
* The CrossFunction is the base class for functions that are invoked by a {@link eu.stratosphere.api.java.operators.CrossOperator}.
*/
public abstract class CrossFunction extends AbstractFunction implements GenericCrosser<Record, Record, Record> {
......
......@@ -19,7 +19,7 @@ import eu.stratosphere.types.Record;
import eu.stratosphere.util.Collector;
/**
* The JoinFunction must implementation by functions of a {@link JoinOperator}.
* The JoinFunction must implementation by functions of a {@link eu.stratosphere.api.java.operators.JoinOperator}.
* It resembles an equality join of both inputs on their key fields.
*/
public abstract class JoinFunction extends AbstractFunction implements GenericJoiner<Record, Record, Record> {
......
......@@ -23,7 +23,7 @@ import eu.stratosphere.util.Collector;
/**
* The ReduceFunction must be extended to provide a reducer implementation, as invoked by a
* {@link ReduceOperator}.
* {@link eu.stratosphere.api.java.operators.ReduceOperator}.
*/
public abstract class ReduceFunction extends AbstractFunction implements GenericGroupReduce<Record, Record>, GenericCombine<Record> {
......
......@@ -28,10 +28,8 @@ import eu.stratosphere.types.Record;
* The input format requires ({@link ExternalProcessInputSplit} objects that hold the command to execute.
*
* <b>Warning:</b> This format does not consume the standard error stream (stderr) of the started process. This might cause deadlocks.
*
*
* @param <T>, The type of the input split (must extend ExternalProcessInputSplit)
*
* @param <T> The type of the input split (must extend ExternalProcessInputSplit)
*/
public abstract class ExternalProcessFixedLengthInputFormat<T extends ExternalProcessInputSplit> extends ExternalProcessInputFormat<T> {
......
......@@ -26,12 +26,12 @@ import eu.stratosphere.core.io.GenericInputSplit;
* The input format checks the exit code of the process to validate whether the process terminated correctly. A list of allowed exit codes can be provided.
* The input format requires ({@link ExternalProcessInputSplit} objects that hold the command to execute.
*
* <b> Attention! </b><br>
* <b>Attention! </b><br/>
* You must take care to read from (and process) both output streams of the process, standard out (stdout) and standard error (stderr).
* Otherwise, the input format might get deadlocked!
*
*
* @param <T>, The type of the input split (must extend ExternalProcessInputSplit)
* @param <T> The type of the input split (must extend ExternalProcessInputSplit)
*/
public abstract class ExternalProcessInputFormat<T extends ExternalProcessInputSplit> extends GenericInputFormat {
private static final long serialVersionUID = 1L;
......
......@@ -21,7 +21,7 @@ import eu.stratosphere.core.memory.DataInputView;
import eu.stratosphere.core.memory.DataOutputView;
/**
* The ExternalProcessInputSplit contains all informations for {@link InputFormat} that read their data from external processes.
* The ExternalProcessInputSplit contains all informations for {@link eu.stratosphere.api.common.io.InputFormat} that read their data from external processes.
* Each parallel instance of an InputFormat starts an external process and reads its output.
* The command to start the external process must be executable on all nodes.
*
......
......@@ -28,13 +28,13 @@ import eu.stratosphere.types.Record;
* Use this operator if you want to pass data from the application submitting the
* Stratosphere job to the cluster.
* There are two main ways to use the CollectionDataSource:
* * Using a @link {@link SerializableIterator}
*
* Using an {@link java.util.Iterator} that is also {@link java.io.Serializable}.
* <pre>
* CollectionDataSource source = new CollectionDataSource(new SerializableIteratorTest(), &quot;IterSource&quot;);
* CollectionDataSource source = new CollectionDataSource(mySerializableIterator, &quot;IterSource&quot;);
* </pre>
*
* * Using a Collection of Java Objects.
* Using a Collection of Java Objects.
*
* <pre>
* CollectionDataSource source2 = new CollectionDataSource(new List&lt;String&gt;(), &quot;Collection source&quot;);
......
......@@ -82,7 +82,7 @@ public final class RecordComparator extends TypeComparator<Record> {
*
* @param keyFields The positions of the key fields.
* @param keyTypes The types (classes) of the key fields.
* @param sortOrder The direction for sorting. A value of <i>true</i> indicates ascending for an attribute,
* @param sortDirection The direction for sorting. A value of <i>true</i> indicates ascending for an attribute,
* a value of <i>false</i> indicated descending. If the parameter is <i>null</i>, then
* all order comparisons will assume ascending order on all fields.
*/
......@@ -150,11 +150,7 @@ public final class RecordComparator extends TypeComparator<Record> {
/**
* Copy constructor.
*
* @param keyFields
* @param keys
* @param normalKeyLengths
* @param leadingNormalKeys
* @param normalKeyPrefixLen
* @param toCopy Comparator to copy.
*/
private RecordComparator(RecordComparator toCopy) {
this.keyFields = toCopy.keyFields;
......
......@@ -22,7 +22,7 @@ import eu.stratosphere.types.Key;
import eu.stratosphere.types.Record;
/**
* A factory for a {@link TypeComparator} for {@link Record}. The comparator uses a subset of
* A factory for a {@link eu.stratosphere.api.common.typeutils.TypeComparator} for {@link Record}. The comparator uses a subset of
* the fields for the comparison. That subset of fields (positions and types) is read from the
* supplied configuration.
*/
......
Markdown is supported
0% .
You are about to add 0 people to the discussion. Proceed with caution.
先完成此消息的编辑!
想要评论请 注册