- checkCollection(Collection<X>, Class<X>) - 类 中的静态方法org.apache.flink.api.java.io.CollectionInputFormat
-  
- checkJoinKeyFields(int[]) - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration.SolutionSetPlaceHolder
-  
- checkSameExecutionContext(DataSet<?>, DataSet<?>) - 类 中的静态方法org.apache.flink.api.java.DataSet
-  
- ChecksumHashCode() - 类 的构造器org.apache.flink.api.java.Utils.ChecksumHashCode
-  
- ChecksumHashCode(long, long) - 类 的构造器org.apache.flink.api.java.Utils.ChecksumHashCode
-  
- checksumHashCode(DataSet<T>) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
- ChecksumHashCodeHelper(String) - 类 的构造器org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
-  
- choices(String...) - 类 中的方法org.apache.flink.api.java.utils.Option
- 
已过时。 Restrict the list of possible values of the parameter. 
- clean(F) - 类 中的方法org.apache.flink.api.java.DataSet
-  
- clearJobListeners() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Clear all registered JobListeners.
 
- clone() - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
-  
- clone() - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
-  
- clone() - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
-  
- clone() - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
-  
- close() - 类 中的方法org.apache.flink.api.java.io.BlockingShuffleOutputFormat
-  
- close() - 类 中的方法org.apache.flink.api.java.io.CsvOutputFormat
-  
- close() - 类 中的方法org.apache.flink.api.java.io.DiscardingOutputFormat
-  
- close() - 类 中的方法org.apache.flink.api.java.io.LocalCollectionOutputFormat
-  
- close() - 类 中的方法org.apache.flink.api.java.io.PrintingOutputFormat
-  
- close() - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
-  
- close() - 类 中的方法org.apache.flink.api.java.operators.translation.TupleWrappingCollector
-  
- close() - 类 中的方法org.apache.flink.api.java.operators.translation.WrappingFunction
-  
- close() - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
-  
- close() - 类 中的方法org.apache.flink.api.java.Utils.CollectHelper
-  
- close() - 类 中的方法org.apache.flink.api.java.Utils.CountHelper
-  
- closeWith(DataSet<ST>, DataSet<WT>) - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Closes the delta iteration. 
- closeWith(DataSet<T>) - 类 中的方法org.apache.flink.api.java.operators.IterativeDataSet
- 
Closes the iteration. 
- closeWith(DataSet<T>, DataSet<?>) - 类 中的方法org.apache.flink.api.java.operators.IterativeDataSet
- 
Closes the iteration and specifies a termination criterion. 
- coGroup(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Initiates a CoGroup transformation. 
- CoGroupOperator<I1,I2,OUT> - org.apache.flink.api.java.operators中的类
- 
A  DataSet that is the result of a CoGroup transformation. 
- CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, Partitioner<?>, String) - 类 的构造器org.apache.flink.api.java.operators.CoGroupOperator
-  
- CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, List<Pair<Integer, Order>>, List<Pair<Integer, Order>>, Partitioner<?>, String) - 类 的构造器org.apache.flink.api.java.operators.CoGroupOperator
-  
- CoGroupOperator.CoGroupOperatorSets<I1,I2> - org.apache.flink.api.java.operators中的类
- 
Intermediate step of a CoGroup transformation. 
- CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate - org.apache.flink.api.java.operators中的类
- 
Intermediate step of a CoGroup transformation. 
- CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction - org.apache.flink.api.java.operators中的类
- 
- CoGroupOperatorSets(DataSet<I1>, DataSet<I2>) - 类 的构造器org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
-  
- CoGroupRawOperator<I1,I2,OUT> - org.apache.flink.api.java.operators中的类
- 
A  DataSet that is the result of a CoGroup transformation. 
- CoGroupRawOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, String) - 类 的构造器org.apache.flink.api.java.operators.CoGroupRawOperator
-  
- collect() - 类 中的方法org.apache.flink.api.java.DataSet
- 
Convenience method to get the elements of a DataSet as a List. 
- collect(IN) - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
-  
- collect(IN) - 类 中的方法org.apache.flink.api.java.operators.translation.TupleWrappingCollector
-  
- CollectHelper(String, TypeSerializer<T>) - 类 的构造器org.apache.flink.api.java.Utils.CollectHelper
-  
- CollectionEnvironment - org.apache.flink.api.java中的类
- 
Version of  ExecutionEnvironment that allows serial, local, collection-based executions of
 Flink programs. 
- CollectionEnvironment() - 类 的构造器org.apache.flink.api.java.CollectionEnvironment
-  
- CollectionInputFormat<T> - org.apache.flink.api.java.io中的类
- 
An input format that returns objects from a collection. 
- CollectionInputFormat(Collection<T>, TypeSerializer<T>) - 类 的构造器org.apache.flink.api.java.io.CollectionInputFormat
-  
- ColumnSummary - org.apache.flink.api.java.summarize中的类
- 
Summary for a column of values. 
- ColumnSummary() - 类 的构造器org.apache.flink.api.java.summarize.ColumnSummary
-  
- combine(Iterable<T>, Collector<T>) - 类 中的方法org.apache.flink.api.java.functions.FirstReducer
-  
- combine(Iterable<IN>, Collector<IN>) - 类 中的方法org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
-  
- combine(Iterable<IN>, Collector<IN>) - 类 中的方法org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
-  
- combine(Aggregator<T, R>) - 接口 中的方法org.apache.flink.api.java.summarize.aggregation.Aggregator
- 
Combine two aggregations of the same type. 
- combine(Aggregator<Boolean, BooleanColumnSummary>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
-  
- combine(Aggregator<Double, Double>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
-  
- combine(Aggregator<Double, Double>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
-  
- combine(Aggregator<Double, Double>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
-  
- combine(Aggregator<Float, Float>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
-  
- combine(Aggregator<Float, Float>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
-  
- combine(Aggregator<Float, Float>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
-  
- combine(Aggregator<Integer, Integer>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
-  
- combine(Aggregator<Integer, Integer>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
-  
- combine(Aggregator<Integer, Integer>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
-  
- combine(Aggregator<Long, Long>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
-  
- combine(Aggregator<Long, Long>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
-  
- combine(Aggregator<T, NumericColumnSummary<T>>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
- 
combine two aggregations. 
- combine(Aggregator<Object, ObjectColumnSummary>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
-  
- combine(Aggregator<Short, Short>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
-  
- combine(Aggregator<Short, Short>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
-  
- combine(Aggregator<Short, Short>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
-  
- combine(Aggregator<String, StringColumnSummary>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
-  
- combine(Aggregator<Tuple, R>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
-  
- combine(Aggregator<VT, R>) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
-  
- combineGroup(GroupCombineFunction<T, R>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Applies a GroupCombineFunction on a non-grouped  DataSet. 
- combineGroup(GroupCombineFunction<T, R>) - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
- 
Applies a GroupCombineFunction on a grouped  DataSet. 
- combineGroup(GroupCombineFunction<T, R>) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
- 
Applies a GroupCombineFunction on a grouped  DataSet. 
- CombineToGroupCombineWrapper<IN,OUT,F extends org.apache.flink.api.common.functions.CombineFunction<IN,IN> & org.apache.flink.api.common.functions.GroupReduceFunction<IN,OUT>> - org.apache.flink.api.java.operators.translation中的类
- 
A wrapper the wraps a function that implements both CombineFunctionandGroupReduceFunctioninterfaces and makes it look like a function that implementsGroupCombineFunctionandGroupReduceFunctionto the runtime.
 
- CombineToGroupCombineWrapper(F) - 类 的构造器org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
-  
- commentPrefix - 类 中的变量org.apache.flink.api.java.io.CsvReader
-  
- compareTo(IntermediateSampleData<T>) - 类 中的方法org.apache.flink.api.java.sampling.IntermediateSampleData
-  
- CompensatedSum - org.apache.flink.api.java.summarize.aggregation中的类
- 
Used to calculate sums using the Kahan summation algorithm. 
- CompensatedSum(double, double) - 类 的构造器org.apache.flink.api.java.summarize.aggregation.CompensatedSum
- 
Used to calculate sums using the Kahan summation algorithm. 
- configure(ReadableConfig, ClassLoader) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Sets all relevant options contained in the ReadableConfigsuch as e.g.
 
- configure(Configuration) - 类 中的方法org.apache.flink.api.java.io.BlockingShuffleOutputFormat
-  
- configure(Configuration) - 类 中的方法org.apache.flink.api.java.io.DiscardingOutputFormat
-  
- configure(Configuration) - 类 中的方法org.apache.flink.api.java.io.LocalCollectionOutputFormat
-  
- configure(Configuration) - 类 中的方法org.apache.flink.api.java.io.PrintingOutputFormat
-  
- configure(Configuration) - 类 中的方法org.apache.flink.api.java.io.TextInputFormat
-  
- configure(Configuration) - 类 中的方法org.apache.flink.api.java.io.TextValueInputFormat
-  
- configure(Configuration) - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
-  
- configure(Configuration) - 类 中的方法org.apache.flink.api.java.Utils.CollectHelper
-  
- configure(Configuration) - 类 中的方法org.apache.flink.api.java.Utils.CountHelper
-  
- containsNonNull() - 类 中的方法org.apache.flink.api.java.summarize.ColumnSummary
- 
True if this column contains any non-null values. 
- containsNull() - 类 中的方法org.apache.flink.api.java.summarize.ColumnSummary
- 
True if this column contains any null values. 
- context - 类 中的变量org.apache.flink.api.java.DataSet
-  
- count() - 类 中的方法org.apache.flink.api.java.DataSet
- 
Convenience method to get the count (number of elements) of a DataSet. 
- countElementsPerPartition(DataSet<T>) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
Method that goes over all the elements in each partition in order to retrieve the total
 number of elements. 
- CountHelper(String) - 类 的构造器org.apache.flink.api.java.Utils.CountHelper
-  
- create(TupleTypeInfoBase<?>) - 类 中的静态方法org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
-  
- create(Class<T>) - 类 中的静态方法org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
- 
Create a SummaryAggregator for the supplied type. 
- createAggregationFunction(Class<T>) - 接口 中的方法org.apache.flink.api.java.aggregation.AggregationFunctionFactory
-  
- createAggregationFunction(Class<T>) - 类 中的方法org.apache.flink.api.java.aggregation.MaxAggregationFunction.MaxAggregationFunctionFactory
-  
- createAggregationFunction(Class<T>) - 类 中的方法org.apache.flink.api.java.aggregation.MinAggregationFunction.MinAggregationFunctionFactory
-  
- createAggregationFunction(Class<T>) - 类 中的方法org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
-  
- createCollectionsEnvironment() - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
- createDefaultJoin(Keys<I2>) - 类 中的方法org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
-  
- createDefaultMask(int) - 类 中的静态方法org.apache.flink.api.java.io.CsvInputFormat
-  
- createExecutionEnvironment() - 接口 中的方法org.apache.flink.api.java.ExecutionEnvironmentFactory
- 
Creates an ExecutionEnvironment from this factory. 
- createInput(InputFormat<X, ?>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Generic method to create an input  DataSet with in  InputFormat. 
- createInput(InputFormat<X, ?>, TypeInformation<X>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Generic method to create an input DataSet with in InputFormat.
 
- createJoinFunctionAssigner(Keys<I2>) - 类 中的方法org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
-  
- createLocalEnvironment() - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
- createLocalEnvironment(int) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
- createLocalEnvironment(Configuration) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
- createLocalEnvironmentWithWebUI(Configuration) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a  LocalEnvironment for local program execution that also starts the web
 monitoring UI. 
- createOutputFormat(AbstractID) - 类 中的静态方法org.apache.flink.api.java.io.BlockingShuffleOutputFormat
-  
- createProgramPlan() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates the program's Plan.
 
- createProgramPlan(String) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates the program's Plan.
 
- createProgramPlan(String, boolean) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates the program's Plan.
 
- createProjectionPropertiesDual(int[], boolean[], TypeInformation<?>, TypeInformation<?>) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
-  
- createProjectionPropertiesSingle(int[], CompositeType<?>) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
-  
- createPropertiesFile(String) - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
- 
Create a properties file with all the known parameters (call after the last get*() call). 
- createPropertiesFile(String, boolean) - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
- 
Create a properties file with all the known parameters (call after the last get*() call). 
- createRemoteEnvironment(String, int, String...) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
- createRemoteEnvironment(String, int, Configuration, String...) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
- createRemoteEnvironment(String, int, int, String...) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
- createResult() - 接口 中的方法org.apache.flink.api.java.operators.CustomUnaryOperation
-  
- createTypeWithKey(Keys.SelectorFunctionKeys<T, K>) - 类 中的静态方法org.apache.flink.api.java.operators.KeyFunctions
-  
- createTypeWithKey(Keys.SelectorFunctionKeys<T, K1>, Keys.SelectorFunctionKeys<T, K2>) - 类 中的静态方法org.apache.flink.api.java.operators.KeyFunctions
-  
- cross(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Initiates a Cross transformation. 
- cross(T1, T2) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-  
- CrossOperator<I1,I2,OUT> - org.apache.flink.api.java.operators中的类
- 
A  DataSet that is the result of a Cross transformation. 
- CrossOperator(DataSet<I1>, DataSet<I2>, CrossFunction<I1, I2, OUT>, TypeInformation<OUT>, CrossOperatorBase.CrossHint, String) - 类 的构造器org.apache.flink.api.java.operators.CrossOperator
-  
- CrossOperator.CrossProjection<I1,I2> - org.apache.flink.api.java.operators中的类
-  
- CrossOperator.DefaultCross<I1,I2> - org.apache.flink.api.java.operators中的类
- 
A Cross transformation that wraps pairs of crossed elements into Tuple2.
 
- CrossOperator.ProjectCross<I1,I2,OUT extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.api.java.operators中的类
- 
A Cross transformation that projects crossing elements or fields of crossing Tuplesinto resultTuples.
 
- CrossOperator.ProjectCrossFunction<T1,T2,R extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.api.java.operators中的类
-  
- CrossProjection(DataSet<I1>, DataSet<I2>, int[], int[], CrossOperatorBase.CrossHint) - 类 的构造器org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-  
- crossWithHuge(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Initiates a Cross transformation. 
- crossWithTiny(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Initiates a Cross transformation. 
- CsvInputFormat<OUT> - org.apache.flink.api.java.io中的类
- 
InputFormat that reads csv files. 
- CsvInputFormat(Path) - 类 的构造器org.apache.flink.api.java.io.CsvInputFormat
-  
- CsvOutputFormat<T extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.api.java.io中的类
- 
This is an OutputFormat to serialize Tuples to text.
 
- CsvOutputFormat(Path) - 类 的构造器org.apache.flink.api.java.io.CsvOutputFormat
- 
Creates an instance of CsvOutputFormat. 
- CsvOutputFormat(Path, String) - 类 的构造器org.apache.flink.api.java.io.CsvOutputFormat
- 
Creates an instance of CsvOutputFormat. 
- CsvOutputFormat(Path, String, String) - 类 的构造器org.apache.flink.api.java.io.CsvOutputFormat
- 
Creates an instance of CsvOutputFormat. 
- CsvReader - org.apache.flink.api.java.io中的类
- 
A builder class to instantiate a CSV parsing data source. 
- CsvReader(Path, ExecutionEnvironment) - 类 的构造器org.apache.flink.api.java.io.CsvReader
-  
- CsvReader(String, ExecutionEnvironment) - 类 的构造器org.apache.flink.api.java.io.CsvReader
-  
- customPartitioner - 类 中的变量org.apache.flink.api.java.operators.Grouping
-  
- CustomUnaryOperation<IN,OUT> - org.apache.flink.api.java.operators中的接口
-  
- fieldDelimiter - 类 中的变量org.apache.flink.api.java.io.CsvReader
-  
- fieldDelimiter(char) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
- fieldDelimiter(String) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Configures the delimiter that separates the fields within a row. 
- fields - 类 中的变量org.apache.flink.api.java.operators.ProjectOperator
-  
- fillInType(TypeInformation<T>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Tries to fill in the type information. 
- fillRecord(OUT, Object[]) - 类 中的方法org.apache.flink.api.java.io.CsvInputFormat
-  
- fillRecord(OUT, Object[]) - 类 中的方法org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- fillRecord(Row, Object[]) - 类 中的方法org.apache.flink.api.java.io.RowCsvInputFormat
-  
- fillRecord(OUT, Object[]) - 类 中的方法org.apache.flink.api.java.io.TupleCsvInputFormat
-  
- filter(FilterFunction<T>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Applies a Filter transformation on a  DataSet. 
- FilterOperator<T> - org.apache.flink.api.java.operators中的类
- 
This operator represents the application of a "filter" function on a data set, and the result
 data set produced by the function. 
- FilterOperator(DataSet<T>, FilterFunction<T>, String) - 类 的构造器org.apache.flink.api.java.operators.FilterOperator
-  
- first(int) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Returns a new set containing the first n elements in this  DataSet. 
- first(int) - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
- 
Returns a new set containing the first n elements in this grouped and sorted  DataSet. 
- first(int) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
- 
Returns a new set containing the first n elements in this grouped  DataSet. 
- FirstReducer<T> - org.apache.flink.api.java.functions中的类
- 
Reducer that only emits the first N elements in a group. 
- FirstReducer(int) - 类 的构造器org.apache.flink.api.java.functions.FirstReducer
-  
- flatMap(FlatMapFunction<T, R>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Applies a FlatMap transformation on a  DataSet. 
- flatMap(IN) - 类 中的方法org.apache.flink.api.java.functions.FlatMapIterator
- 
The core method of the function. 
- flatMap(IN, Collector<OUT>) - 类 中的方法org.apache.flink.api.java.functions.FlatMapIterator
- 
- flatMap(T, Collector<T>) - 类 中的方法org.apache.flink.api.java.operators.translation.PlanFilterOperator.FlatMapFilter
-  
- FlatMapIterator<IN,OUT> - org.apache.flink.api.java.functions中的类
- 
A convenience variant of the RichFlatMapFunctionthat returns elements through an iterator, rather then through a collector.
 
- FlatMapIterator() - 类 的构造器org.apache.flink.api.java.functions.FlatMapIterator
-  
- FlatMapOperator<IN,OUT> - org.apache.flink.api.java.operators中的类
- 
This operator represents the application of a "flatMap" function on a data set, and the result
 data set produced by the function. 
- FlatMapOperator(DataSet<IN>, TypeInformation<OUT>, FlatMapFunction<IN, OUT>, String) - 类 的构造器org.apache.flink.api.java.operators.FlatMapOperator
-  
- FlinkChillPackageRegistrar - org.apache.flink.api.java.typeutils.runtime.kryo中的类
- 
Registers all chill serializers used for Java types. 
- FlinkChillPackageRegistrar() - 类 的构造器org.apache.flink.api.java.typeutils.runtime.kryo.FlinkChillPackageRegistrar
-  
- FloatSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
- 
Aggregator that can handle Float types. 
- FloatSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
-  
- FloatSummaryAggregator.MaxFloatAggregator - org.apache.flink.api.java.summarize.aggregation中的类
- 
Aggregator for max operation. 
- FloatSummaryAggregator.MinFloatAggregator - org.apache.flink.api.java.summarize.aggregation中的类
- 
Aggregator for min operation. 
- FloatSummaryAggregator.SumFloatAggregator - org.apache.flink.api.java.summarize.aggregation中的类
- 
Aggregator for sum operation. 
- FloatValueSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
-  
- format(IN) - 接口 中的方法org.apache.flink.api.java.io.TextOutputFormat.TextFormatter
-  
- FormattingMapper<T> - org.apache.flink.api.java.functions中的类
- 
- FormattingMapper(TextOutputFormat.TextFormatter<T>) - 类 的构造器org.apache.flink.api.java.functions.FormattingMapper
-  
- fromArgs(String[]) - 类 中的静态方法org.apache.flink.api.java.utils.MultipleParameterTool
- 
- fromArgs(String[]) - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
- 
- fromCollection(Collection<X>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a DataSet from the given non-empty collection. 
- fromCollection(Collection<X>, TypeInformation<X>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a DataSet from the given non-empty collection. 
- fromCollection(Iterator<X>, Class<X>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a DataSet from the given iterator. 
- fromCollection(Iterator<X>, TypeInformation<X>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a DataSet from the given iterator. 
- fromElements(X...) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a new data set that contains the given elements. 
- fromElements(Class<X>, X...) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a new data set that contains the given elements. 
- fromMap(Map<String, String>) - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
- 
- fromMultiMap(Map<String, Collection<String>>) - 类 中的静态方法org.apache.flink.api.java.utils.MultipleParameterTool
- 
- fromParallelCollection(SplittableIterator<X>, Class<X>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a new data set that contains elements in the iterator. 
- fromParallelCollection(SplittableIterator<X>, TypeInformation<X>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a new data set that contains elements in the iterator. 
- fromPropertiesFile(String) - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
- 
- fromPropertiesFile(File) - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
- 
- fromPropertiesFile(InputStream) - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
- 
- fromSystemProperties() - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
- 
- fullOuterJoin(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Initiates a Full Outer Join transformation. 
- fullOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Initiates a Full Outer Join transformation. 
- function - 类 中的变量org.apache.flink.api.java.operators.FilterOperator
-  
- function - 类 中的变量org.apache.flink.api.java.operators.FlatMapOperator
-  
- function - 类 中的变量org.apache.flink.api.java.operators.MapOperator
-  
- function - 类 中的变量org.apache.flink.api.java.operators.MapPartitionOperator
-  
- FunctionAnnotation - org.apache.flink.api.java.functions中的类
- 
This class defines Java annotations for semantic assertions that can be added to Flink functions. 
- FunctionAnnotation.ForwardedFields - org.apache.flink.api.java.functions中的注释类型
- 
The ForwardedFields annotation declares fields which are never modified by the annotated
 function and which are forwarded at the same position to the output or unchanged copied to
 another position in the output. 
- FunctionAnnotation.ForwardedFieldsFirst - org.apache.flink.api.java.functions中的注释类型
- 
The ForwardedFieldsFirst annotation declares fields of the first input of a function which
 are never modified by the annotated function and which are forwarded at the same position to
 the output or unchanged copied to another position in the output. 
- FunctionAnnotation.ForwardedFieldsSecond - org.apache.flink.api.java.functions中的注释类型
- 
The ForwardedFieldsSecond annotation declares fields of the second input of a function which
 are never modified by the annotated function and which are forwarded at the same position to
 the output or unchanged copied to another position in the output. 
- FunctionAnnotation.NonForwardedFields - org.apache.flink.api.java.functions中的注释类型
- 
The NonForwardedFields annotation declares ALL fields which not preserved on the same
 position in a functions output. 
- FunctionAnnotation.NonForwardedFieldsFirst - org.apache.flink.api.java.functions中的注释类型
- 
The NonForwardedFieldsFirst annotation declares for a function ALL fields of its first input
 which are not preserved on the same position in its output. 
- FunctionAnnotation.NonForwardedFieldsSecond - org.apache.flink.api.java.functions中的注释类型
- 
The NonForwardedFieldsSecond annotation declares for a function ALL fields of its second
 input which are not preserved on the same position in its output. 
- FunctionAnnotation.ReadFields - org.apache.flink.api.java.functions中的注释类型
- 
The ReadFields annotation declares for a function all fields which it accesses and evaluates,
 i.e., all fields that are used by the function to compute its result. 
- FunctionAnnotation.ReadFieldsFirst - org.apache.flink.api.java.functions中的注释类型
- 
The ReadFieldsFirst annotation declares for a function all fields of the first input which it
 accesses and evaluates, i.e., all fields of the first input that are used by the function to
 compute its result. 
- FunctionAnnotation.ReadFieldsSecond - org.apache.flink.api.java.functions中的注释类型
- 
The ReadFieldsSecond annotation declares for a function all fields of the second input which
 it accesses and evaluates, i.e., all fields of the second input that are used by the function
 to compute its result. 
- generate() - 类 中的方法org.apache.flink.api.java.utils.PlanGenerator
-  
- generateSequence(long, long) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a new data set that contains a sequence of numbers. 
- get(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the String value for the given key. 
- get(String, String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the String value for the given key. 
- get(String) - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
- 
Returns the String value for the given key. 
- get(String) - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
- 
Returns the String value for the given key. 
- getAggregate() - 类 中的方法org.apache.flink.api.java.aggregation.AggregationFunction
-  
- getAggregators() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Gets the registry for aggregators for the iteration. 
- getAggregators() - 类 中的方法org.apache.flink.api.java.operators.IterativeDataSet
- 
Gets the registry for aggregators. 
- getAlt() - 类 中的方法org.apache.flink.api.java.utils.Option
- 
已过时。 
- getAnalyzedUdfSemanticsFlag() - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
-  
- getAnalyzedUdfSemanticsFlag() - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
-  
- getBitSize(long) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
-  
- getBoolean(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Boolean value for the given key. 
- getBoolean(String, boolean) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Boolean value for the given key. 
- getBroadcastSets() - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
-  
- getBroadcastSets() - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
-  
- getBroadcastSets() - 接口 中的方法org.apache.flink.api.java.operators.UdfOperator
- 
Gets the broadcast sets (name and data set) that have been added to context of the UDF. 
- getByte(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Byte value for the given key. 
- getByte(String, byte) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Byte value for the given key. 
- getCallLocationName() - 类 中的静态方法org.apache.flink.api.java.Utils
-  
- getCallLocationName(int) - 类 中的静态方法org.apache.flink.api.java.Utils
-  
- getCharset() - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Gets the character set for the reader. 
- getCharsetName() - 类 中的方法org.apache.flink.api.java.io.TextInputFormat
-  
- getCharsetName() - 类 中的方法org.apache.flink.api.java.io.TextOutputFormat
-  
- getCharsetName() - 类 中的方法org.apache.flink.api.java.io.TextValueInputFormat
-  
- getChecksum() - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
-  
- getChoices() - 类 中的方法org.apache.flink.api.java.utils.Option
- 
已过时。 
- getConfig() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Gets the config object that defines execution parameters. 
- getConfiguration() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
-  
- getConfiguration() - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
- 
- getCount() - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
-  
- getCrossHint() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator
-  
- getCustomPartitioner() - 类 中的方法org.apache.flink.api.java.operators.Grouping
- 
Gets the custom partitioner to be used for this grouping, or null, if none was
 defined.
 
- getCustomPartitioner() - 类 中的方法org.apache.flink.api.java.operators.PartitionOperator
- 
Gets the custom partitioner from this partitioning. 
- getDataSet() - 类 中的方法org.apache.flink.api.java.operators.DataSink
-  
- getDefaultLocalParallelism() - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
- getDefaultValue() - 类 中的方法org.apache.flink.api.java.utils.Option
- 
已过时。 
- getDouble(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Double value for the given key. 
- getDouble(String, double) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Double value for the given key. 
- getElement() - 类 中的方法org.apache.flink.api.java.sampling.IntermediateSampleData
-  
- getEmptyCount() - 类 中的方法org.apache.flink.api.java.summarize.StringColumnSummary
- 
Number of empty strings e.g. java.lang.String.isEmpty(). 
- getExecutionEnvironment() - 类 中的方法org.apache.flink.api.java.DataSet
- 
- getExecutionEnvironment() - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates an execution environment that represents the context in which the program is
 currently executed. 
- getExecutionPlan() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates the plan with which the system will execute the program, and returns it as a String
 using a JSON representation of the execution data flow graph. 
- getExecutionPlan(Plan) - 接口 中的方法org.apache.flink.api.java.ExecutionPlanUtil.ExecutionPlanJSONGenerator
- 
Returns the execution plan as a JSON string. 
- getExecutionPlanAsJSON(Plan) - 类 中的静态方法org.apache.flink.api.java.ExecutionPlanUtil
- 
Extracts the execution plan (as JSON) from the given Plan.
 
- getExecutorServiceLoader() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
-  
- getFactory() - 枚举 中的方法org.apache.flink.api.java.aggregation.Aggregations
-  
- getFalseCount() - 类 中的方法org.apache.flink.api.java.summarize.BooleanColumnSummary
-  
- getFields() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-  
- getFieldTypes() - 类 中的方法org.apache.flink.api.java.io.CsvInputFormat
-  
- getFilePath() - 类 中的方法org.apache.flink.api.java.io.CsvReader
-  
- getFloat(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Float value for the given key. 
- getFloat(String, float) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Float value for the given key. 
- getFormat() - 类 中的方法org.apache.flink.api.java.operators.DataSink
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.CoGroupRawOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.FilterOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.FlatMapOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.GroupCombineOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.GroupReduceOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.MapOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.MapPartitionOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.ReduceOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
-  
- getFunction() - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
-  
- getGroupOrdering() - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
-  
- getGroupSortKeyPositions() - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
-  
- getGroupSortOrders() - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
-  
- getHelp() - 类 中的方法org.apache.flink.api.java.utils.RequiredParameters
- 
已过时。 Build a help text for the defined parameters. 
- getHelp(List<String>) - 类 中的方法org.apache.flink.api.java.utils.RequiredParameters
- 
已过时。 Build a help text for the defined parameters and list the missing arguments at the end of the
 text. 
- getHelpText() - 类 中的方法org.apache.flink.api.java.utils.Option
- 
已过时。 
- getInfinityCount() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
- 
Number of values that are positive or negative infinity. 
- getInitialSolutionSet() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Gets the initial solution set. 
- getInitialWorkset() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Gets the initial workset. 
- getInput() - 类 中的方法org.apache.flink.api.java.operators.NoOpOperator
-  
- getInput() - 类 中的方法org.apache.flink.api.java.operators.SingleInputOperator
- 
Gets the data set that this operation uses as its input. 
- getInput1() - 类 中的方法org.apache.flink.api.java.operators.TwoInputOperator
- 
Gets the data set that this operation uses as its first input. 
- getInput1Type() - 类 中的方法org.apache.flink.api.java.operators.TwoInputOperator
- 
Gets the type information of the data type of the first input data set. 
- getInput2() - 类 中的方法org.apache.flink.api.java.operators.TwoInputOperator
- 
Gets the data set that this operation uses as its second input. 
- getInput2Type() - 类 中的方法org.apache.flink.api.java.operators.TwoInputOperator
- 
Gets the type information of the data type of the second input data set. 
- getInputDataSet() - 类 中的方法org.apache.flink.api.java.operators.Grouping
- 
Returns the input DataSet of a grouping operation, that is the one before the grouping. 
- getInputFormat() - 类 中的方法org.apache.flink.api.java.operators.DataSource
- 
Gets the input format that is executed by this data source. 
- getInputType() - 类 中的方法org.apache.flink.api.java.operators.SingleInputOperator
- 
Gets the type information of the data type of the input data set. 
- getInt(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Integer value for the given key. 
- getInt(String, int) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Integer value for the given key. 
- getIntermediateDataSetId() - 类 中的方法org.apache.flink.api.java.io.BlockingShuffleOutputFormat
-  
- getIsFromFirst() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-  
- getIterationHead() - 类 中的方法org.apache.flink.api.java.operators.BulkIterationResultSet
-  
- getIterationHead() - 类 中的方法org.apache.flink.api.java.operators.DeltaIterationResultSet
-  
- getJobListeners() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Gets the config JobListeners. 
- getJoinHint() - 类 中的方法org.apache.flink.api.java.operators.JoinOperator
- 
Gets the JoinHint that describes how the join is executed. 
- getJoinType() - 类 中的方法org.apache.flink.api.java.operators.JoinOperator
- 
Gets the JoinType that describes this join operation (e.g. inner, outer) 
- getKeyFromArgs(String[], int) - 类 中的静态方法org.apache.flink.api.java.Utils
- 
Get the key from the given args. 
- getKeyPositions() - 类 中的方法org.apache.flink.api.java.operators.DeltaIterationResultSet
-  
- getKeys() - 类 中的方法org.apache.flink.api.java.operators.Grouping
-  
- getKeys1() - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator
-  
- getKeys1() - 类 中的方法org.apache.flink.api.java.operators.CoGroupRawOperator
-  
- getKeys1() - 类 中的方法org.apache.flink.api.java.operators.JoinOperator
-  
- getKeys2() - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator
-  
- getKeys2() - 类 中的方法org.apache.flink.api.java.operators.CoGroupRawOperator
-  
- getKeys2() - 类 中的方法org.apache.flink.api.java.operators.JoinOperator
-  
- getLastGroupKey() - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-  
- getLastJobExecutionResult() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Returns the JobExecutionResultof the last executed job.
 
- getLastKey() - 类 中的方法org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-  
- getLastSortKey() - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-  
- getLocalValue() - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
-  
- getLong(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Long value for the given key. 
- getLong(String, long) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Long value for the given key. 
- getMax() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
-  
- getMaxIterations() - 类 中的方法org.apache.flink.api.java.operators.DeltaIterationResultSet
-  
- getMaxIterations() - 类 中的方法org.apache.flink.api.java.operators.IterativeDataSet
- 
Gets the maximum number of iterations. 
- getMaxLength() - 类 中的方法org.apache.flink.api.java.summarize.StringColumnSummary
- 
Longest String length. 
- getMean() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
- 
Null, NaN, and Infinite values are ignored in this calculation. 
- getMeanLength() - 类 中的方法org.apache.flink.api.java.summarize.StringColumnSummary
-  
- getMin() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
-  
- getMinLength() - 类 中的方法org.apache.flink.api.java.summarize.StringColumnSummary
- 
Shortest String length. 
- getMinResources() - 类 中的方法org.apache.flink.api.java.operators.DataSink
- 
Returns the minimum resources of this data sink. 
- getMinResources() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Gets the minimum resources from this iteration. 
- getMinResources() - 类 中的方法org.apache.flink.api.java.operators.Operator
- 
Returns the minimum resource of this operator. 
- getMissingArguments() - 异常错误 中的方法org.apache.flink.api.java.utils.RequiredParametersException
- 
已过时。 
- getMissingCount() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
- 
The number of "missing" values where "missing" is defined as null, NaN, or Infinity. 
- getMultiParameter(String) - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
- 
Returns the Collection of String values for the given key. 
- getMultiParameterRequired(String) - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
- 
Returns the Collection of String values for the given key. 
- getName() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Gets the name from this iteration. 
- getName() - 类 中的方法org.apache.flink.api.java.operators.Operator
- 
Returns the name of the operator. 
- getName() - 类 中的方法org.apache.flink.api.java.utils.Option
- 
已过时。 
- getNanCount() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
- 
Number of values that are NaN. 
- getNextPartialSolution() - 类 中的方法org.apache.flink.api.java.operators.BulkIterationResultSet
-  
- getNextRegistrationId() - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.FlinkChillPackageRegistrar
-  
- getNextSolutionSet() - 类 中的方法org.apache.flink.api.java.operators.DeltaIterationResultSet
-  
- getNextWorkset() - 类 中的方法org.apache.flink.api.java.operators.DeltaIterationResultSet
-  
- getNonMissingCount() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
- 
The number of values that are not null, NaN, or Infinity. 
- getNonNullCount() - 类 中的方法org.apache.flink.api.java.summarize.BooleanColumnSummary
- 
The number of non-null values in this column. 
- getNonNullCount() - 类 中的方法org.apache.flink.api.java.summarize.ColumnSummary
- 
The number of non-null values in this column. 
- getNonNullCount() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
- 
The number of non-null values in this column. 
- getNonNullCount() - 类 中的方法org.apache.flink.api.java.summarize.ObjectColumnSummary
- 
The number of non-null values in this column. 
- getNonNullCount() - 类 中的方法org.apache.flink.api.java.summarize.StringColumnSummary
-  
- getNullCount() - 类 中的方法org.apache.flink.api.java.summarize.BooleanColumnSummary
-  
- getNullCount() - 类 中的方法org.apache.flink.api.java.summarize.ColumnSummary
- 
The number of null values in this column. 
- getNullCount() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
-  
- getNullCount() - 类 中的方法org.apache.flink.api.java.summarize.ObjectColumnSummary
-  
- getNullCount() - 类 中的方法org.apache.flink.api.java.summarize.StringColumnSummary
-  
- getNumberOfExecutionRetries() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
- getNumberOfParameters() - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
- getNumberOfParameters() - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
- 
- getNumberOfParameters() - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
- 
- getParallelism() - 类 中的方法org.apache.flink.api.java.CollectionEnvironment
-  
- getParallelism() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Gets the parallelism with which operation are executed by default. 
- getParallelism() - 类 中的方法org.apache.flink.api.java.operators.DataSink
- 
Returns the parallelism of this data sink. 
- getParallelism() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Gets the iteration's parallelism. 
- getParallelism() - 类 中的方法org.apache.flink.api.java.operators.Operator
- 
Returns the parallelism of this operator. 
- getParameters() - 类 中的方法org.apache.flink.api.java.operators.DataSink
-  
- getParameters() - 类 中的方法org.apache.flink.api.java.operators.DataSource
-  
- getParameters() - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
-  
- getParameters() - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
-  
- getParameters() - 接口 中的方法org.apache.flink.api.java.operators.UdfOperator
- 
Gets the configuration parameters that will be passed to the UDF's open method AbstractRichFunction.open(Configuration).
 
- getPartitioner() - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
- 
Gets the custom partitioner used by this join, or null, if none is set.
 
- getPartitioner() - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator
- 
Gets the custom partitioner used by this join, or null, if none is set.
 
- getPartitioner() - 类 中的方法org.apache.flink.api.java.operators.JoinOperator
- 
Gets the custom partitioner used by this join, or null, if none is set.
 
- getPreferredResources() - 类 中的方法org.apache.flink.api.java.operators.DataSink
- 
Returns the preferred resources of this data sink. 
- getPreferredResources() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Gets the preferred resources from this iteration. 
- getPreferredResources() - 类 中的方法org.apache.flink.api.java.operators.Operator
- 
Returns the preferred resource of this operator. 
- getProducedType() - 类 中的方法org.apache.flink.api.java.io.RowCsvInputFormat
-  
- getProducedType() - 类 中的方法org.apache.flink.api.java.io.TypeSerializerInputFormat
-  
- getProperties() - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
- 
- getRequired(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the String value for the given key. 
- getRestartStrategy() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Returns the specified restart strategy configuration. 
- getResultType() - 类 中的方法org.apache.flink.api.java.operators.Operator
- 
Returns the type of the result of this operator. 
- getSemanticProperties() - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator
-  
- getSemanticProperties() - 类 中的方法org.apache.flink.api.java.operators.GroupCombineOperator
-  
- getSemanticProperties() - 类 中的方法org.apache.flink.api.java.operators.GroupReduceOperator
-  
- getSemanticProperties() - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-  
- getSemanticProperties() - 类 中的方法org.apache.flink.api.java.operators.ReduceOperator
-  
- getSemanticProperties() - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
-  
- getSemanticProperties() - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
-  
- getSemanticProperties() - 接口 中的方法org.apache.flink.api.java.operators.UdfOperator
- 
Gets the semantic properties that have been set for the user-defined functions (UDF). 
- getSemanticPropsDual(Set<Annotation>, TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
-  
- getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
-  
- getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>, boolean) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
-  
- getSemanticPropsSingle(Set<Annotation>, TypeInformation<?>, TypeInformation<?>) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
-  
- getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
-  
- getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>, boolean) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
-  
- getSerializerTree(TypeInformation<T>) - 类 中的静态方法org.apache.flink.api.java.Utils
- 
Debugging utility to understand the hierarchy of serializers created by the Java API. 
- getShort(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Short value for the given key. 
- getShort(String, short) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
Returns the Short value for the given key. 
- getSolutionSet() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Gets the solution set of the delta iteration. 
- getSortSelectionFunctionKey() - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
-  
- getSplitDataProperties() - 类 中的方法org.apache.flink.api.java.operators.DataSource
- 
- getSplitGroupKeys() - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
-  
- getSplitOrder() - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
-  
- getSplitPartitioner() - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
-  
- getSplitPartitionKeys() - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
-  
- getStandardDeviation() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
- 
Standard Deviation is a measure of variation in a set of numbers. 
- getSum() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
-  
- getTerminationCriterion() - 类 中的方法org.apache.flink.api.java.operators.BulkIterationResultSet
-  
- getTotalCount() - 类 中的方法org.apache.flink.api.java.summarize.ColumnSummary
- 
The number of all rows in this column including both nulls and non-nulls. 
- getTrueCount() - 类 中的方法org.apache.flink.api.java.summarize.BooleanColumnSummary
-  
- getType() - 类 中的方法org.apache.flink.api.java.DataSet
- 
Returns the TypeInformationfor the type of this DataSet.
 
- getType() - 类 中的方法org.apache.flink.api.java.operators.DataSink
-  
- getType() - 类 中的方法org.apache.flink.api.java.utils.Option
- 
已过时。 
- getUnrequestedParameters() - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
- 
- getUserCodeClassLoader() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
-  
- getValue(BooleanValue) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
-  
- getValue(DoubleValue) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
-  
- getValue(FloatValue) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
-  
- getValue(VT) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
- 
Get the value out of a value type. 
- getValue(IntValue) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
-  
- getValue(LongValue) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
-  
- getValue(ShortValue) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
-  
- getValue(StringValue) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
-  
- getVariance() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
- 
Variance is a measure of how far a set of numbers are spread out. 
- getWeight() - 类 中的方法org.apache.flink.api.java.sampling.IntermediateSampleData
-  
- getWorkset() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Gets the working set of the delta iteration. 
- getWorksetType() - 类 中的方法org.apache.flink.api.java.operators.DeltaIterationResultSet
-  
- getWrappedFunction() - 类 中的方法org.apache.flink.api.java.operators.translation.WrappingFunction
-  
- groupBy(KeySelector<T, K>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Groups a  DataSet using a  KeySelector function. 
- groupBy(int...) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Groups a  TupleDataSet using field position keys. 
- groupBy(String...) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Groups a  DataSet using field expressions. 
- GroupCombineOperator<IN,OUT> - org.apache.flink.api.java.operators中的类
- 
This operator behaves like the GroupReduceOperator with Combine but only runs the Combine part
 which reduces all data locally in their partitions. 
- GroupCombineOperator(DataSet<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - 类 的构造器org.apache.flink.api.java.operators.GroupCombineOperator
- 
Constructor for a non-grouped reduce (all reduce). 
- GroupCombineOperator(Grouping<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - 类 的构造器org.apache.flink.api.java.operators.GroupCombineOperator
- 
Constructor for a grouped reduce. 
- Grouping<T> - org.apache.flink.api.java.operators中的类
- 
Grouping is an intermediate step for a transformation on a grouped DataSet. 
- Grouping(DataSet<T>, Keys<T>) - 类 的构造器org.apache.flink.api.java.operators.Grouping
-  
- GroupReduceIterator<IN,OUT> - org.apache.flink.api.java.functions中的类
- 
Base class that simplifies reducing all values provided as  Iterable. 
- GroupReduceIterator() - 类 的构造器org.apache.flink.api.java.functions.GroupReduceIterator
-  
- GroupReduceOperator<IN,OUT> - org.apache.flink.api.java.operators中的类
- 
This operator represents the application of a "reduceGroup" function on a data set, and the
 result data set produced by the function. 
- GroupReduceOperator(DataSet<IN>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - 类 的构造器org.apache.flink.api.java.operators.GroupReduceOperator
- 
Constructor for a non-grouped reduce (all reduce). 
- GroupReduceOperator(Grouping<IN>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - 类 的构造器org.apache.flink.api.java.operators.GroupReduceOperator
- 
Constructor for a grouped reduce. 
- parallelism(int) - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Sets the parallelism for the iteration. 
- parallelism - 类 中的变量org.apache.flink.api.java.operators.Operator
-  
- ParallelIteratorInputFormat<T> - org.apache.flink.api.java.io中的类
- 
An input format that generates data in parallel through a SplittableIterator.
 
- ParallelIteratorInputFormat(SplittableIterator<T>) - 类 的构造器org.apache.flink.api.java.io.ParallelIteratorInputFormat
-  
- ParameterTool - org.apache.flink.api.java.utils中的类
- 
This class provides simple utility methods for reading and parsing program arguments from
 different sources. 
- parsedValues - 类 中的变量org.apache.flink.api.java.io.CsvInputFormat
-  
- parseQuotedStrings - 类 中的变量org.apache.flink.api.java.io.CsvReader
-  
- parseQuotedStrings(char) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Enables quoted String parsing. 
- parseRecord(Object[], byte[], int, int) - 类 中的方法org.apache.flink.api.java.io.RowCsvInputFormat
-  
- partition(Integer, int) - 类 中的方法org.apache.flink.api.java.functions.IdPartitioner
-  
- partition(T, int) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
-  
- partitionByHash(int...) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Hash-partitions a DataSet on the specified key fields. 
- partitionByHash(String...) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Hash-partitions a DataSet on the specified key fields. 
- partitionByHash(KeySelector<T, K>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Partitions a DataSet using the specified KeySelector. 
- partitionByRange(int...) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Range-partitions a DataSet on the specified key fields. 
- partitionByRange(String...) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Range-partitions a DataSet on the specified key fields. 
- partitionByRange(KeySelector<T, K>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Range-partitions a DataSet using the specified KeySelector. 
- partitionByRange(DataSet<T>, DataDistribution, int...) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
Range-partitions a DataSet on the specified tuple field positions. 
- partitionByRange(DataSet<T>, DataDistribution, String...) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
Range-partitions a DataSet on the specified fields. 
- partitionByRange(DataSet<T>, DataDistribution, KeySelector<T, K>) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
Range-partitions a DataSet using the specified key selector function. 
- partitionCustom(Partitioner<K>, int) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Partitions a tuple DataSet on the specified key fields using a custom partitioner. 
- partitionCustom(Partitioner<K>, String) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Partitions a POJO DataSet on the specified key fields using a custom partitioner. 
- partitionCustom(Partitioner<K>, KeySelector<T, K>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Partitions a DataSet on the key returned by the selector, using a custom partitioner. 
- PartitionOperator<T> - org.apache.flink.api.java.operators中的类
- 
This operator represents a partitioning. 
- PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, String) - 类 的构造器org.apache.flink.api.java.operators.PartitionOperator
-  
- PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, DataDistribution, String) - 类 的构造器org.apache.flink.api.java.operators.PartitionOperator
-  
- PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, String) - 类 的构造器org.apache.flink.api.java.operators.PartitionOperator
-  
- PartitionOperator(DataSet<T>, Keys<T>, Partitioner<?>, String) - 类 的构造器org.apache.flink.api.java.operators.PartitionOperator
-  
- PartitionOperator(DataSet<T>, Keys<T>, Partitioner<P>, TypeInformation<P>, String) - 类 的构造器org.apache.flink.api.java.operators.PartitionOperator
-  
- PlanBothUnwrappingCoGroupOperator<I1,I2,OUT,K> - org.apache.flink.api.java.operators.translation中的类
- 
A co group operator that applies the operation only on the unwrapped values. 
- PlanBothUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, Keys.SelectorFunctionKeys<I1, K>, Keys.SelectorFunctionKeys<I2, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, I1>>, TypeInformation<Tuple2<K, I2>>) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanBothUnwrappingCoGroupOperator
-  
- PlanFilterOperator<T> - org.apache.flink.api.java.operators.translation中的类
-  
- PlanFilterOperator(FilterFunction<T>, String, TypeInformation<T>) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanFilterOperator
-  
- PlanFilterOperator.FlatMapFilter<T> - org.apache.flink.api.java.operators.translation中的类
-  
- PlanGenerator - org.apache.flink.api.java.utils中的类
- 
A generator that generates a Planfrom a graph ofOperators.
 
- PlanGenerator(List<DataSink<?>>, ExecutionConfig, int, List<Tuple2<String, DistributedCache.DistributedCacheEntry>>, String) - 类 的构造器org.apache.flink.api.java.utils.PlanGenerator
-  
- PlanLeftUnwrappingCoGroupOperator<I1,I2,OUT,K> - org.apache.flink.api.java.operators.translation中的类
- 
A co group operator that applies the operation only on the unwrapped values on the left. 
- PlanLeftUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, Keys.SelectorFunctionKeys<I1, K>, int[], String, TypeInformation<OUT>, TypeInformation<Tuple2<K, I1>>, TypeInformation<I2>) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanLeftUnwrappingCoGroupOperator
-  
- PlanProjectOperator<T,R extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.api.java.operators.translation中的类
- 
A map operator that retains a subset of fields from incoming tuples. 
- PlanProjectOperator(int[], String, TypeInformation<T>, TypeInformation<R>, ExecutionConfig) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanProjectOperator
-  
- PlanRightUnwrappingCoGroupOperator<I1,I2,OUT,K> - org.apache.flink.api.java.operators.translation中的类
- 
A co group operator that applies the operation only on the unwrapped values on the right. 
- PlanRightUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, int[], Keys.SelectorFunctionKeys<I2, K>, String, TypeInformation<OUT>, TypeInformation<I1>, TypeInformation<Tuple2<K, I2>>) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanRightUnwrappingCoGroupOperator
-  
- PlanUnwrappingGroupCombineOperator<IN,OUT,K> - org.apache.flink.api.java.operators.translation中的类
- 
A group combine operator that takes 2-tuples (key-value pairs), and applies the group combine
 operation only on the unwrapped values. 
- PlanUnwrappingGroupCombineOperator(GroupCombineFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, IN>>) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanUnwrappingGroupCombineOperator
-  
- PlanUnwrappingReduceGroupOperator<IN,OUT,K> - org.apache.flink.api.java.operators.translation中的类
- 
A reduce operator that takes 2-tuples (key-value pairs), and applies the group reduce operation
 only on the unwrapped values. 
- PlanUnwrappingReduceGroupOperator(GroupReduceFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, IN>>, boolean) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator
-  
- PlanUnwrappingReduceOperator<T,K> - org.apache.flink.api.java.operators.translation中的类
- 
A reduce operator that takes 2-tuples (key-value pairs), and applies the reduce operation only on
 the unwrapped values. 
- PlanUnwrappingReduceOperator(ReduceFunction<T>, Keys.SelectorFunctionKeys<T, K>, String, TypeInformation<T>, TypeInformation<Tuple2<K, T>>) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceOperator
-  
- PlanUnwrappingSortedGroupCombineOperator<IN,OUT,K1,K2> - org.apache.flink.api.java.operators.translation中的类
- 
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted partial
 group reduce operation only on the unwrapped values. 
- PlanUnwrappingSortedGroupCombineOperator(GroupCombineFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K1>, Keys.SelectorFunctionKeys<IN, K2>, String, TypeInformation<OUT>, TypeInformation<Tuple3<K1, K2, IN>>) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedGroupCombineOperator
-  
- PlanUnwrappingSortedReduceGroupOperator<IN,OUT,K1,K2> - org.apache.flink.api.java.operators.translation中的类
- 
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted group
 reduce operation only on the unwrapped values. 
- PlanUnwrappingSortedReduceGroupOperator(GroupReduceFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K1>, Keys.SelectorFunctionKeys<IN, K2>, String, TypeInformation<OUT>, TypeInformation<Tuple3<K1, K2, IN>>, boolean) - 类 的构造器org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator
-  
- PoissonSampler<T> - org.apache.flink.api.java.sampling中的类
- 
A sampler implementation based on the Poisson Distribution. 
- PoissonSampler(double, long) - 类 的构造器org.apache.flink.api.java.sampling.PoissonSampler
- 
Create a poisson sampler which can sample elements with replacement. 
- PoissonSampler(double) - 类 的构造器org.apache.flink.api.java.sampling.PoissonSampler
- 
Create a poisson sampler which can sample elements with replacement. 
- PojoCsvInputFormat<OUT> - org.apache.flink.api.java.io中的类
- 
Input format that reads csv into POJOs. 
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, int[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[], int[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, int[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[], int[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, boolean[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[], boolean[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, boolean[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[], boolean[]) - 类 的构造器org.apache.flink.api.java.io.PojoCsvInputFormat
-  
- pojoType(Class<T>, String...) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Configures the reader to read the CSV data and parse it to the given type. 
- preferredResources - 类 中的变量org.apache.flink.api.java.operators.Operator
-  
- PrimitiveInputFormat<OT> - org.apache.flink.api.java.io中的类
- 
An input format that reads single field primitive data from a given file. 
- PrimitiveInputFormat(Path, Class<OT>) - 类 的构造器org.apache.flink.api.java.io.PrimitiveInputFormat
-  
- PrimitiveInputFormat(Path, String, Class<OT>) - 类 的构造器org.apache.flink.api.java.io.PrimitiveInputFormat
-  
- print() - 类 中的方法org.apache.flink.api.java.DataSet
- 
Prints the elements in a DataSet to the standard output stream  System.out of the JVM
 that calls the print() method. 
- print(String) - 类 中的方法org.apache.flink.api.java.DataSet
- 
- PrintingOutputFormat<T> - org.apache.flink.api.java.io中的类
- 
Output format that prints results into either stdout or stderr. 
- PrintingOutputFormat() - 类 的构造器org.apache.flink.api.java.io.PrintingOutputFormat
- 
Instantiates a printing output format that prints to standard out. 
- PrintingOutputFormat(boolean) - 类 的构造器org.apache.flink.api.java.io.PrintingOutputFormat
- 
Instantiates a printing output format that prints to standard out. 
- PrintingOutputFormat(String, boolean) - 类 的构造器org.apache.flink.api.java.io.PrintingOutputFormat
- 
Instantiates a printing output format that prints to standard out with a prefixed message. 
- printOnTaskManager(String) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a DataSet to the standard output streams (stdout) of the TaskManagers that execute the
 program (or more specifically, the data sink operators). 
- printToErr() - 类 中的方法org.apache.flink.api.java.DataSet
- 
Prints the elements in a DataSet to the standard error stream  System.err of the JVM
 that calls the print() method. 
- printToErr(String) - 类 中的方法org.apache.flink.api.java.DataSet
- 
- project(int...) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Applies a Project transformation on a  TupleDataSet. 
- ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperatorBase.CrossHint) - 类 的构造器org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-  
- ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperator.CrossProjection<I1, I2>, CrossOperatorBase.CrossHint) - 类 的构造器org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-  
- projectFirst(int...) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Continues a ProjectCross transformation and adds fields of the first cross input. 
- projectFirst(int...) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.DefaultCross
- 
Initiates a ProjectCross transformation and projects the first cross input. 
- projectFirst(int...) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCross
- 
Continues a ProjectCross transformation and adds fields of the first cross input to the
 projection. 
- projectFirst(int...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
- 
Applies a ProjectJoin transformation and projects the first join input
 If the first join input is a  TupleDataSet, fields can be selected by
 their index. 
- projectFirst(int...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
- 
Continues a ProjectJoin transformation and adds fields of the first join input to the
 projection. 
- Projection(DataSet<T>, int[]) - 类 的构造器org.apache.flink.api.java.operators.ProjectOperator.Projection
-  
- ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-  
- ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>, JoinOperator.JoinProjection<I1, I2>) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-  
- ProjectOperator<IN,OUT extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.api.java.operators中的类
- 
This operator represents the application of a projection operation on a data set, and the result
 data set produced by the function. 
- ProjectOperator(DataSet<IN>, int[], TupleTypeInfo<OUT>) - 类 的构造器org.apache.flink.api.java.operators.ProjectOperator
-  
- ProjectOperator.Projection<T> - org.apache.flink.api.java.operators中的类
- 
- projectSecond(int...) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Continues a ProjectCross transformation and adds fields of the second cross input. 
- projectSecond(int...) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.DefaultCross
- 
Initiates a ProjectCross transformation and projects the second cross input. 
- projectSecond(int...) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCross
- 
Continues a ProjectCross transformation and adds fields of the second cross input to the
 projection. 
- projectSecond(int...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
- 
Applies a ProjectJoin transformation and projects the second join input
 If the second join input is a  TupleDataSet, fields can be selected by
 their index. 
- projectSecond(int...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
- 
Continues a ProjectJoin transformation and adds fields of the second join input to the
 projection. 
- projectTuple1() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple1() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple10() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple10() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple11() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple11() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple12() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple12() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple13() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple13() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple14() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple14() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple15() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple15() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple16() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple16() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple17() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple17() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple18() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple18() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple19() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple19() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple2() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple2() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple20() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple20() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple21() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple21() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple22() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple22() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple23() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple23() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple24() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple24() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple25() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple25() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple3() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple3() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple4() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple4() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple5() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple5() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple6() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple6() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple7() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple7() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple8() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple8() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTuple9() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
Projects a pair of crossed elements to a Tuplewith the previously selected
 fields.
 
- projectTuple9() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
Projects a  TupleDataSet to the previously selected fields. 
- projectTupleX() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
- 
- projectTupleX() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
- 
- RandomSampler<T> - org.apache.flink.api.java.sampling中的类
- 
A data sample is a set of data selected from a statistical population by a defined procedure. 
- RandomSampler() - 类 的构造器org.apache.flink.api.java.sampling.RandomSampler
-  
- reachedEnd() - 类 中的方法org.apache.flink.api.java.io.CollectionInputFormat
-  
- reachedEnd() - 类 中的方法org.apache.flink.api.java.io.IteratorInputFormat
-  
- reachedEnd() - 类 中的方法org.apache.flink.api.java.io.ParallelIteratorInputFormat
-  
- readCsvFile(String) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a CSV reader to read a comma separated value (CSV) file. 
- readDualForwardAnnotations(Class<?>) - 类 中的静态方法org.apache.flink.api.java.functions.FunctionAnnotation
- 
Reads the annotations of a user defined function with two inputs and returns semantic
 properties according to the forwarded fields annotated. 
- readFile(FileInputFormat<X>, String) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
-  
- readFileOfPrimitives(String, Class<X>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a  DataSet that represents the primitive type produced by reading the given
 file line wise. 
- readFileOfPrimitives(String, String, Class<X>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a  DataSet that represents the primitive type produced by reading the given
 file in delimited way. 
- readRecord(OUT, byte[], int, int) - 类 中的方法org.apache.flink.api.java.io.CsvInputFormat
-  
- readRecord(OT, byte[], int, int) - 类 中的方法org.apache.flink.api.java.io.PrimitiveInputFormat
-  
- readRecord(String, byte[], int, int) - 类 中的方法org.apache.flink.api.java.io.TextInputFormat
-  
- readRecord(StringValue, byte[], int, int) - 类 中的方法org.apache.flink.api.java.io.TextValueInputFormat
-  
- readSingleForwardAnnotations(Class<?>) - 类 中的静态方法org.apache.flink.api.java.functions.FunctionAnnotation
- 
Reads the annotations of a user defined function with one input and returns semantic
 properties according to the forwarded fields annotated. 
- readTextFile(String) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a  DataSet that represents the Strings produced by reading the given file line
 wise. 
- readTextFile(String, String) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a  DataSet that represents the Strings produced by reading the given file line
 wise. 
- readTextFileWithValue(String) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a  DataSet that represents the Strings produced by reading the given file line
 wise. 
- readTextFileWithValue(String, String, boolean) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Creates a  DataSet that represents the Strings produced by reading the given file line
 wise. 
- rebalance() - 类 中的方法org.apache.flink.api.java.DataSet
- 
Enforces a re-balancing of the DataSet, i.e., the DataSet is evenly distributed over all
 parallel instances of the following task. 
- reduce(ReduceFunction<T>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Applies a Reduce transformation on a non-grouped  DataSet. 
- reduce(Iterable<T>, Collector<T>) - 类 中的方法org.apache.flink.api.java.functions.FirstReducer
-  
- reduce(Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.api.java.functions.GroupReduceIterator
-  
- reduce(Iterable<IntermediateSampleData<T>>, Collector<T>) - 类 中的方法org.apache.flink.api.java.functions.SampleInCoordinator
-  
- reduce(T, T) - 类 中的方法org.apache.flink.api.java.functions.SelectByMaxFunction
- 
Reduce implementation, returns bigger tuple or value1 if both tuples are equal. 
- reduce(T, T) - 类 中的方法org.apache.flink.api.java.functions.SelectByMinFunction
- 
Reduce implementation, returns smaller tuple or value1 if both tuples are equal. 
- reduce(Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
-  
- reduce(Iterable<IN>, Collector<OUT>) - 类 中的方法org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
-  
- reduce(ReduceFunction<T>) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
- 
Applies a Reduce transformation on a grouped  DataSet. 
- reduceGroup(GroupReduceFunction<T, R>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Applies a GroupReduce transformation on a non-grouped  DataSet. 
- reduceGroup(Iterable<IN>) - 类 中的方法org.apache.flink.api.java.functions.GroupReduceIterator
-  
- reduceGroup(GroupReduceFunction<T, R>) - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
- 
Applies a GroupReduce transformation on a grouped and sorted  DataSet. 
- reduceGroup(GroupReduceFunction<T, R>) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
- 
Applies a GroupReduce transformation on a grouped  DataSet. 
- ReduceOperator<IN> - org.apache.flink.api.java.operators中的类
- 
This operator represents the application of a "reduce" function on a data set, and the result
 data set produced by the function. 
- ReduceOperator(DataSet<IN>, ReduceFunction<IN>, String) - 类 的构造器org.apache.flink.api.java.operators.ReduceOperator
- 
This is the case for a reduce-all case (in contrast to the reduce-per-group case). 
- ReduceOperator(Grouping<IN>, ReduceFunction<IN>, String) - 类 的构造器org.apache.flink.api.java.operators.ReduceOperator
-  
- registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Registers an Aggregatorfor the iteration together with aConvergenceCriterion.
 
- registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - 类 中的方法org.apache.flink.api.java.operators.IterativeDataSet
- 
Registers an Aggregatorfor the iteration together with aConvergenceCriterion.
 
- registerAggregator(String, Aggregator<?>) - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Registers an Aggregatorfor the iteration.
 
- registerAggregator(String, Aggregator<?>) - 类 中的方法org.apache.flink.api.java.operators.IterativeDataSet
- 
Registers an Aggregatorfor the iteration.
 
- registerCachedFile(String, String) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Registers a file at the distributed cache under the given name. 
- registerCachedFile(String, String, boolean) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Registers a file at the distributed cache under the given name. 
- registerJobListener(JobListener) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Register a JobListenerin this environment.
 
- registerSerializers(Kryo) - 类 中的方法org.apache.flink.api.java.typeutils.runtime.kryo.FlinkChillPackageRegistrar
-  
- registerType(Class<?>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Registers the given type with the serialization stack. 
- registerTypeWithKryoSerializer(Class<?>, T) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Registers the given type with a Kryo Serializer. 
- registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Registers the given Serializer via its class as a serializer for the given type at the
 KryoSerializer. 
- RemoteEnvironment - org.apache.flink.api.java中的类
- 
- RemoteEnvironment(String, int, String...) - 类 的构造器org.apache.flink.api.java.RemoteEnvironment
- 
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given
 host name and port. 
- RemoteEnvironment(String, int, Configuration, String[]) - 类 的构造器org.apache.flink.api.java.RemoteEnvironment
- 
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given
 host name and port. 
- RemoteEnvironment(String, int, Configuration, String[], URL[]) - 类 的构造器org.apache.flink.api.java.RemoteEnvironment
- 
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given
 host name and port. 
- RemoteEnvironmentConfigUtils - org.apache.flink.api.java中的类
- 
A set of tools used by batch and streaming remote environments when preparing their
 configurations. 
- RemoteEnvironmentConfigUtils() - 类 的构造器org.apache.flink.api.java.RemoteEnvironmentConfigUtils
-  
- remove() - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-  
- remove() - 类 中的方法org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-  
- RequiredParameters - org.apache.flink.api.java.utils中的类
- 
- RequiredParameters() - 类 的构造器org.apache.flink.api.java.utils.RequiredParameters
- 
已过时。 
- RequiredParametersException - org.apache.flink.api.java.utils中的异常错误
- 
- RequiredParametersException() - 异常错误 的构造器org.apache.flink.api.java.utils.RequiredParametersException
- 
已过时。 
- RequiredParametersException(String, List<String>) - 异常错误 的构造器org.apache.flink.api.java.utils.RequiredParametersException
- 
已过时。 
- RequiredParametersException(String) - 异常错误 的构造器org.apache.flink.api.java.utils.RequiredParametersException
- 
已过时。 
- RequiredParametersException(String, Throwable) - 异常错误 的构造器org.apache.flink.api.java.utils.RequiredParametersException
- 
已过时。 
- RequiredParametersException(Throwable) - 异常错误 的构造器org.apache.flink.api.java.utils.RequiredParametersException
- 
已过时。 
- ReservoirSamplerWithoutReplacement<T> - org.apache.flink.api.java.sampling中的类
- 
A simple in memory implementation of Reservoir Sampling without replacement, and with only one
 pass through the input iteration whose size is unpredictable. 
- ReservoirSamplerWithoutReplacement(int, Random) - 类 的构造器org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
- 
Create a new sampler with reservoir size and a supplied random number generator. 
- ReservoirSamplerWithoutReplacement(int) - 类 的构造器org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
- 
Create a new sampler with reservoir size and a default random number generator. 
- ReservoirSamplerWithoutReplacement(int, long) - 类 的构造器org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
- 
Create a new sampler with reservoir size and the seed for random number generator. 
- ReservoirSamplerWithReplacement<T> - org.apache.flink.api.java.sampling中的类
- 
A simple in memory implementation of Reservoir Sampling with replacement and with only one pass
 through the input iteration whose size is unpredictable. 
- ReservoirSamplerWithReplacement(int) - 类 的构造器org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
- 
Create a sampler with fixed sample size and default random number generator. 
- ReservoirSamplerWithReplacement(int, long) - 类 的构造器org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
- 
Create a sampler with fixed sample size and random number generator seed. 
- ReservoirSamplerWithReplacement(int, Random) - 类 的构造器org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
- 
Create a sampler with fixed sample size and random number generator. 
- resetContextEnvironment() - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
Un-sets the context environment factory. 
- resetLocal() - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
-  
- resolveFactory(ThreadLocal<T>, T) - 类 中的静态方法org.apache.flink.api.java.Utils
- 
Resolves the given factories. 
- result() - 接口 中的方法org.apache.flink.api.java.summarize.aggregation.Aggregator
- 
Provide the final result of the aggregation. 
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
-  
- result() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
-  
- returns(Class<OUT>) - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
- 
Adds a type information hint about the return type of this operator. 
- returns(TypeHint<OUT>) - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
- 
Adds a type information hint about the return type of this operator. 
- returns(TypeInformation<OUT>) - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
- 
Adds a type information hint about the return type of this operator. 
- returns(Class<OUT>) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
- 
Adds a type information hint about the return type of this operator. 
- returns(TypeHint<OUT>) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
- 
Adds a type information hint about the return type of this operator. 
- returns(TypeInformation<OUT>) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
- 
Adds a type information hint about the return type of this operator. 
- RichCombineToGroupCombineWrapper<IN,OUT,F extends org.apache.flink.api.common.functions.RichGroupReduceFunction<IN,OUT> & org.apache.flink.api.common.functions.CombineFunction<IN,IN>> - org.apache.flink.api.java.operators.translation中的类
- 
A wrapper the wraps a function that implements both CombineFunctionandGroupReduceFunctioninterfaces and makes it look like a function that implementsGroupCombineFunctionandGroupReduceFunctionto the runtime.
 
- RichCombineToGroupCombineWrapper(F) - 类 的构造器org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
-  
- rightOuterJoin(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Initiates a Right Outer Join transformation. 
- rightOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Initiates a Right Outer Join transformation. 
- RNG - 类 中的静态变量org.apache.flink.api.java.Utils
-  
- RowCsvInputFormat - org.apache.flink.api.java.io中的类
- 
Input format that reads csv into Row.
 
- RowCsvInputFormat(Path, TypeInformation[], String, String, int[], boolean) - 类 的构造器org.apache.flink.api.java.io.RowCsvInputFormat
-  
- RowCsvInputFormat(Path, TypeInformation[], String, String, int[]) - 类 的构造器org.apache.flink.api.java.io.RowCsvInputFormat
-  
- RowCsvInputFormat(Path, TypeInformation[], String, String) - 类 的构造器org.apache.flink.api.java.io.RowCsvInputFormat
-  
- RowCsvInputFormat(Path, TypeInformation[], int[]) - 类 的构造器org.apache.flink.api.java.io.RowCsvInputFormat
-  
- RowCsvInputFormat(Path, TypeInformation[], boolean) - 类 的构造器org.apache.flink.api.java.io.RowCsvInputFormat
-  
- RowCsvInputFormat(Path, TypeInformation[]) - 类 的构造器org.apache.flink.api.java.io.RowCsvInputFormat
-  
- runOperation(CustomUnaryOperation<T, X>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
- sample(Iterator<T>) - 类 中的方法org.apache.flink.api.java.sampling.BernoulliSampler
- 
Sample the input elements, for each input element, take a Bernoulli trail for sampling. 
- sample(Iterator<T>) - 类 中的方法org.apache.flink.api.java.sampling.DistributedRandomSampler
- 
Combine the first phase and second phase in sequence, implemented for test purpose only. 
- sample(Iterator<T>) - 类 中的方法org.apache.flink.api.java.sampling.PoissonSampler
- 
Sample the input elements, for each input element, generate its count following a poisson
 distribution. 
- sample(Iterator<T>) - 类 中的方法org.apache.flink.api.java.sampling.RandomSampler
- 
Randomly sample the elements from input in sequence, and return the result iterator. 
- sample(DataSet<T>, boolean, double) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
Generate a sample of DataSet by the probability fraction of each element. 
- sample(DataSet<T>, boolean, double, long) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
Generate a sample of DataSet by the probability fraction of each element. 
- SampleInCoordinator<T> - org.apache.flink.api.java.functions中的类
- 
SampleInCoordinator wraps the sample logic of the coordinator side (the second phase of
 distributed sample algorithm). 
- SampleInCoordinator(boolean, int, long) - 类 的构造器org.apache.flink.api.java.functions.SampleInCoordinator
- 
Create a function instance of SampleInCoordinator. 
- sampleInCoordinator(Iterator<IntermediateSampleData<T>>) - 类 中的方法org.apache.flink.api.java.sampling.DistributedRandomSampler
- 
Sample algorithm for the second phase. 
- SampleInPartition<T> - org.apache.flink.api.java.functions中的类
- 
SampleInPartition wraps the sample logic on the partition side (the first phase of distributed
 sample algorithm). 
- SampleInPartition(boolean, int, long) - 类 的构造器org.apache.flink.api.java.functions.SampleInPartition
- 
Create a function instance of SampleInPartition. 
- sampleInPartition(Iterator<T>) - 类 中的方法org.apache.flink.api.java.sampling.DistributedRandomSampler
- 
Sample algorithm for the first phase. 
- sampleInPartition(Iterator<T>) - 类 中的方法org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
-  
- sampleInPartition(Iterator<T>) - 类 中的方法org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
-  
- SampleWithFraction<T> - org.apache.flink.api.java.functions中的类
- 
A map partition function wrapper for sampling algorithms with fraction, the sample algorithm
 takes the partition iterator as input. 
- SampleWithFraction(boolean, double, long) - 类 的构造器org.apache.flink.api.java.functions.SampleWithFraction
- 
Create a function instance of SampleWithFraction. 
- sampleWithSize(DataSet<T>, boolean, int) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
Generate a sample of DataSet which contains fixed size elements. 
- sampleWithSize(DataSet<T>, boolean, int, long) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
Generate a sample of DataSet which contains fixed size elements. 
- SelectByMaxFunction<T extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.api.java.functions中的类
- 
Function that enables selection by maximal value of a field. 
- SelectByMaxFunction(TupleTypeInfo<T>, int...) - 类 的构造器org.apache.flink.api.java.functions.SelectByMaxFunction
- 
Constructor which is overwriting the default constructor. 
- SelectByMinFunction<T extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.api.java.functions中的类
- 
Function that enables selection by minimal value of a field. 
- SelectByMinFunction(TupleTypeInfo<T>, int...) - 类 的构造器org.apache.flink.api.java.functions.SelectByMinFunction
- 
Constructor which is overwriting the default constructor. 
- SemanticPropUtil - org.apache.flink.api.java.functions中的类
- 
Utility class that contains helper methods to work with SemanticProperties.
 
- serialize(T, DataOutputView) - 类 中的方法org.apache.flink.api.java.io.TypeSerializerOutputFormat
-  
- set(Iterator<Tuple3<K1, K2, T>>) - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-  
- set(Collector<Tuple3<K1, K2, IN>>) - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
-  
- set(Iterator<Tuple2<K, T>>) - 类 中的方法org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-  
- set(Collector<Tuple2<K, IN>>) - 类 中的方法org.apache.flink.api.java.operators.translation.TupleWrappingCollector
-  
- setAllowNullValues(boolean) - 类 中的方法org.apache.flink.api.java.io.CsvOutputFormat
- 
Configures the format to either allow null values (writing an empty field), or to throw an
 exception when encountering a null field. 
- setAnalyzedUdfSemanticsFlag() - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
-  
- setAnalyzedUdfSemanticsFlag() - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
-  
- setCharset(String) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Sets the charset of the reader. 
- setCharsetName(String) - 类 中的方法org.apache.flink.api.java.io.CsvOutputFormat
- 
Sets the charset with which the CSV strings are written to the file. 
- setCharsetName(String) - 类 中的方法org.apache.flink.api.java.io.TextInputFormat
-  
- setCharsetName(String) - 类 中的方法org.apache.flink.api.java.io.TextOutputFormat
-  
- setCharsetName(String) - 类 中的方法org.apache.flink.api.java.io.TextValueInputFormat
-  
- setCombinable(boolean) - 类 中的方法org.apache.flink.api.java.operators.GroupReduceOperator
-  
- setCombineHint(ReduceOperatorBase.CombineHint) - 类 中的方法org.apache.flink.api.java.operators.DistinctOperator
- 
Sets the strategy to use for the combine phase of the reduce. 
- setCombineHint(ReduceOperatorBase.CombineHint) - 类 中的方法org.apache.flink.api.java.operators.ReduceOperator
- 
Sets the strategy to use for the combine phase of the reduce. 
- setDefaultLocalParallelism(int) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
- 
- setInput(DataSet<IN>) - 接口 中的方法org.apache.flink.api.java.operators.CustomUnaryOperation
-  
- setInput(DataSet<IN>) - 类 中的方法org.apache.flink.api.java.operators.NoOpOperator
-  
- setInputType(TypeInformation<?>, ExecutionConfig) - 类 中的方法org.apache.flink.api.java.io.CsvOutputFormat
- 
The purpose of this method is solely to check whether the data type to be processed is in
 fact a tuple type. 
- setInputType(TypeInformation<?>, ExecutionConfig) - 类 中的方法org.apache.flink.api.java.io.LocalCollectionOutputFormat
-  
- setInputType(TypeInformation<?>, ExecutionConfig) - 类 中的方法org.apache.flink.api.java.io.TypeSerializerOutputFormat
-  
- setJarURLsToConfig(String[], Configuration) - 类 中的静态方法org.apache.flink.api.java.RemoteEnvironmentConfigUtils
-  
- setJobManagerAddressToConfig(String, int, Configuration) - 类 中的静态方法org.apache.flink.api.java.RemoteEnvironmentConfigUtils
-  
- setNumberOfExecutionRetries(int) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
- setParallelism(int) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Sets the parallelism for operations executed through this environment. 
- setParallelism(int) - 类 中的方法org.apache.flink.api.java.operators.DataSink
- 
Sets the parallelism for this data sink. 
- setParallelism(int) - 类 中的方法org.apache.flink.api.java.operators.Operator
- 
Sets the parallelism for this operator. 
- setParallelism(int) - 类 中的方法org.apache.flink.api.java.operators.UnionOperator
-  
- setQuoteStrings(boolean) - 类 中的方法org.apache.flink.api.java.io.CsvOutputFormat
- 
Configures whether the output format should quote string values. 
- setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
- 
Sets the restart strategy configuration. 
- setRuntimeContext(RuntimeContext) - 类 中的方法org.apache.flink.api.java.operators.translation.WrappingFunction
-  
- setSemanticProperties(SingleInputSemanticProperties) - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
- 
Sets the semantic properties for the user-defined function (UDF). 
- setSemanticProperties(DualInputSemanticProperties) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
- 
Sets the semantic properties for the user-defined function (UDF). 
- setSerializer(TypeSerializer<T>) - 类 中的方法org.apache.flink.api.java.io.TypeSerializerOutputFormat
-  
- setSkipInvalidLines(boolean) - 类 中的方法org.apache.flink.api.java.io.TextValueInputFormat
-  
- setSolutionSetUnManaged(boolean) - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
- 
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or
 unmanaged memory (objects on heap). 
- ShortSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
- 
Aggregator that can handle Short types. 
- ShortSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
-  
- ShortSummaryAggregator.MaxShortAggregator - org.apache.flink.api.java.summarize.aggregation中的类
- 
Aggregator for max operation. 
- ShortSummaryAggregator.MinShortAggregator - org.apache.flink.api.java.summarize.aggregation中的类
- 
Aggregator for min operation. 
- ShortSummaryAggregator.SumShortAggregator - org.apache.flink.api.java.summarize.aggregation中的类
- 
Aggregator for sum operation. 
- ShortValueSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
-  
- SingleInputOperator<IN,OUT,O extends SingleInputOperator<IN,OUT,O>> - org.apache.flink.api.java.operators中的类
- 
Base class for operations that operates on a single input data set. 
- SingleInputOperator(DataSet<IN>, TypeInformation<OUT>) - 类 的构造器org.apache.flink.api.java.operators.SingleInputOperator
-  
- SingleInputUdfOperator<IN,OUT,O extends SingleInputUdfOperator<IN,OUT,O>> - org.apache.flink.api.java.operators中的类
- 
The SingleInputUdfOperator is the base class of all unary operators that execute
 user-defined functions (UDFs). 
- SingleInputUdfOperator(DataSet<IN>, TypeInformation<OUT>) - 类 的构造器org.apache.flink.api.java.operators.SingleInputUdfOperator
- 
Creates a new operators with the given data set as input. 
- skipFirstLineAsHeader - 类 中的变量org.apache.flink.api.java.io.CsvReader
-  
- SortedGrouping<T> - org.apache.flink.api.java.operators中的类
- 
SortedGrouping is an intermediate step for a transformation on a grouped and sorted DataSet. 
- SortedGrouping(DataSet<T>, Keys<T>, int, Order) - 类 的构造器org.apache.flink.api.java.operators.SortedGrouping
-  
- SortedGrouping(DataSet<T>, Keys<T>, String, Order) - 类 的构造器org.apache.flink.api.java.operators.SortedGrouping
-  
- SortedGrouping(DataSet<T>, Keys<T>, Keys.SelectorFunctionKeys<T, K>, Order) - 类 的构造器org.apache.flink.api.java.operators.SortedGrouping
-  
- sortFirstGroup(int, Order) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
- 
Sorts Tupleelements within a group in
 the first input on the specified field in the specifiedOrder.
 
- sortFirstGroup(String, Order) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
- 
Sorts Pojo or Tupleelements within a
 group in the first input on the specified field in the specifiedOrder.
 
- sortGroup(int, Order) - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
- 
Sorts Tupleelements within a group on the specified
 field in the specifiedOrder.
 
- sortGroup(String, Order) - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
- 
Sorts Tupleor POJO elements within a group on the
 specified field in the specifiedOrder.
 
- sortGroup(int, Order) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
- 
Sorts Tupleelements within a group on the specified
 field in the specifiedOrder.
 
- sortGroup(String, Order) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
- 
Sorts Pojos within a group on the specified field in the specified Order.
 
- sortGroup(KeySelector<T, K>, Order) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
- 
Sorts elements within a group on a key extracted by the specified KeySelectorin the specifiedOrder.
 
- sortLocalOutput(int, Order) - 类 中的方法org.apache.flink.api.java.operators.DataSink
- 
- sortLocalOutput(String, Order) - 类 中的方法org.apache.flink.api.java.operators.DataSink
- 
- sortPartition(int, Order) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Locally sorts the partitions of the DataSet on the specified field in the specified order. 
- sortPartition(String, Order) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Locally sorts the partitions of the DataSet on the specified field in the specified order. 
- sortPartition(KeySelector<T, K>, Order) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Locally sorts the partitions of the DataSet on the extracted key in the specified order. 
- sortPartition(int, Order) - 类 中的方法org.apache.flink.api.java.operators.SortPartitionOperator
- 
Appends an additional sort order with the specified field in the specified order to the local
 partition sorting of the DataSet. 
- sortPartition(String, Order) - 类 中的方法org.apache.flink.api.java.operators.SortPartitionOperator
- 
Appends an additional sort order with the specified field in the specified order to the local
 partition sorting of the DataSet. 
- sortPartition(KeySelector<T, K>, Order) - 类 中的方法org.apache.flink.api.java.operators.SortPartitionOperator
-  
- SortPartitionOperator<T> - org.apache.flink.api.java.operators中的类
- 
This operator represents a DataSet with locally sorted partitions. 
- SortPartitionOperator(DataSet<T>, int, Order, String) - 类 的构造器org.apache.flink.api.java.operators.SortPartitionOperator
-  
- SortPartitionOperator(DataSet<T>, String, Order, String) - 类 的构造器org.apache.flink.api.java.operators.SortPartitionOperator
-  
- SortPartitionOperator(DataSet<T>, Keys.SelectorFunctionKeys<T, K>, Order, String) - 类 的构造器org.apache.flink.api.java.operators.SortPartitionOperator
-  
- sortSecondGroup(int, Order) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
- 
Sorts Tupleelements within a group in
 the second input on the specified field in the specifiedOrder.
 
- sortSecondGroup(String, Order) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
- 
Sorts Pojo or Tupleelements within a
 group in the second input on the specified field in the specifiedOrder.
 
- SourcePartitionerMarker(String) - 类 的构造器org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
-  
- SplitDataProperties<T> - org.apache.flink.api.java.io中的类
- 
SplitDataProperties define data properties on  InputSplit
 generated by the  InputFormat of a  DataSource. 
- SplitDataProperties(TypeInformation<T>) - 类 的构造器org.apache.flink.api.java.io.SplitDataProperties
- 
Creates SplitDataProperties for the given data types. 
- SplitDataProperties(DataSource<T>) - 类 的构造器org.apache.flink.api.java.io.SplitDataProperties
- 
Creates SplitDataProperties for the given data types. 
- SplitDataProperties.SourcePartitionerMarker<T> - org.apache.flink.api.java.io中的类
- 
A custom partitioner to mark compatible split partitionings. 
- splitsGroupedBy(int...) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
- 
Defines that the data within an input split is grouped on the fields defined by the field
 positions. 
- splitsGroupedBy(String) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
- 
Defines that the data within an input split is grouped on the fields defined by the field
 expressions. 
- splitsOrderedBy(int[], Order[]) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
- 
Defines that the data within an input split is sorted on the fields defined by the field
 positions in the specified orders. 
- splitsOrderedBy(String, Order[]) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
- 
Defines that the data within an input split is sorted on the fields defined by the field
 expressions in the specified orders. 
- splitsPartitionedBy(int...) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
- 
Defines that data is partitioned across input splits on the fields defined by field
 positions. 
- splitsPartitionedBy(String, int...) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
- 
Defines that data is partitioned using a specific partitioning method across input splits on
 the fields defined by field positions. 
- splitsPartitionedBy(String) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
- 
Defines that data is partitioned across input splits on the fields defined by field
 expressions. 
- splitsPartitionedBy(String, String) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties
- 
Defines that data is partitioned using an identifiable method across input splits on the
 fields defined by field expressions. 
- StringColumnSummary - org.apache.flink.api.java.summarize中的类
- 
Summary for a column of Strings. 
- StringColumnSummary(long, long, long, Integer, Integer, Double) - 类 的构造器org.apache.flink.api.java.summarize.StringColumnSummary
-  
- StringSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
- 
- StringSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
-  
- StringValueSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
-  
- sum(int) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Syntactic sugar for aggregate (SUM, field). 
- sum(int) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
- 
Syntactic sugar for aggregate (SUM, field). 
- SumAggregationFunction<T> - org.apache.flink.api.java.aggregation中的类
- 
Definitions of sum functions for different numerical types. 
- SumAggregationFunction() - 类 的构造器org.apache.flink.api.java.aggregation.SumAggregationFunction
-  
- SumAggregationFunction.SumAggregationFunctionFactory - org.apache.flink.api.java.aggregation中的类
- 
- SumAggregationFunctionFactory() - 类 的构造器org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
-  
- SumDoubleAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
-  
- SumFloatAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
-  
- SumIntegerAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
-  
- summarize(DataSet<T>) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
- 
Summarize a DataSet of Tuples by collecting single pass statistics for all columns. 
- SummaryAggregatorFactory - org.apache.flink.api.java.summarize.aggregation中的类
- 
Factory for creating Summary Aggregators. 
- SummaryAggregatorFactory() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
-  
- SumShortAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
-  
- supportsMultiPaths() - 类 中的方法org.apache.flink.api.java.io.TextInputFormat
-  
- supportsMultiPaths() - 类 中的方法org.apache.flink.api.java.io.TextValueInputFormat
-  
- TextInputFormat - org.apache.flink.api.java.io中的类
- 
Input Format that reads text files. 
- TextInputFormat(Path) - 类 的构造器org.apache.flink.api.java.io.TextInputFormat
-  
- TextOutputFormat<T> - org.apache.flink.api.java.io中的类
- 
A FileOutputFormatthat writes objects to a text file.
 
- TextOutputFormat(Path) - 类 的构造器org.apache.flink.api.java.io.TextOutputFormat
-  
- TextOutputFormat(Path, String) - 类 的构造器org.apache.flink.api.java.io.TextOutputFormat
-  
- TextOutputFormat.TextFormatter<IN> - org.apache.flink.api.java.io中的接口
- 
Formatter that transforms values into their  String representations. 
- TextValueInputFormat - org.apache.flink.api.java.io中的类
- 
Input format that reads text files. 
- TextValueInputFormat(Path) - 类 的构造器org.apache.flink.api.java.io.TextValueInputFormat
-  
- toBooleanMask(int[]) - 类 中的静态方法org.apache.flink.api.java.io.CsvInputFormat
-  
- toMap() - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
-  
- toMap() - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
-  
- toMap() - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
-  
- toMultiMap() - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
- 
- toString() - 类 中的方法org.apache.flink.api.java.aggregation.MaxAggregationFunction
-  
- toString() - 类 中的方法org.apache.flink.api.java.aggregation.MinAggregationFunction
-  
- toString() - 类 中的方法org.apache.flink.api.java.aggregation.SumAggregationFunction
-  
- toString() - 类 中的方法org.apache.flink.api.java.io.CollectionInputFormat
-  
- toString() - 类 中的方法org.apache.flink.api.java.io.CsvInputFormat
-  
- toString() - 类 中的方法org.apache.flink.api.java.io.CsvOutputFormat
-  
- toString() - 类 中的方法org.apache.flink.api.java.io.PrintingOutputFormat
-  
- toString() - 类 中的方法org.apache.flink.api.java.io.TextInputFormat
-  
- toString() - 类 中的方法org.apache.flink.api.java.io.TextOutputFormat
-  
- toString() - 类 中的方法org.apache.flink.api.java.io.TextValueInputFormat
-  
- toString() - 类 中的方法org.apache.flink.api.java.LocalEnvironment
-  
- toString() - 类 中的方法org.apache.flink.api.java.operators.DataSink
-  
- toString() - 类 中的方法org.apache.flink.api.java.RemoteEnvironment
-  
- toString() - 类 中的方法org.apache.flink.api.java.summarize.BooleanColumnSummary
-  
- toString() - 类 中的方法org.apache.flink.api.java.summarize.NumericColumnSummary
-  
- toString() - 类 中的方法org.apache.flink.api.java.summarize.ObjectColumnSummary
-  
- toString() - 类 中的方法org.apache.flink.api.java.summarize.StringColumnSummary
-  
- toString() - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
-  
- translateToDataFlow(Operator<IN>) - 类 中的方法org.apache.flink.api.java.operators.AggregateOperator
-  
- translateToDataFlow(Operator<I1>, Operator<I2>) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator
-  
- translateToDataFlow(Operator<I1>, Operator<I2>) - 类 中的方法org.apache.flink.api.java.operators.CoGroupRawOperator
-  
- translateToDataFlow(Operator<I1>, Operator<I2>) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator
-  
- translateToDataFlow(Operator<T>) - 类 中的方法org.apache.flink.api.java.operators.DataSink
-  
- translateToDataFlow() - 类 中的方法org.apache.flink.api.java.operators.DataSource
-  
- translateToDataFlow(Operator<T>) - 类 中的方法org.apache.flink.api.java.operators.DistinctOperator
-  
- translateToDataFlow(Operator<T>) - 类 中的方法org.apache.flink.api.java.operators.FilterOperator
-  
- translateToDataFlow(Operator<IN>) - 类 中的方法org.apache.flink.api.java.operators.FlatMapOperator
-  
- translateToDataFlow(Operator<IN>) - 类 中的方法org.apache.flink.api.java.operators.GroupCombineOperator
-  
- translateToDataFlow(Operator<IN>) - 类 中的方法org.apache.flink.api.java.operators.GroupReduceOperator
-  
- translateToDataFlow(Operator<T>) - 类 中的方法org.apache.flink.api.java.operators.IterativeDataSet
-  
- translateToDataFlow(Operator<I1>, Operator<I2>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-  
- translateToDataFlow(Operator<IN>) - 类 中的方法org.apache.flink.api.java.operators.MapOperator
-  
- translateToDataFlow(Operator<IN>) - 类 中的方法org.apache.flink.api.java.operators.MapPartitionOperator
-  
- translateToDataFlow(Operator<T>) - 类 中的方法org.apache.flink.api.java.operators.PartitionOperator
-  
- translateToDataFlow(Operator<IN>) - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator
-  
- translateToDataFlow(Operator<IN>) - 类 中的方法org.apache.flink.api.java.operators.ReduceOperator
-  
- translateToDataFlow(Operator<IN>) - 类 中的方法org.apache.flink.api.java.operators.SingleInputOperator
- 
Translates this operation to a data flow operator of the common data flow API. 
- translateToDataFlow(Operator<T>) - 类 中的方法org.apache.flink.api.java.operators.SortPartitionOperator
-  
- translateToDataFlow(Operator<IN1>, Operator<IN2>) - 类 中的方法org.apache.flink.api.java.operators.TwoInputOperator
- 
Translates this java API operator into a common API operator with two inputs. 
- translateToDataFlow(Operator<T>, Operator<T>) - 类 中的方法org.apache.flink.api.java.operators.UnionOperator
- 
Returns the BinaryNodeTranslation of the Union. 
- translateToPlan(List<DataSink<?>>, String) - 类 中的方法org.apache.flink.api.java.operators.OperatorTranslation
-  
- Tuple3UnwrappingIterator<T,K1,K2> - org.apache.flink.api.java.operators.translation中的类
- 
An iterator that reads 3-tuples (groupKey, sortKey, value) and returns only the values (third
 field). 
- Tuple3UnwrappingIterator() - 类 的构造器org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-  
- Tuple3WrappingCollector<IN,K1,K2> - org.apache.flink.api.java.operators.translation中的类
- 
Needed to wrap tuples to Tuple3<groupKey, sortKey, value>for combine method of group
 reduce with key selector sorting.
 
- Tuple3WrappingCollector(Tuple3UnwrappingIterator<IN, K1, K2>) - 类 的构造器org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
-  
- TupleCsvInputFormat<OUT> - org.apache.flink.api.java.io中的类
- 
Input format that reads csv into tuples. 
- TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>) - 类 的构造器org.apache.flink.api.java.io.TupleCsvInputFormat
-  
- TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>) - 类 的构造器org.apache.flink.api.java.io.TupleCsvInputFormat
-  
- TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>, int[]) - 类 的构造器org.apache.flink.api.java.io.TupleCsvInputFormat
-  
- TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>, int[]) - 类 的构造器org.apache.flink.api.java.io.TupleCsvInputFormat
-  
- TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>, boolean[]) - 类 的构造器org.apache.flink.api.java.io.TupleCsvInputFormat
-  
- TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>, boolean[]) - 类 的构造器org.apache.flink.api.java.io.TupleCsvInputFormat
-  
- TupleLeftUnwrappingJoiner<I1,I2,OUT,K> - org.apache.flink.api.java.operators.translation中的类
- 
Joiner that unwraps values from the left set before applying the join operation. 
- TupleLeftUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - 类 的构造器org.apache.flink.api.java.operators.translation.TupleLeftUnwrappingJoiner
-  
- TupleRightUnwrappingJoiner<I1,I2,OUT,K> - org.apache.flink.api.java.operators.translation中的类
- 
Joiner that unwraps values from the right set before applying the join operation. 
- TupleRightUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - 类 的构造器org.apache.flink.api.java.operators.translation.TupleRightUnwrappingJoiner
-  
- TupleSummaryAggregator<R extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.api.java.summarize.aggregation中的类
- 
Aggregate tuples using an array of aggregators, one for each "column" or position within the
 Tuple. 
- TupleSummaryAggregator(Aggregator[]) - 类 的构造器org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
-  
- tupleType(Class<T>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Configures the reader to read the CSV data and parse it to the given type. 
- TupleUnwrappingIterator<T,K> - org.apache.flink.api.java.operators.translation中的类
- 
An iterator that reads 2-tuples (key value pairs) and returns only the values (second field). 
- TupleUnwrappingIterator() - 类 的构造器org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-  
- TupleUnwrappingJoiner<I1,I2,OUT,K> - org.apache.flink.api.java.operators.translation中的类
- 
Joiner that unwraps both values before applying the join operation. 
- TupleUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - 类 的构造器org.apache.flink.api.java.operators.translation.TupleUnwrappingJoiner
-  
- TupleWrappingCollector<IN,K> - org.apache.flink.api.java.operators.translation中的类
- 
Needed to wrap tuples to Tuple2<key, value>pairs for combine method of group reduce with
 key selector function.
 
- TupleWrappingCollector(TupleUnwrappingIterator<IN, K>) - 类 的构造器org.apache.flink.api.java.operators.translation.TupleWrappingCollector
-  
- TwoInputOperator<IN1,IN2,OUT,O extends TwoInputOperator<IN1,IN2,OUT,O>> - org.apache.flink.api.java.operators中的类
- 
Base class for operations that operates on two input data sets. 
- TwoInputOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - 类 的构造器org.apache.flink.api.java.operators.TwoInputOperator
-  
- TwoInputUdfOperator<IN1,IN2,OUT,O extends TwoInputUdfOperator<IN1,IN2,OUT,O>> - org.apache.flink.api.java.operators中的类
- 
The TwoInputUdfOperator is the base class of all binary operators that execute
 user-defined functions (UDFs). 
- TwoInputUdfOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - 类 的构造器org.apache.flink.api.java.operators.TwoInputUdfOperator
- 
Creates a new operators with the two given data sets as inputs. 
- TwoKeyExtractingMapper<T,K1,K2> - org.apache.flink.api.java.operators.translation中的类
- 
Mapper that extracts two keys of a value. 
- TwoKeyExtractingMapper(KeySelector<T, K1>, KeySelector<T, K2>) - 类 的构造器org.apache.flink.api.java.operators.translation.TwoKeyExtractingMapper
-  
- type(OptionType) - 类 中的方法org.apache.flink.api.java.utils.Option
- 
已过时。 Define the type of the Option. 
- types(Class<T0>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>, Class<T22>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>, Class<T22>, Class<T23>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>, Class<T22>, Class<T23>, Class<T24>) - 类 中的方法org.apache.flink.api.java.io.CsvReader
- 
Specifies the types for the CSV fields. 
- types(Class<?>...) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCross
- 
- types(Class<?>...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
- 
- types(Class<?>...) - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator
- 
- TypeSerializerInputFormat<T> - org.apache.flink.api.java.io中的类
- 
Reads elements by deserializing them with a given type serializer. 
- TypeSerializerInputFormat(TypeInformation<T>) - 类 的构造器org.apache.flink.api.java.io.TypeSerializerInputFormat
-  
- TypeSerializerOutputFormat<T> - org.apache.flink.api.java.io中的类
- 
Stores elements by serializing them with their type serializer. 
- TypeSerializerOutputFormat() - 类 的构造器org.apache.flink.api.java.io.TypeSerializerOutputFormat
-  
- where(int...) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
- 
Continues a CoGroup transformation. 
- where(String...) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
- 
Continues a CoGroup transformation. 
- where(KeySelector<I1, K>) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
- 
Continues a CoGroup transformation and defines a  KeySelector function for the
 first co-grouped  DataSet. 
- where(int...) - 类 中的方法org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
- 
Continues a Join transformation. 
- where(String...) - 类 中的方法org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
- 
Continues a Join transformation. 
- where(KeySelector<I1, K>) - 类 中的方法org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
- 
Continues a Join transformation and defines a  KeySelector function for the first join
  DataSet. 
- where(int...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
- 
Continues a Join transformation. 
- where(String...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
- 
Continues a Join transformation. 
- where(KeySelector<I1, K>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
- 
Continues a Join transformation and defines a  KeySelector function for the first join
  DataSet. 
- with(CoGroupFunction<I1, I2, R>) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
- 
Finalizes a CoGroup transformation by applying a RichCoGroupFunctionto groups of elements
 with identical keys.
 
- with(CrossFunction<I1, I2, R>) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.DefaultCross
- 
Finalizes a Cross transformation by applying a CrossFunctionto each pair of
 crossed elements.
 
- with(JoinFunction<I1, I2, R>) - 接口 中的方法org.apache.flink.api.java.operators.join.JoinFunctionAssigner
-  
- with(FlatJoinFunction<I1, I2, R>) - 接口 中的方法org.apache.flink.api.java.operators.join.JoinFunctionAssigner
-  
- with(FlatJoinFunction<I1, I2, R>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
- 
Finalizes a Join transformation by applying a RichFlatJoinFunctionto each pair of joined
 elements.
 
- with(JoinFunction<I1, I2, R>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
-  
- withBroadcastSet(DataSet<?>, String) - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
-  
- withBroadcastSet(DataSet<?>, String) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
-  
- withBroadcastSet(DataSet<?>, String) - 接口 中的方法org.apache.flink.api.java.operators.UdfOperator
- 
Adds a certain data set as a broadcast set to this operator. 
- withForwardedFields(String...) - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
- 
Adds semantic information about forwarded fields of the user-defined function. 
- withForwardedFieldsFirst(String...) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-  
- withForwardedFieldsFirst(String...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-  
- withForwardedFieldsFirst(String...) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
- 
Adds semantic information about forwarded fields of the first input of the user-defined
 function. 
- withForwardedFieldsSecond(String...) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-  
- withForwardedFieldsSecond(String...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-  
- withForwardedFieldsSecond(String...) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
- 
Adds semantic information about forwarded fields of the second input of the user-defined
 function. 
- withOrders(Order...) - 类 中的方法org.apache.flink.api.java.operators.PartitionOperator
- 
Sets the order of keys for range partitioning. 
- withParameters(Configuration) - 类 中的方法org.apache.flink.api.java.operators.DataSink
- 
Pass a configuration to the OutputFormat. 
- withParameters(Configuration) - 类 中的方法org.apache.flink.api.java.operators.DataSource
- 
Pass a configuration to the InputFormat. 
- withParameters(Configuration) - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
-  
- withParameters(Configuration) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
-  
- withParameters(Configuration) - 接口 中的方法org.apache.flink.api.java.operators.UdfOperator
- 
Sets the configuration parameters for the UDF. 
- withPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
- 
Sets a custom partitioner for the CoGroup operation. 
- withPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator
- 
Sets a custom partitioner for the CoGroup operation. 
- withPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator
- 
Sets a custom partitioner for this join. 
- withPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
- 
Uses a custom partitioner for the grouping. 
- withPartitioner(Partitioner<?>) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
- 
Uses a custom partitioner for the grouping. 
- wrappedFunction - 类 中的变量org.apache.flink.api.java.operators.translation.WrappingFunction
-  
- WrappingFlatJoinFunction(JoinFunction<IN1, IN2, OUT>) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.DefaultJoin.WrappingFlatJoinFunction
-  
- WrappingFunction<T extends org.apache.flink.api.common.functions.Function> - org.apache.flink.api.java.operators.translation中的类
- 
Wrapper around Function.
 
- WrappingFunction(T) - 类 的构造器org.apache.flink.api.java.operators.translation.WrappingFunction
-  
- write(FileOutputFormat<T>, String) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a DataSet using a FileOutputFormatto a specified location.
 
- write(FileOutputFormat<T>, String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a DataSet using a FileOutputFormatto a specified location.
 
- writeAsCsv(String) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a TupleDataSet as CSV file(s) to the specified location.
 
- writeAsCsv(String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a TupleDataSet as CSV file(s) to the specified location.
 
- writeAsCsv(String, String, String) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a TupleDataSet as CSV file(s) to the specified location with the specified
 field and line delimiters.
 
- writeAsCsv(String, String, String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a TupleDataSet as CSV file(s) to the specified location with the specified
 field and line delimiters.
 
- writeAsFormattedText(String, TextOutputFormat.TextFormatter<T>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a DataSet as text file(s) to the specified location. 
- writeAsFormattedText(String, FileSystem.WriteMode, TextOutputFormat.TextFormatter<T>) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a DataSet as text file(s) to the specified location. 
- writeAsText(String) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a DataSet as text file(s) to the specified location. 
- writeAsText(String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.api.java.DataSet
- 
Writes a DataSet as text file(s) to the specified location. 
- writeRecord(T) - 类 中的方法org.apache.flink.api.java.io.BlockingShuffleOutputFormat
-  
- writeRecord(T) - 类 中的方法org.apache.flink.api.java.io.CsvOutputFormat
-  
- writeRecord(T) - 类 中的方法org.apache.flink.api.java.io.DiscardingOutputFormat
-  
- writeRecord(T) - 类 中的方法org.apache.flink.api.java.io.LocalCollectionOutputFormat
-  
- writeRecord(T) - 类 中的方法org.apache.flink.api.java.io.PrintingOutputFormat
-  
- writeRecord(T) - 类 中的方法org.apache.flink.api.java.io.TextOutputFormat
-  
- writeRecord(T) - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
-  
- writeRecord(T) - 类 中的方法org.apache.flink.api.java.Utils.CollectHelper
-  
- writeRecord(T) - 类 中的方法org.apache.flink.api.java.Utils.CountHelper
-