跳过导航链接
A B C D E F G H I J K L M N O P Q R S T U V W Z 

A

AbstractParameterTool - org.apache.flink.api.java.utils中的类
This class provides common utility methods of ParameterTool and MultipleParameterTool.
AbstractParameterTool() - 类 的构造器org.apache.flink.api.java.utils.AbstractParameterTool
 
add(double, double) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding a value and a correction term.
add(double) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding a value without a correction term.
add(CompensatedSum) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding two sums, and updating the correction term for reducing numeric errors.
add(Utils.ChecksumHashCode) - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
 
addDefaultKryoSerializer(Class<?>, T) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Adds a new Kryo default serializer to the Runtime.
addSourceFieldOffset(SingleInputSemanticProperties, int, int) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
Creates SemanticProperties by adding an offset to each input field index of the given SemanticProperties.
addSourceFieldOffsets(DualInputSemanticProperties, int, int, int, int) - 类 中的静态方法org.apache.flink.api.java.functions.SemanticPropUtil
Creates SemanticProperties by adding offsets to each input field index of the given SemanticProperties.
addToDefaults(String, String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
 
aggregate(T) - 类 中的方法org.apache.flink.api.java.aggregation.AggregationFunction
 
aggregate(Aggregations, int) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Applies an Aggregate transformation on a non-grouped Tuple DataSet.
aggregate(Aggregations, int) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
已过时。
Applies an Aggregate transformation on a grouped Tuple DataSet.
aggregate(T) - 接口 中的方法org.apache.flink.api.java.summarize.aggregation.Aggregator
Add a value to the current aggregation.
aggregate(Boolean) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
aggregate(Double) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
aggregate(Double) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
aggregate(Double) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
aggregate(Float) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
aggregate(Float) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
aggregate(Float) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
aggregate(Integer) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
aggregate(Integer) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
aggregate(Integer) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
aggregate(Long) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
aggregate(Long) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
aggregate(T) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
Add a value to the current aggregation.
aggregate(Object) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
aggregate(Short) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
aggregate(Short) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
aggregate(Short) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
aggregate(String) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
aggregate(Tuple) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
aggregate(VT) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
AggregateOperator<IN> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
AggregateOperator(DataSet<IN>, Aggregations, int, String) - 类 的构造器org.apache.flink.api.java.operators.AggregateOperator
已过时。
Non grouped aggregation.
AggregateOperator(Grouping<IN>, Aggregations, int, String) - 类 的构造器org.apache.flink.api.java.operators.AggregateOperator
已过时。
Grouped aggregation.
AggregationFunction<T> - org.apache.flink.api.java.aggregation中的类
 
AggregationFunction() - 类 的构造器org.apache.flink.api.java.aggregation.AggregationFunction
 
AggregationFunctionFactory - org.apache.flink.api.java.aggregation中的接口
Interface of factory for creating AggregationFunction.
Aggregations - org.apache.flink.api.java.aggregation中的枚举
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
Aggregator<T,R> - org.apache.flink.api.java.summarize.aggregation中的接口
Generic interface for aggregation.
and(Aggregations, int) - 类 中的方法org.apache.flink.api.java.operators.AggregateOperator
已过时。
 
andMax(int) - 类 中的方法org.apache.flink.api.java.operators.AggregateOperator
已过时。
 
andMin(int) - 类 中的方法org.apache.flink.api.java.operators.AggregateOperator
已过时。
 
andSum(int) - 类 中的方法org.apache.flink.api.java.operators.AggregateOperator
已过时。
 
appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K>) - 类 中的静态方法org.apache.flink.api.java.operators.KeyFunctions
 
appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K1>, Keys.SelectorFunctionKeys<T, K2>) - 类 中的静态方法org.apache.flink.api.java.operators.KeyFunctions
 
appendKeyRemover(Operator<Tuple2<K, T>>, Keys.SelectorFunctionKeys<T, K>) - 类 中的静态方法org.apache.flink.api.java.operators.KeyFunctions
 
areExplicitEnvironmentsAllowed() - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment or a RemoteEnvironment.

B

BernoulliSampler<T> - org.apache.flink.api.java.sampling中的类
A sampler implementation built upon a Bernoulli trail.
BernoulliSampler(double) - 类 的构造器org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and default random number generator.
BernoulliSampler(double, long) - 类 的构造器org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator seed.
BernoulliSampler(double, Random) - 类 的构造器org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator.
BlockingShuffleOutputFormat<T> - org.apache.flink.api.java.io中的类
This is the inner OutputFormat used for specify the BLOCKING_PERSISTENT result partition type of coming edge.
BooleanColumnSummary - org.apache.flink.api.java.summarize中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
BooleanColumnSummary(long, long, long) - 类 的构造器org.apache.flink.api.java.summarize.BooleanColumnSummary
已过时。
 
BooleanSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator for Boolean type.
BooleanSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
BooleanValueSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
 
BulkIterationResultSet<T> - org.apache.flink.api.java.operators中的类
Resulting DataSet of bulk iterations.

C

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
已过时。
This method will be removed at some point.
ChecksumHashCodeHelper(String) - 类 的构造器org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
An intermediate CoGroupOperator without CoGroupFunction applied yet.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
CollectionEnvironment() - 类 的构造器org.apache.flink.api.java.CollectionEnvironment
已过时。
 
CollectionInputFormat<T> - org.apache.flink.api.java.io中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
CollectionInputFormat(Collection<T>, TypeSerializer<T>) - 类 的构造器org.apache.flink.api.java.io.CollectionInputFormat
已过时。
 
ColumnSummary - org.apache.flink.api.java.summarize中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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 CombineFunction and GroupReduceFunction interfaces and makes it look like a function that implements GroupCombineFunction and GroupReduceFunction to 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 ReadableConfig such 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
已过时。
Creates a CollectionEnvironment that uses Java Collections underneath.
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
已过时。
Creates a LocalEnvironment.
createLocalEnvironment(int) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Creates a LocalEnvironment.
createLocalEnvironment(Configuration) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Creates a LocalEnvironment.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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 Tuples into result Tuples.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的接口
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.

D

data - 类 中的变量org.apache.flink.api.java.utils.MultipleParameterTool
 
data - 类 中的变量org.apache.flink.api.java.utils.ParameterTool
 
DataSet<T> - org.apache.flink.api.java中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
DataSet(ExecutionEnvironment, TypeInformation<T>) - 类 的构造器org.apache.flink.api.java.DataSet
已过时。
 
DataSetUtils - org.apache.flink.api.java.utils中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
DataSink<T> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
DataSink(DataSet<T>, OutputFormat<T>, TypeInformation<T>) - 类 的构造器org.apache.flink.api.java.operators.DataSink
已过时。
 
DataSource<OUT> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
DataSource(ExecutionEnvironment, InputFormat<OUT, ?>, TypeInformation<OUT>, String) - 类 的构造器org.apache.flink.api.java.operators.DataSource
已过时。
Creates a new data source.
DEFAULT_FIELD_DELIMITER - 类 中的静态变量org.apache.flink.api.java.io.CsvInputFormat
 
DEFAULT_FIELD_DELIMITER - 类 中的静态变量org.apache.flink.api.java.io.CsvOutputFormat
已过时。
 
DEFAULT_LINE_DELIMITER - 类 中的静态变量org.apache.flink.api.java.io.CsvInputFormat
 
DEFAULT_LINE_DELIMITER - 类 中的静态变量org.apache.flink.api.java.io.CsvOutputFormat
已过时。
 
DEFAULT_UNDEFINED - 类 中的静态变量org.apache.flink.api.java.utils.AbstractParameterTool
 
DefaultCross(DataSet<I1>, DataSet<I2>, CrossOperatorBase.CrossHint, String) - 类 的构造器org.apache.flink.api.java.operators.CrossOperator.DefaultCross
已过时。
 
defaultData - 类 中的变量org.apache.flink.api.java.utils.AbstractParameterTool
 
DefaultJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, String, JoinType) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
已过时。
 
defaultName - 类 中的变量org.apache.flink.api.java.operators.FilterOperator
已过时。
 
defaultName - 类 中的变量org.apache.flink.api.java.operators.FlatMapOperator
已过时。
 
defaultName - 类 中的变量org.apache.flink.api.java.operators.MapOperator
已过时。
 
defaultName - 类 中的变量org.apache.flink.api.java.operators.MapPartitionOperator
已过时。
 
delta() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.CompensatedSum
The correction term.
DeltaIteration<ST,WT> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
DeltaIteration(ExecutionEnvironment, TypeInformation<ST>, DataSet<ST>, DataSet<WT>, Keys<ST>, int) - 类 的构造器org.apache.flink.api.java.operators.DeltaIteration
已过时。
 
DeltaIteration.SolutionSetPlaceHolder<ST> - org.apache.flink.api.java.operators中的类
已过时。
A DataSet that acts as a placeholder for the solution set during the iteration.
DeltaIteration.WorksetPlaceHolder<WT> - org.apache.flink.api.java.operators中的类
已过时。
A DataSet that acts as a placeholder for the workset during the iteration.
DeltaIterationResultSet<ST,WT> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
deserialize(T, DataInputView) - 类 中的方法org.apache.flink.api.java.io.TypeSerializerInputFormat
已过时。
 
DiscardingOutputFormat<T> - org.apache.flink.api.java.io中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
DiscardingOutputFormat() - 类 的构造器org.apache.flink.api.java.io.DiscardingOutputFormat
已过时。
 
distinct(KeySelector<T, K>) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Returns a distinct set of a DataSet using a KeySelector function.
distinct(int...) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Returns a distinct set of a Tuple DataSet using field position keys.
distinct(String...) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Returns a distinct set of a DataSet using expression keys.
distinct() - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Returns a distinct set of a DataSet.
DistinctOperator<T> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
DistinctOperator(DataSet<T>, Keys<T>, String) - 类 的构造器org.apache.flink.api.java.operators.DistinctOperator
已过时。
 
DistributedRandomSampler<T> - org.apache.flink.api.java.sampling中的类
For sampling with fraction, the sample algorithms are natively distributed, while it's not true for fixed size sample algorithms.
DistributedRandomSampler(int) - 类 的构造器org.apache.flink.api.java.sampling.DistributedRandomSampler
 
DoubleSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator that can handle Double types.
DoubleSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
DoubleSummaryAggregator.MaxDoubleAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator for max operation.
DoubleSummaryAggregator.MinDoubleAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator for min operation.
DoubleSummaryAggregator.SumDoubleAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator for sum operation.
DoubleValueSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
 

E

emptyIntermediateIterable - 类 中的变量org.apache.flink.api.java.sampling.DistributedRandomSampler
 
emptyIterable - 类 中的变量org.apache.flink.api.java.sampling.RandomSampler
 
EPSILON - 类 中的静态变量org.apache.flink.api.java.sampling.RandomSampler
 
equals(Object) - 类 中的方法org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
已过时。
 
equals(Object) - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
 
equals(Object) - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
 
equals(Object) - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
 
equalTo(int...) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
已过时。
Continues a CoGroup transformation and defines the Tuple fields of the second co-grouped DataSet that should be used as grouping keys.
equalTo(String...) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
已过时。
Continues a CoGroup transformation and defines the fields of the second co-grouped DataSet that should be used as grouping keys.
equalTo(KeySelector<I2, K>) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
已过时。
Continues a CoGroup transformation and defines a KeySelector function for the second co-grouped DataSet.
equalTo(int...) - 类 中的方法org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
已过时。
Continues a Join transformation and defines the Tuple fields of the second join DataSet that should be used as join keys.
equalTo(String...) - 类 中的方法org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
已过时。
Continues a Join transformation and defines the fields of the second join DataSet that should be used as join keys.
equalTo(KeySelector<I2, K>) - 类 中的方法org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
已过时。
Continues a Join transformation and defines a KeySelector function for the second join DataSet.
equalTo(int...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
已过时。
Continues a Join transformation and defines the Tuple fields of the second join DataSet that should be used as join keys.
equalTo(String...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
已过时。
Continues a Join transformation and defines the fields of the second join DataSet that should be used as join keys.
equalTo(KeySelector<I2, K>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
已过时。
Continues a Join transformation and defines a KeySelector function for the second join DataSet.
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.EquiJoin
已过时。
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, JoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.EquiJoin
已过时。
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String, JoinType) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.EquiJoin
已过时。
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, JoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String, JoinType) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.EquiJoin
已过时。
 
execute(String) - 类 中的方法org.apache.flink.api.java.CollectionEnvironment
已过时。
 
execute() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Triggers the program execution.
execute(String) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Triggers the program execution.
executeAsync() - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Triggers the program execution asynchronously.
executeAsync(String) - 类 中的方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Triggers the program execution asynchronously.
ExecutionEnvironment - org.apache.flink.api.java中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
ExecutionEnvironment(Configuration) - 类 的构造器org.apache.flink.api.java.ExecutionEnvironment
已过时。
Creates a new ExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
ExecutionEnvironment(Configuration, ClassLoader) - 类 的构造器org.apache.flink.api.java.ExecutionEnvironment
已过时。
Creates a new ExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
ExecutionEnvironment(PipelineExecutorServiceLoader, Configuration, ClassLoader) - 类 的构造器org.apache.flink.api.java.ExecutionEnvironment
已过时。
Creates a new ExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
ExecutionEnvironment() - 类 的构造器org.apache.flink.api.java.ExecutionEnvironment
已过时。
Creates a new Execution Environment.
ExecutionEnvironmentFactory - org.apache.flink.api.java中的接口
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
ExecutionPlanUtil - org.apache.flink.api.java中的类
A utility for extracting an execution plan (as JSON) from a Plan.
ExecutionPlanUtil() - 类 的构造器org.apache.flink.api.java.ExecutionPlanUtil
 
ExecutionPlanUtil.ExecutionPlanJSONGenerator - org.apache.flink.api.java中的接口
Internal interface for the JSON plan generator that has to reside in the optimizer package.
extractSemanticAnnotations(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
已过时。
 
extractSemanticAnnotationsFromUdf(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.ProjectCross
已过时。
 
extractSemanticAnnotationsFromUdf(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.EquiJoin
已过时。
 
extractSemanticAnnotationsFromUdf(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
已过时。
 
extractSemanticAnnotationsFromUdf(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
已过时。
 

F

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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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
已过时。
Delegates calls to the FlatMapIterator.flatMap(Object) method.
flatMap(T, Collector<T>) - 类 中的方法org.apache.flink.api.java.operators.translation.PlanFilterOperator.FlatMapFilter
 
FlatMapIterator<IN,OUT> - org.apache.flink.api.java.functions中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
FlatMapIterator() - 类 的构造器org.apache.flink.api.java.functions.FlatMapIterator
已过时。
 
FlatMapOperator<IN,OUT> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
Mapper that converts values to strings using a TextOutputFormat.TextFormatter.
FormattingMapper(TextOutputFormat.TextFormatter<T>) - 类 的构造器org.apache.flink.api.java.functions.FormattingMapper
 
fromArgs(String[]) - 类 中的静态方法org.apache.flink.api.java.utils.MultipleParameterTool
Returns MultipleParameterTool for the given arguments.
fromArgs(String[]) - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given arguments.
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
Returns ParameterTool for the given map.
fromMultiMap(Map<String, Collection<String>>) - 类 中的静态方法org.apache.flink.api.java.utils.MultipleParameterTool
Returns MultipleParameterTool for the given multi map.
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
Returns ParameterTool for the given Properties file.
fromPropertiesFile(File) - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given Properties file.
fromPropertiesFile(InputStream) - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given InputStream from Properties file.
fromSystemProperties() - 类 中的静态方法org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool from the system properties.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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.

G

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.
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
 
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
Returns a Configuration object from this 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
已过时。
Gets the default parallelism that will be used for the local execution environment created by ExecutionEnvironment.createLocalEnvironment().
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
已过时。
Returns the ExecutionEnvironment in which this DataSet is registered.
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
已过时。
 
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 JobExecutionResult of 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.
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.
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
已过时。
This method will be replaced by ExecutionEnvironment.getRestartStrategy(). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of execution retries.
getNumberOfParameters() - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
Returns number of parameters in AbstractParameterTool.
getNumberOfParameters() - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
Returns number of parameters in ParameterTool.
getNumberOfParameters() - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
Returns number of parameters in 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 RichFunction.open(OpenContext).
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
Returns a Properties object from this 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
已过时。
Returns the SplitDataProperties for the InputSplits of this DataSource for configurations.
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 TypeInformation for the type of this DataSet.
getType() - 类 中的方法org.apache.flink.api.java.operators.DataSink
已过时。
 
getUnrequestedParameters() - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
Returns the set of parameter names which have not been requested with AbstractParameterTool.has(String) or one of the get methods.
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 Tuple DataSet 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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
Grouping(DataSet<T>, Keys<T>) - 类 的构造器org.apache.flink.api.java.operators.Grouping
已过时。
 
GroupReduceIterator<IN,OUT> - org.apache.flink.api.java.functions中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
GroupReduceIterator() - 类 的构造器org.apache.flink.api.java.functions.GroupReduceIterator
已过时。
 
GroupReduceOperator<IN,OUT> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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.

H

has(String) - 类 中的方法org.apache.flink.api.java.utils.AbstractParameterTool
Check if value is set.
has(String) - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
Check if value is set.
has(String) - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
Check if value is set.
hashCode() - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
 
hashCode() - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
 
hashCode() - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
 
hasNext() - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
hasNext() - 类 中的方法org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 

I

IdPartitioner - org.apache.flink.api.java.functions中的类
Partitioner that partitions by id.
IdPartitioner() - 类 的构造器org.apache.flink.api.java.functions.IdPartitioner
 
ignoreComments(String) - 类 中的方法org.apache.flink.api.java.io.CsvReader
已过时。
Configures the string that starts comments.
ignoreFirstLine() - 类 中的方法org.apache.flink.api.java.io.CsvReader
已过时。
Sets the CSV reader to ignore the first line.
ignoreInvalidLines - 类 中的变量org.apache.flink.api.java.io.CsvReader
已过时。
 
ignoreInvalidLines() - 类 中的方法org.apache.flink.api.java.io.CsvReader
已过时。
Sets the CSV reader to ignore any invalid lines.
includedMask - 类 中的变量org.apache.flink.api.java.io.CsvReader
已过时。
 
includeFields(boolean...) - 类 中的方法org.apache.flink.api.java.io.CsvReader
已过时。
Configures which fields of the CSV file should be included and which should be skipped.
includeFields(String) - 类 中的方法org.apache.flink.api.java.io.CsvReader
已过时。
Configures which fields of the CSV file should be included and which should be skipped.
includeFields(long) - 类 中的方法org.apache.flink.api.java.io.CsvReader
已过时。
Configures which fields of the CSV file should be included and which should be skipped.
initializeAggregate() - 类 中的方法org.apache.flink.api.java.aggregation.AggregationFunction
 
initializeContextEnvironment(ExecutionEnvironmentFactory) - 类 中的静态方法org.apache.flink.api.java.ExecutionEnvironment
已过时。
Sets a context environment factory, that creates the context environment for running programs with pre-configured environments.
initializeSplit(FileInputSplit, Long) - 类 中的方法org.apache.flink.api.java.io.CsvInputFormat
 
initializeSplit(FileInputSplit, Long) - 类 中的方法org.apache.flink.api.java.io.PojoCsvInputFormat
 
initializeSplit(FileInputSplit, Long) - 类 中的方法org.apache.flink.api.java.io.PrimitiveInputFormat
已过时。
 
initMax() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
initMax() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
initMax() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
initMax() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
initMax() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
initMax() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
initMin() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
initMin() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
initMin() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
initMin() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
initMin() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
initMin() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
initPrimitiveAggregator() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
 
initPrimitiveAggregator() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
 
initPrimitiveAggregator() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
 
initPrimitiveAggregator() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
Initialize an aggregator that can be used for the underlying primitive in the Value type.
initPrimitiveAggregator() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
 
initPrimitiveAggregator() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
 
initPrimitiveAggregator() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
 
initPrimitiveAggregator() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
 
initSum() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
initSum() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
initSum() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
initSum() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
initSum() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
initSum() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
input1 - 类 中的变量org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
已过时。
 
input2 - 类 中的变量org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
已过时。
 
inputDataSet - 类 中的变量org.apache.flink.api.java.operators.Grouping
已过时。
 
IntegerSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator that can handle Integer types.
IntegerSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
IntegerSummaryAggregator.MaxIntegerAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator for max operation.
IntegerSummaryAggregator.MinIntegerAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator for min operation.
IntegerSummaryAggregator.SumIntegerAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator for sum operation.
IntegerValueSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
 
IntermediateSampleData<T> - org.apache.flink.api.java.sampling中的类
The data structure which is transferred between partitions and the coordinator for distributed random sampling.
IntermediateSampleData(double, T) - 类 的构造器org.apache.flink.api.java.sampling.IntermediateSampleData
 
isCombinable() - 类 中的方法org.apache.flink.api.java.operators.GroupReduceOperator
已过时。
 
isInfinite(Double) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
isInfinite(Float) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
isInfinite(Integer) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
isInfinite(Long) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
isInfinite(T) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
isInfinite(Short) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
isNan(Double) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
isNan(Float) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
isNan(Integer) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
isNan(Long) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
isNan(T) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
isNan(Short) - 类 中的方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
isOuter() - 枚举 中的方法org.apache.flink.api.java.operators.join.JoinType
已过时。
 
isSkipInvalidLines() - 类 中的方法org.apache.flink.api.java.io.TextValueInputFormat
已过时。
 
isSolutionSetUnManaged() - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
已过时。
gets whether the solution set is in managed or unmanaged memory.
iterate(int) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Initiates an iterative part of the program that executes multiple times and feeds back data sets.
iterateDelta(DataSet<R>, int, int...) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Initiates a delta iteration.
IterativeDataSet<T> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
IterativeDataSet(ExecutionEnvironment, TypeInformation<T>, DataSet<T>, int) - 类 的构造器org.apache.flink.api.java.operators.IterativeDataSet
已过时。
 
iterator() - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
iterator() - 类 中的方法org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
IteratorInputFormat<T> - org.apache.flink.api.java.io中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
IteratorInputFormat(Iterator<T>) - 类 的构造器org.apache.flink.api.java.io.IteratorInputFormat
已过时。
 

J

join(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Initiates a Join transformation.
join(DataSet<R>, JoinOperatorBase.JoinHint) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Initiates a Join transformation.
join(IN1, IN2, Collector<OUT>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.DefaultJoin.WrappingFlatJoinFunction
已过时。
 
join(Tuple2<K, I1>, I2, Collector<OUT>) - 类 中的方法org.apache.flink.api.java.operators.translation.TupleLeftUnwrappingJoiner
 
join(I1, Tuple2<K, I2>, Collector<OUT>) - 类 中的方法org.apache.flink.api.java.operators.translation.TupleRightUnwrappingJoiner
 
join(Tuple2<K, I1>, Tuple2<K, I2>, Collector<OUT>) - 类 中的方法org.apache.flink.api.java.operators.translation.TupleUnwrappingJoiner
 
JoinFunctionAssigner<I1,I2> - org.apache.flink.api.java.operators.join中的接口
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
joinHint - 类 中的变量org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
已过时。
 
JoinOperator<I1,I2,OUT> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
JoinOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, JoinType) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator
已过时。
 
JoinOperator.DefaultJoin<I1,I2> - org.apache.flink.api.java.operators中的类
已过时。
A Join transformation that wraps pairs of joining elements into Tuple2.
JoinOperator.DefaultJoin.WrappingFlatJoinFunction<IN1,IN2,OUT> - org.apache.flink.api.java.operators中的类
已过时。
Wrapper around JoinFunction.
JoinOperator.EquiJoin<I1,I2,OUT> - org.apache.flink.api.java.operators中的类
已过时。
A Join transformation that applies a JoinFunction on each pair of joining elements.
JoinOperator.JoinOperatorSets<I1,I2> - org.apache.flink.api.java.operators中的类
已过时。
Intermediate step of a Join transformation.
JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate - org.apache.flink.api.java.operators中的类
已过时。
Intermediate step of a Join transformation.
JoinOperator.ProjectJoin<I1,I2,OUT extends org.apache.flink.api.java.tuple.Tuple> - org.apache.flink.api.java.operators中的类
已过时。
A Join transformation that projects joining elements or fields of joining Tuples into result Tuples.
JoinOperatorSets(DataSet<I1>, DataSet<I2>) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
已过时。
 
JoinOperatorSets(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint) - 类 的构造器org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
已过时。
 
JoinOperatorSetsBase<I1,I2> - org.apache.flink.api.java.operators.join中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>) - 类 的构造器org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
已过时。
 
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint) - 类 的构造器org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
已过时。
 
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint, JoinType) - 类 的构造器org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
已过时。
 
JoinOperatorSetsBase.JoinOperatorSetsPredicateBase - org.apache.flink.api.java.operators.join中的类
已过时。
Intermediate step of a Join transformation.
JoinOperatorSetsPredicateBase(Keys<I1>) - 类 的构造器org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
已过时。
 
joinType - 类 中的变量org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
已过时。
 
JoinType - org.apache.flink.api.java.operators.join中的枚举
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
joinType - 类 中的变量org.apache.flink.api.java.operators.JoinOperator
已过时。
 
joinWithHuge(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Initiates a Join transformation.
joinWithTiny(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Initiates a Join transformation.

K

KeyExtractingMapper<T,K> - org.apache.flink.api.java.operators.translation中的类
Mapper that extracts keys.
KeyExtractingMapper(KeySelector<T, K>) - 类 的构造器org.apache.flink.api.java.operators.translation.KeyExtractingMapper
 
KeyFunctions - org.apache.flink.api.java.operators中的类
This class holds static utilities to append functions that extract and prune keys.
KeyFunctions() - 类 的构造器org.apache.flink.api.java.operators.KeyFunctions
 
KeyRemovingMapper<T,K> - org.apache.flink.api.java.operators.translation中的类
Mapper that removes keys.
KeyRemovingMapper() - 类 的构造器org.apache.flink.api.java.operators.translation.KeyRemovingMapper
 
keys - 类 中的变量org.apache.flink.api.java.operators.Grouping
已过时。
 
keys1 - 类 中的变量org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
已过时。
 
keys1 - 类 中的变量org.apache.flink.api.java.operators.JoinOperator
已过时。
 
keys2 - 类 中的变量org.apache.flink.api.java.operators.JoinOperator
已过时。
 

L

lastJobExecutionResult - 类 中的变量org.apache.flink.api.java.ExecutionEnvironment
已过时。
Result from the latest execution, to make it retrievable when using eager execution methods.
leftOuterJoin(DataSet<R>) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Initiates a Left Outer Join transformation.
leftOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Initiates a Left Outer Join transformation.
lineDelimiter - 类 中的变量org.apache.flink.api.java.io.CsvReader
已过时。
 
lineDelimiter(String) - 类 中的方法org.apache.flink.api.java.io.CsvReader
已过时。
Configures the delimiter that separates the lines/rows.
LocalCollectionOutputFormat<T> - org.apache.flink.api.java.io中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
LocalCollectionOutputFormat(Collection<T>) - 类 的构造器org.apache.flink.api.java.io.LocalCollectionOutputFormat
已过时。
 
LocalEnvironment - org.apache.flink.api.java中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
LocalEnvironment() - 类 的构造器org.apache.flink.api.java.LocalEnvironment
已过时。
Creates a new local environment.
LocalEnvironment(Configuration) - 类 的构造器org.apache.flink.api.java.LocalEnvironment
已过时。
Creates a new local environment that configures its local executor with the given configuration.
LOG - 类 中的静态变量org.apache.flink.api.java.ExecutionEnvironment
已过时。
The logger used by the environment and its subclasses.
LongSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator that can handle Long types.
LongSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
LongSummaryAggregator.MaxLongAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator for max operation.
LongSummaryAggregator.MinLongAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator for min operation.
LongValueSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
 

M

map(MapFunction<T, R>) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Applies a Map transformation on this DataSet.
map(T) - 类 中的方法org.apache.flink.api.java.functions.FormattingMapper
 
map(T) - 类 中的方法org.apache.flink.api.java.operators.translation.KeyExtractingMapper
 
map(Tuple2<K, T>) - 类 中的方法org.apache.flink.api.java.operators.translation.KeyRemovingMapper
 
map(T) - 类 中的方法org.apache.flink.api.java.operators.translation.TwoKeyExtractingMapper
 
MapOperator<IN,OUT> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
MapOperator(DataSet<IN>, TypeInformation<OUT>, MapFunction<IN, OUT>, String) - 类 的构造器org.apache.flink.api.java.operators.MapOperator
已过时。
 
mapPartition(MapPartitionFunction<T, R>) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Applies a Map-style operation to the entire partition of the data.
mapPartition(Iterable<T>, Collector<IntermediateSampleData<T>>) - 类 中的方法org.apache.flink.api.java.functions.SampleInPartition
 
mapPartition(Iterable<T>, Collector<T>) - 类 中的方法org.apache.flink.api.java.functions.SampleWithFraction
 
MapPartitionOperator<IN,OUT> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
MapPartitionOperator(DataSet<IN>, TypeInformation<OUT>, MapPartitionFunction<IN, OUT>, String) - 类 的构造器org.apache.flink.api.java.operators.MapPartitionOperator
已过时。
 
max(int) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Syntactic sugar for DataSet.aggregate(Aggregations, int) using Aggregations.MAX as the aggregation function.
max(int) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
已过时。
Syntactic sugar for aggregate (MAX, field).
max(Short, Short) - 类 中的静态方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
Like Math.max() except for shorts.
MaxAggregationFunction<T extends Comparable<T>> - org.apache.flink.api.java.aggregation中的类
Implementation of AggregationFunction for max operation.
MaxAggregationFunction() - 类 的构造器org.apache.flink.api.java.aggregation.MaxAggregationFunction
 
MaxAggregationFunction.MaxAggregationFunctionFactory - org.apache.flink.api.java.aggregation中的类
MaxAggregationFunctionFactory() - 类 的构造器org.apache.flink.api.java.aggregation.MaxAggregationFunction.MaxAggregationFunctionFactory
 
maxBy(int...) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Selects an element with maximum value.
maxBy(int...) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
已过时。
Applies a special case of a reduce transformation (maxBy) on a grouped DataSet.
MaxDoubleAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
MaxFloatAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
MaxIntegerAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
MaxLongAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
MaxShortAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
merge(Accumulator<Utils.ChecksumHashCode, Utils.ChecksumHashCode>) - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCode
 
mergeWith(MultipleParameterTool) - 类 中的方法org.apache.flink.api.java.utils.MultipleParameterTool
mergeWith(ParameterTool) - 类 中的方法org.apache.flink.api.java.utils.ParameterTool
Merges two ParameterTool.
min(int) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Syntactic sugar for DataSet.aggregate(Aggregations, int) using Aggregations.MIN as the aggregation function.
min(int) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
已过时。
Syntactic sugar for aggregate (MIN, field).
min(Short, Short) - 类 中的静态方法org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
Like Math.min() except for shorts.
MinAggregationFunction<T extends Comparable<T>> - org.apache.flink.api.java.aggregation中的类
Implementations of AggregationFunction for min operation.
MinAggregationFunction() - 类 的构造器org.apache.flink.api.java.aggregation.MinAggregationFunction
 
MinAggregationFunction.MinAggregationFunctionFactory - org.apache.flink.api.java.aggregation中的类
MinAggregationFunctionFactory() - 类 的构造器org.apache.flink.api.java.aggregation.MinAggregationFunction.MinAggregationFunctionFactory
 
minBy(int...) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Selects an element with minimum value.
minBy(int...) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
已过时。
Applies a special case of a reduce transformation (minBy) on a grouped DataSet.
MinDoubleAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
MinFloatAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
MinIntegerAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
MinLongAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
minResources - 类 中的变量org.apache.flink.api.java.operators.Operator
已过时。
 
MinShortAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
MultipleParameterTool - org.apache.flink.api.java.utils中的类
This class provides simple utility methods for reading and parsing program arguments from different sources.

N

name(String) - 类 中的方法org.apache.flink.api.java.operators.DataSink
已过时。
 
name(String) - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
已过时。
Sets the name for the iteration.
name - 类 中的变量org.apache.flink.api.java.operators.Operator
已过时。
 
name(String) - 类 中的方法org.apache.flink.api.java.operators.Operator
已过时。
Sets the name of this operator.
next() - 类 中的方法org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
next() - 类 中的方法org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
nextRecord(T) - 类 中的方法org.apache.flink.api.java.io.CollectionInputFormat
已过时。
 
nextRecord(OUT) - 类 中的方法org.apache.flink.api.java.io.CsvInputFormat
 
nextRecord(T) - 类 中的方法org.apache.flink.api.java.io.IteratorInputFormat
已过时。
 
nextRecord(T) - 类 中的方法org.apache.flink.api.java.io.ParallelIteratorInputFormat
已过时。
 
NO_VALUE_KEY - 类 中的静态变量org.apache.flink.api.java.utils.AbstractParameterTool
 
NoOpOperator<IN> - org.apache.flink.api.java.operators中的类
This operator will be ignored during translation.
NoOpOperator(DataSet<IN>, TypeInformation<IN>) - 类 的构造器org.apache.flink.api.java.operators.NoOpOperator
 
NumericColumnSummary<T> - org.apache.flink.api.java.summarize中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
NumericColumnSummary(long, long, long, long, T, T, T, Double, Double, Double) - 类 的构造器org.apache.flink.api.java.summarize.NumericColumnSummary
已过时。
 
NumericSummaryAggregator<T extends Number> - org.apache.flink.api.java.summarize.aggregation中的类
Generic aggregator for all numeric types creates a summary of a column of numbers.
NumericSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
numSamples - 类 中的变量org.apache.flink.api.java.sampling.DistributedRandomSampler
 

O

ObjectColumnSummary - org.apache.flink.api.java.summarize中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
ObjectColumnSummary(long, long) - 类 的构造器org.apache.flink.api.java.summarize.ObjectColumnSummary
已过时。
 
ObjectSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator that calculates statistics for Object values.
ObjectSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
open(int, int) - 类 中的方法org.apache.flink.api.java.io.BlockingShuffleOutputFormat
 
open(GenericInputSplit) - 类 中的方法org.apache.flink.api.java.io.CollectionInputFormat
已过时。
 
open(int, int) - 类 中的方法org.apache.flink.api.java.io.CsvOutputFormat
已过时。
 
open(int, int) - 类 中的方法org.apache.flink.api.java.io.DiscardingOutputFormat
已过时。
 
open(int, int) - 类 中的方法org.apache.flink.api.java.io.LocalCollectionOutputFormat
已过时。
 
open(GenericInputSplit) - 类 中的方法org.apache.flink.api.java.io.ParallelIteratorInputFormat
已过时。
 
open(int, int) - 类 中的方法org.apache.flink.api.java.io.PrintingOutputFormat
已过时。
 
open(int, int) - 类 中的方法org.apache.flink.api.java.io.TextOutputFormat
已过时。
 
open(OpenContext) - 类 中的方法org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
 
open(OpenContext) - 类 中的方法org.apache.flink.api.java.operators.translation.WrappingFunction
 
open(int, int) - 类 中的方法org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
open(int, int) - 类 中的方法org.apache.flink.api.java.Utils.CollectHelper
 
open(int, int) - 类 中的方法org.apache.flink.api.java.Utils.CountHelper
 
Operator<OUT,O extends Operator<OUT,O>> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
Operator(ExecutionEnvironment, TypeInformation<OUT>) - 类 的构造器org.apache.flink.api.java.operators.Operator
已过时。
 
OperatorTranslation - org.apache.flink.api.java.operators中的类
Used for translating data sets into corresponding operators.
OperatorTranslation() - 类 的构造器org.apache.flink.api.java.operators.OperatorTranslation
 
org.apache.flink.api.java - 程序包 org.apache.flink.api.java
 
org.apache.flink.api.java.aggregation - 程序包 org.apache.flink.api.java.aggregation
 
org.apache.flink.api.java.functions - 程序包 org.apache.flink.api.java.functions
 
org.apache.flink.api.java.io - 程序包 org.apache.flink.api.java.io
 
org.apache.flink.api.java.operators - 程序包 org.apache.flink.api.java.operators
 
org.apache.flink.api.java.operators.join - 程序包 org.apache.flink.api.java.operators.join
 
org.apache.flink.api.java.operators.translation - 程序包 org.apache.flink.api.java.operators.translation
 
org.apache.flink.api.java.sampling - 程序包 org.apache.flink.api.java.sampling
 
org.apache.flink.api.java.summarize - 程序包 org.apache.flink.api.java.summarize
 
org.apache.flink.api.java.summarize.aggregation - 程序包 org.apache.flink.api.java.summarize.aggregation
 
org.apache.flink.api.java.typeutils.runtime.kryo - 程序包 org.apache.flink.api.java.typeutils.runtime.kryo
 
org.apache.flink.api.java.utils - 程序包 org.apache.flink.api.java.utils
 
output(OutputFormat<T>) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Emits a DataSet using an OutputFormat.

P

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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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 Plan from a graph of Operators.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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 Tuple DataSet.
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 Tuple DataSet, 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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
ProjectOperator(DataSet<IN>, int[], TupleTypeInfo<OUT>) - 类 的构造器org.apache.flink.api.java.operators.ProjectOperator
已过时。
 
ProjectOperator.Projection<T> - org.apache.flink.api.java.operators中的类
已过时。
A projection of DataSet.
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 Tuple DataSet, 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 Tuple with the previously selected fields.
projectTuple1() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple10() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple10() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple11() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple11() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple12() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple12() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple13() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple13() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple14() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple14() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple15() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple15() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple16() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple16() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple17() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple17() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple18() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple18() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple19() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple19() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple2() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple2() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple20() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple20() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple21() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple21() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple22() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple22() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple23() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple23() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple24() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple24() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple25() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple25() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple3() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple3() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple4() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple4() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple5() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple5() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple6() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple6() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple7() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple7() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple8() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple8() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTuple9() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple9() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Projects a Tuple DataSet to the previously selected fields.
projectTupleX() - 类 中的方法org.apache.flink.api.java.operators.CrossOperator.CrossProjection
已过时。
Chooses a projectTupleX according to the length of CrossOperator.CrossProjection.fieldIndexes.
projectTupleX() - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator.Projection
已过时。
Chooses a projectTupleX according to the length of ProjectOperator.Projection.fieldIndexes.

Q

quoteCharacter - 类 中的变量org.apache.flink.api.java.io.CsvReader
已过时。
 

R

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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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 Aggregator for the iteration together with a ConvergenceCriterion.
registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - 类 中的方法org.apache.flink.api.java.operators.IterativeDataSet
已过时。
Registers an Aggregator for the iteration together with a ConvergenceCriterion.
registerAggregator(String, Aggregator<?>) - 类 中的方法org.apache.flink.api.java.operators.DeltaIteration
已过时。
Registers an Aggregator for the iteration.
registerAggregator(String, Aggregator<?>) - 类 中的方法org.apache.flink.api.java.operators.IterativeDataSet
已过时。
Registers an Aggregator for 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 JobListener in 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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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
 
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 CombineFunction and GroupReduceFunction interfaces and makes it look like a function that implements GroupCombineFunction and GroupReduceFunction to 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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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
已过时。
Runs a CustomUnaryOperation on the data set.

S

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
已过时。
Sets the default parallelism that will be used for the local execution environment created by ExecutionEnvironment.createLocalEnvironment().
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
已过时。
This method will be replaced by ExecutionEnvironment.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of execution retries.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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 Tuple elements within a group in the first input on the specified field in the specified Order.
sortFirstGroup(String, Order) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
已过时。
Sorts Pojo or Tuple elements within a group in the first input on the specified field in the specified Order.
sortGroup(int, Order) - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
已过时。
Sorts Tuple elements within a group on the specified field in the specified Order.
sortGroup(String, Order) - 类 中的方法org.apache.flink.api.java.operators.SortedGrouping
已过时。
Sorts Tuple or POJO elements within a group on the specified field in the specified Order.
sortGroup(int, Order) - 类 中的方法org.apache.flink.api.java.operators.UnsortedGrouping
已过时。
Sorts Tuple elements within a group on the specified field in the specified Order.
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 KeySelector in the specified Order.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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 Tuple elements within a group in the second input on the specified field in the specified Order.
sortSecondGroup(String, Order) - 类 中的方法org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
已过时。
Sorts Pojo or Tuple elements within a group in the second input on the specified field in the specified Order.
SourcePartitionerMarker(String) - 类 的构造器org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
已过时。
 
SplitDataProperties<T> - org.apache.flink.api.java.io中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
StringColumnSummary(long, long, long, Integer, Integer, Double) - 类 的构造器org.apache.flink.api.java.summarize.StringColumnSummary
已过时。
 
StringSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
Aggregator that calculates statistics for String values.
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
已过时。
 

T

TextInputFormat - org.apache.flink.api.java.io中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
TextInputFormat(Path) - 类 的构造器org.apache.flink.api.java.io.TextInputFormat
已过时。
 
TextOutputFormat<T> - org.apache.flink.api.java.io中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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
Return MultiMap of all the parameters processed by 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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
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
 
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
已过时。
Deprecated method only kept for compatibility.
types(Class<?>...) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
已过时。
Deprecated method only kept for compatibility.
types(Class<?>...) - 类 中的方法org.apache.flink.api.java.operators.ProjectOperator
已过时。
Deprecated method only kept for compatibility.
TypeSerializerInputFormat<T> - org.apache.flink.api.java.io中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
TypeSerializerInputFormat(TypeInformation<T>) - 类 的构造器org.apache.flink.api.java.io.TypeSerializerInputFormat
已过时。
 
TypeSerializerOutputFormat<T> - org.apache.flink.api.java.io中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
TypeSerializerOutputFormat() - 类 的构造器org.apache.flink.api.java.io.TypeSerializerOutputFormat
已过时。
 

U

UdfOperator<O extends UdfOperator<O>> - org.apache.flink.api.java.operators中的接口
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
udfWithForwardedFieldsAnnotation(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.SingleInputUdfOperator
已过时。
 
udfWithForwardedFieldsFirstAnnotation(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.EquiJoin
已过时。
 
udfWithForwardedFieldsFirstAnnotation(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
已过时。
 
udfWithForwardedFieldsSecondAnnotation(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.JoinOperator.EquiJoin
已过时。
 
udfWithForwardedFieldsSecondAnnotation(Class<?>) - 类 中的方法org.apache.flink.api.java.operators.TwoInputUdfOperator
已过时。
 
union(DataSet<T>) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Creates a union of this DataSet with an other DataSet.
UnionOperator<T> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
UnionOperator(DataSet<T>, DataSet<T>, String) - 类 的构造器org.apache.flink.api.java.operators.UnionOperator
已过时。
Create an operator that produces the union of the two given data sets.
unrequestedParameters - 类 中的变量org.apache.flink.api.java.utils.AbstractParameterTool
 
UnsortedGrouping<T> - org.apache.flink.api.java.operators中的类
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
UnsortedGrouping(DataSet<T>, Keys<T>) - 类 的构造器org.apache.flink.api.java.operators.UnsortedGrouping
已过时。
 
UnsupportedAggregationTypeException - org.apache.flink.api.java.aggregation中的异常错误
已过时。
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
UnsupportedAggregationTypeException(String) - 异常错误 的构造器org.apache.flink.api.java.aggregation.UnsupportedAggregationTypeException
已过时。
 
useKeySelector() - 类 中的方法org.apache.flink.api.java.operators.SortPartitionOperator
已过时。
Returns whether using key selector or not.
Utils - org.apache.flink.api.java中的类
Utility class that contains helper methods to work with Java APIs.
Utils.ChecksumHashCode - org.apache.flink.api.java中的类
Accumulator of Utils.ChecksumHashCode.
Utils.ChecksumHashCodeHelper<T> - org.apache.flink.api.java中的类
RichOutputFormat for Utils.ChecksumHashCode.
Utils.CollectHelper<T> - org.apache.flink.api.java中的类
Utility sink function that collects elements into an accumulator, from which it they can be retrieved by the client.
Utils.CountHelper<T> - org.apache.flink.api.java中的类
Utility sink function that counts elements and writes the count into an accumulator, from which it can be retrieved by the client.

V

validate(String, int) - 类 中的静态方法org.apache.flink.api.java.RemoteEnvironmentConfigUtils
 
value() - 类 中的方法org.apache.flink.api.java.summarize.aggregation.CompensatedSum
The value of the sum.
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.java.aggregation.Aggregations
已过时。
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.api.java.operators.join.JoinType
已过时。
返回带有指定名称的该类型的枚举常量。
values() - 枚举 中的静态方法org.apache.flink.api.java.aggregation.Aggregations
已过时。
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.api.java.operators.join.JoinType
已过时。
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
ValueSummaryAggregator<VT extends org.apache.flink.types.Value,PT,R,A extends Aggregator<PT,R>> - org.apache.flink.api.java.summarize.aggregation中的类
This is a generic Aggregator for Value types like StringValue, DoubleValue, etc.
ValueSummaryAggregator() - 类 的构造器org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
ValueSummaryAggregator.BooleanValueSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
ValueSummaryAggregator.DoubleValueSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
ValueSummaryAggregator.FloatValueSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
ValueSummaryAggregator.IntegerValueSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
ValueSummaryAggregator.LongValueSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
ValueSummaryAggregator.ShortValueSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类
ValueSummaryAggregator.StringValueSummaryAggregator - org.apache.flink.api.java.summarize.aggregation中的类

W

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 RichCoGroupFunction to 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 CrossFunction to 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 RichFlatJoinFunction to 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 FileOutputFormat to a specified location.
write(FileOutputFormat<T>, String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Writes a DataSet using a FileOutputFormat to a specified location.
writeAsCsv(String) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Writes a Tuple DataSet as CSV file(s) to the specified location.
writeAsCsv(String, FileSystem.WriteMode) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Writes a Tuple DataSet as CSV file(s) to the specified location.
writeAsCsv(String, String, String) - 类 中的方法org.apache.flink.api.java.DataSet
已过时。
Writes a Tuple DataSet 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 Tuple DataSet 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
 

Z

ZERO - 类 中的静态变量org.apache.flink.api.java.summarize.aggregation.CompensatedSum
 
zipWithIndex(DataSet<T>) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
已过时。
Method that assigns a unique Long value to all elements in the input data set.
zipWithUniqueId(DataSet<T>) - 类 中的静态方法org.apache.flink.api.java.utils.DataSetUtils
已过时。
Method that assigns a unique Long value to all elements in the input data set as described below.
A B C D E F G H I J K L M N O P Q R S T U V W Z 
跳过导航链接

Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.