Skip navigation links
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 - Class in org.apache.flink.api.java.utils
This class provides common utility methods of ParameterTool and MultipleParameterTool.
AbstractParameterTool() - Constructor for class org.apache.flink.api.java.utils.AbstractParameterTool
 
add(double, double) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding a value and a correction term.
add(double) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding a value without a correction term.
add(CompensatedSum) - Method in class 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) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Adds a new Kryo default serializer to the Runtime.
addSourceFieldOffset(SingleInputSemanticProperties, int, int) - Static method in class 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) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
Creates SemanticProperties by adding offsets to each input field index of the given SemanticProperties.
addToDefaults(String, String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
 
aggregate(T) - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
 
aggregate(Aggregations, int) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Applies an Aggregate transformation on a non-grouped Tuple DataSet.
aggregate(Aggregations, int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Applies an Aggregate transformation on a grouped Tuple DataSet.
aggregate(T) - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
Add a value to the current aggregation.
aggregate(Boolean) - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
aggregate(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
aggregate(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
aggregate(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
Add a value to the current aggregation.
aggregate(Object) - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
aggregate(String) - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
aggregate(Tuple) - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
aggregate(VT) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
AggregateOperator<IN> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator
Deprecated.
Non grouped aggregation.
AggregateOperator(Grouping<IN>, Aggregations, int, String) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator
Deprecated.
Grouped aggregation.
AggregationFunction<T> - Class in org.apache.flink.api.java.aggregation
 
AggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.AggregationFunction
 
AggregationFunctionFactory - Interface in org.apache.flink.api.java.aggregation
Interface of factory for creating AggregationFunction.
Aggregations - Enum in org.apache.flink.api.java.aggregation
Deprecated.
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> - Interface in org.apache.flink.api.java.summarize.aggregation
Generic interface for aggregation.
and(Aggregations, int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
Deprecated.
 
andMax(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
Deprecated.
 
andMin(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
Deprecated.
 
andSum(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
Deprecated.
 
appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K1>, Keys.SelectorFunctionKeys<T, K2>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
appendKeyRemover(Operator<Tuple2<K, T>>, Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
areExplicitEnvironmentsAllowed() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment or a RemoteEnvironment.

B

BernoulliSampler<T> - Class in org.apache.flink.api.java.sampling
A sampler implementation built upon a Bernoulli trail.
BernoulliSampler(double) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and default random number generator.
BernoulliSampler(double, long) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator seed.
BernoulliSampler(double, Random) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator.
BlockingShuffleOutputFormat<T> - Class in org.apache.flink.api.java.io
This is the inner OutputFormat used for specify the BLOCKING_PERSISTENT result partition type of coming edge.
BooleanColumnSummary - Class in org.apache.flink.api.java.summarize
Deprecated.
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) - Constructor for class org.apache.flink.api.java.summarize.BooleanColumnSummary
Deprecated.
 
BooleanSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for Boolean type.
BooleanSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
BooleanValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
 
BulkIterationResultSet<T> - Class in org.apache.flink.api.java.operators
Resulting DataSet of bulk iterations.

C

checkCollection(Collection<X>, Class<X>) - Static method in class org.apache.flink.api.java.io.CollectionInputFormat
Deprecated.
 
checkJoinKeyFields(int[]) - Method in class org.apache.flink.api.java.operators.DeltaIteration.SolutionSetPlaceHolder
Deprecated.
 
checkSameExecutionContext(DataSet<?>, DataSet<?>) - Static method in class org.apache.flink.api.java.DataSet
Deprecated.
 
ChecksumHashCode() - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCode
 
ChecksumHashCode(long, long) - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCode
 
checksumHashCode(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
This method will be removed at some point.
ChecksumHashCodeHelper(String) - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
clean(F) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
 
clearJobListeners() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Clear all registered JobListeners.
clone() - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
 
clone() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
clone() - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
 
clone() - Method in class org.apache.flink.api.java.utils.ParameterTool
 
close() - Method in class org.apache.flink.api.java.io.BlockingShuffleOutputFormat
 
close() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
 
close() - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
Deprecated.
 
close() - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
Deprecated.
 
close() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
Deprecated.
 
close() - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
close() - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
close() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
close() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
close() - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
close() - Method in class org.apache.flink.api.java.Utils.CountHelper
 
closeWith(DataSet<ST>, DataSet<WT>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Closes the delta iteration.
closeWith(DataSet<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Deprecated.
Closes the iteration.
closeWith(DataSet<T>, DataSet<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Deprecated.
Closes the iteration and specifies a termination criterion.
coGroup(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a CoGroup transformation.
CoGroupOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
Deprecated.
 
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) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
Deprecated.
 
CoGroupOperator.CoGroupOperatorSets<I1,I2> - Class in org.apache.flink.api.java.operators
Deprecated.
Intermediate step of a CoGroup transformation.
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate - Class in org.apache.flink.api.java.operators
Deprecated.
Intermediate step of a CoGroup transformation.
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction - Class in org.apache.flink.api.java.operators
Deprecated.
An intermediate CoGroupOperator without CoGroupFunction applied yet.
CoGroupOperatorSets(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Deprecated.
 
CoGroupRawOperator<I1,I2,OUT> - Class in 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) - Constructor for class org.apache.flink.api.java.operators.CoGroupRawOperator
 
collect() - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Convenience method to get the elements of a DataSet as a List.
collect(IN) - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
collect(IN) - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
CollectHelper(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.java.Utils.CollectHelper
 
CollectionEnvironment - Class in org.apache.flink.api.java
Deprecated.
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() - Constructor for class org.apache.flink.api.java.CollectionEnvironment
Deprecated.
 
CollectionInputFormat<T> - Class in org.apache.flink.api.java.io
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.io.CollectionInputFormat
Deprecated.
 
ColumnSummary - Class in org.apache.flink.api.java.summarize
Deprecated.
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() - Constructor for class org.apache.flink.api.java.summarize.ColumnSummary
Deprecated.
 
combine(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.FirstReducer
 
combine(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
 
combine(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
 
combine(Aggregator<T, R>) - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
Combine two aggregations of the same type.
combine(Aggregator<Boolean, BooleanColumnSummary>) - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
combine(Aggregator<Double, Double>) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
combine(Aggregator<Double, Double>) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
combine(Aggregator<Double, Double>) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
combine(Aggregator<Float, Float>) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
combine(Aggregator<Float, Float>) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
combine(Aggregator<Float, Float>) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
combine(Aggregator<Integer, Integer>) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
combine(Aggregator<Integer, Integer>) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
combine(Aggregator<Integer, Integer>) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
combine(Aggregator<Long, Long>) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
combine(Aggregator<Long, Long>) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
combine(Aggregator<T, NumericColumnSummary<T>>) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
combine two aggregations.
combine(Aggregator<Object, ObjectColumnSummary>) - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
combine(Aggregator<Short, Short>) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
combine(Aggregator<Short, Short>) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
combine(Aggregator<Short, Short>) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
combine(Aggregator<String, StringColumnSummary>) - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
combine(Aggregator<Tuple, R>) - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
combine(Aggregator<VT, R>) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Applies a GroupCombineFunction on a non-grouped DataSet.
combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
Applies a GroupCombineFunction on a grouped DataSet.
combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
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>> - Class 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.
CombineToGroupCombineWrapper(F) - Constructor for class org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
 
commentPrefix - Variable in class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
compareTo(IntermediateSampleData<T>) - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
 
CompensatedSum - Class in org.apache.flink.api.java.summarize.aggregation
Used to calculate sums using the Kahan summation algorithm.
CompensatedSum(double, double) - Constructor for class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Used to calculate sums using the Kahan summation algorithm.
configure(ReadableConfig, ClassLoader) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Sets all relevant options contained in the ReadableConfig such as e.g.
configure(Configuration) - Method in class org.apache.flink.api.java.io.BlockingShuffleOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
Deprecated.
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
Deprecated.
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
Deprecated.
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.TextInputFormat
Deprecated.
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
Deprecated.
 
configure(Configuration) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
configure(Configuration) - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
configure(Configuration) - Method in class org.apache.flink.api.java.Utils.CountHelper
 
containsNonNull() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
Deprecated.
True if this column contains any non-null values.
containsNull() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
Deprecated.
True if this column contains any null values.
context - Variable in class org.apache.flink.api.java.DataSet
Deprecated.
 
count() - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Convenience method to get the count (number of elements) of a DataSet.
countElementsPerPartition(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Method that goes over all the elements in each partition in order to retrieve the total number of elements.
CountHelper(String) - Constructor for class org.apache.flink.api.java.Utils.CountHelper
 
create(TupleTypeInfoBase<?>) - Static method in class org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
 
create(Class<T>) - Static method in class org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
Create a SummaryAggregator for the supplied type.
createAggregationFunction(Class<T>) - Method in interface org.apache.flink.api.java.aggregation.AggregationFunctionFactory
 
createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MaxAggregationFunctionFactory
 
createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MinAggregationFunctionFactory
 
createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
 
createCollectionsEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a CollectionEnvironment that uses Java Collections underneath.
createDefaultJoin(Keys<I2>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Deprecated.
 
createDefaultMask(int) - Static method in class org.apache.flink.api.java.io.CsvInputFormat
 
createExecutionEnvironment() - Method in interface org.apache.flink.api.java.ExecutionEnvironmentFactory
Deprecated.
Creates an ExecutionEnvironment from this factory.
createInput(InputFormat<X, ?>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Generic method to create an input DataSet with in InputFormat.
createInput(InputFormat<X, ?>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Generic method to create an input DataSet with in InputFormat.
createJoinFunctionAssigner(Keys<I2>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Deprecated.
 
createLocalEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a LocalEnvironment.
createLocalEnvironment(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a LocalEnvironment.
createLocalEnvironment(Configuration) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a LocalEnvironment.
createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a LocalEnvironment for local program execution that also starts the web monitoring UI.
createOutputFormat(AbstractID) - Static method in class org.apache.flink.api.java.io.BlockingShuffleOutputFormat
 
createProgramPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates the program's Plan.
createProgramPlan(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates the program's Plan.
createProgramPlan(String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates the program's Plan.
createProjectionPropertiesDual(int[], boolean[], TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
createProjectionPropertiesSingle(int[], CompositeType<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
createPropertiesFile(String) - Method in class 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) - Method in class 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...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
createResult() - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
Deprecated.
 
createTypeWithKey(Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
createTypeWithKey(Keys.SelectorFunctionKeys<T, K1>, Keys.SelectorFunctionKeys<T, K2>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
cross(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Cross transformation.
cross(T1, T2) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
Deprecated.
 
CrossOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.CrossOperator
Deprecated.
 
CrossOperator.CrossProjection<I1,I2> - Class in org.apache.flink.api.java.operators
Deprecated.
 
CrossOperator.DefaultCross<I1,I2> - Class in org.apache.flink.api.java.operators
Deprecated.
A Cross transformation that wraps pairs of crossed elements into Tuple2.
CrossOperator.ProjectCross<I1,I2,OUT extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.operators
Deprecated.
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> - Class in org.apache.flink.api.java.operators
Deprecated.
 
CrossProjection(DataSet<I1>, DataSet<I2>, int[], int[], CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
 
crossWithHuge(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Cross transformation.
crossWithTiny(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Cross transformation.
CsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
InputFormat that reads csv files.
CsvInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.CsvInputFormat
 
CsvOutputFormat<T extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.io
Deprecated.
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) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
Creates an instance of CsvOutputFormat.
CsvOutputFormat(Path, String) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
Creates an instance of CsvOutputFormat.
CsvOutputFormat(Path, String, String) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
Creates an instance of CsvOutputFormat.
CsvReader - Class in org.apache.flink.api.java.io
Deprecated.
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) - Constructor for class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
CsvReader(String, ExecutionEnvironment) - Constructor for class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
customPartitioner - Variable in class org.apache.flink.api.java.operators.Grouping
Deprecated.
 
CustomUnaryOperation<IN,OUT> - Interface in org.apache.flink.api.java.operators
Deprecated.
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 - Variable in class org.apache.flink.api.java.utils.MultipleParameterTool
 
data - Variable in class org.apache.flink.api.java.utils.ParameterTool
 
DataSet<T> - Class in org.apache.flink.api.java
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.DataSet
Deprecated.
 
DataSetUtils - Class in org.apache.flink.api.java.utils
Deprecated.
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> - Class in org.apache.flink.api.java.operators
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.DataSink
Deprecated.
 
DataSource<OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.DataSource
Deprecated.
Creates a new data source.
DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvInputFormat
 
DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
 
DEFAULT_LINE_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvInputFormat
 
DEFAULT_LINE_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
 
DEFAULT_UNDEFINED - Static variable in class org.apache.flink.api.java.utils.AbstractParameterTool
 
DefaultCross(DataSet<I1>, DataSet<I2>, CrossOperatorBase.CrossHint, String) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Deprecated.
 
defaultData - Variable in class org.apache.flink.api.java.utils.AbstractParameterTool
 
DefaultJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, String, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Deprecated.
 
defaultName - Variable in class org.apache.flink.api.java.operators.FilterOperator
Deprecated.
 
defaultName - Variable in class org.apache.flink.api.java.operators.FlatMapOperator
Deprecated.
 
defaultName - Variable in class org.apache.flink.api.java.operators.MapOperator
Deprecated.
 
defaultName - Variable in class org.apache.flink.api.java.operators.MapPartitionOperator
Deprecated.
 
delta() - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
The correction term.
DeltaIteration<ST,WT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
 
DeltaIteration.SolutionSetPlaceHolder<ST> - Class in org.apache.flink.api.java.operators
Deprecated.
A DataSet that acts as a placeholder for the solution set during the iteration.
DeltaIteration.WorksetPlaceHolder<WT> - Class in org.apache.flink.api.java.operators
Deprecated.
A DataSet that acts as a placeholder for the workset during the iteration.
DeltaIterationResultSet<ST,WT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Method in class org.apache.flink.api.java.io.TypeSerializerInputFormat
Deprecated.
 
DiscardingOutputFormat<T> - Class in org.apache.flink.api.java.io
Deprecated.
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() - Constructor for class org.apache.flink.api.java.io.DiscardingOutputFormat
Deprecated.
 
distinct(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Returns a distinct set of a DataSet using a KeySelector function.
distinct(int...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Returns a distinct set of a Tuple DataSet using field position keys.
distinct(String...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Returns a distinct set of a DataSet using expression keys.
distinct() - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Returns a distinct set of a DataSet.
DistinctOperator<T> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.DistinctOperator
Deprecated.
 
DistributedRandomSampler<T> - Class in 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) - Constructor for class org.apache.flink.api.java.sampling.DistributedRandomSampler
 
DoubleSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Double types.
DoubleSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
DoubleSummaryAggregator.MaxDoubleAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for max operation.
DoubleSummaryAggregator.MinDoubleAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for min operation.
DoubleSummaryAggregator.SumDoubleAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for sum operation.
DoubleValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
 

E

emptyIntermediateIterable - Variable in class org.apache.flink.api.java.sampling.DistributedRandomSampler
 
emptyIterable - Variable in class org.apache.flink.api.java.sampling.RandomSampler
 
EPSILON - Static variable in class org.apache.flink.api.java.sampling.RandomSampler
 
equals(Object) - Method in class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
Deprecated.
 
equals(Object) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
equals(Object) - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
 
equals(Object) - Method in class org.apache.flink.api.java.utils.ParameterTool
 
equalTo(int...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
Deprecated.
Continues a CoGroup transformation and defines the Tuple fields of the second co-grouped DataSet that should be used as grouping keys.
equalTo(String...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
Deprecated.
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>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
Deprecated.
Continues a CoGroup transformation and defines a KeySelector function for the second co-grouped DataSet.
equalTo(int...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Deprecated.
Continues a Join transformation and defines the Tuple fields of the second join DataSet that should be used as join keys.
equalTo(String...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Deprecated.
Continues a Join transformation and defines the fields of the second join DataSet that should be used as join keys.
equalTo(KeySelector<I2, K>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Deprecated.
Continues a Join transformation and defines a KeySelector function for the second join DataSet.
equalTo(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
Deprecated.
Continues a Join transformation and defines the Tuple fields of the second join DataSet that should be used as join keys.
equalTo(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
Deprecated.
Continues a Join transformation and defines the fields of the second join DataSet that should be used as join keys.
equalTo(KeySelector<I2, K>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, JoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, JoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
execute(String) - Method in class org.apache.flink.api.java.CollectionEnvironment
Deprecated.
 
execute() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Triggers the program execution.
execute(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Triggers the program execution.
executeAsync() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Triggers the program execution asynchronously.
executeAsync(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Triggers the program execution asynchronously.
ExecutionEnvironment - Class in org.apache.flink.api.java
Deprecated.
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) - Constructor for class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a new ExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
ExecutionEnvironment(Configuration, ClassLoader) - Constructor for class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a new ExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
ExecutionEnvironment(PipelineExecutorServiceLoader, Configuration, ClassLoader) - Constructor for class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a new ExecutionEnvironment that will use the given Configuration to configure the PipelineExecutor.
ExecutionEnvironment() - Constructor for class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a new Execution Environment.
ExecutionEnvironmentFactory - Interface in org.apache.flink.api.java
Deprecated.
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 - Class in org.apache.flink.api.java
A utility for extracting an execution plan (as JSON) from a Plan.
ExecutionPlanUtil() - Constructor for class org.apache.flink.api.java.ExecutionPlanUtil
 
ExecutionPlanUtil.ExecutionPlanJSONGenerator - Interface in org.apache.flink.api.java
Internal interface for the JSON plan generator that has to reside in the optimizer package.
extractSemanticAnnotations(Class<?>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 

F

fieldDelimiter - Variable in class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
fieldDelimiter(char) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
fieldDelimiter(String) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Configures the delimiter that separates the fields within a row.
fields - Variable in class org.apache.flink.api.java.operators.ProjectOperator
Deprecated.
 
fillInType(TypeInformation<T>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Tries to fill in the type information.
fillRecord(OUT, Object[]) - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
fillRecord(OUT, Object[]) - Method in class org.apache.flink.api.java.io.PojoCsvInputFormat
 
fillRecord(Row, Object[]) - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
Deprecated.
 
fillRecord(OUT, Object[]) - Method in class org.apache.flink.api.java.io.TupleCsvInputFormat
 
filter(FilterFunction<T>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Applies a Filter transformation on a DataSet.
FilterOperator<T> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.FilterOperator
Deprecated.
 
first(int) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Returns a new set containing the first n elements in this DataSet.
first(int) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
Returns a new set containing the first n elements in this grouped and sorted DataSet.
first(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Returns a new set containing the first n elements in this grouped DataSet.
FirstReducer<T> - Class in org.apache.flink.api.java.functions
Reducer that only emits the first N elements in a group.
FirstReducer(int) - Constructor for class org.apache.flink.api.java.functions.FirstReducer
 
flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Applies a FlatMap transformation on a DataSet.
flatMap(IN) - Method in class org.apache.flink.api.java.functions.FlatMapIterator
Deprecated.
The core method of the function.
flatMap(IN, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.FlatMapIterator
Deprecated.
Delegates calls to the FlatMapIterator.flatMap(Object) method.
flatMap(T, Collector<T>) - Method in class org.apache.flink.api.java.operators.translation.PlanFilterOperator.FlatMapFilter
 
FlatMapIterator<IN,OUT> - Class in org.apache.flink.api.java.functions
Deprecated.
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() - Constructor for class org.apache.flink.api.java.functions.FlatMapIterator
Deprecated.
 
FlatMapOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.FlatMapOperator
Deprecated.
 
FlinkChillPackageRegistrar - Class in org.apache.flink.api.java.typeutils.runtime.kryo
Registers all chill serializers used for Java types.
FlinkChillPackageRegistrar() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.FlinkChillPackageRegistrar
 
FloatSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Float types.
FloatSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
FloatSummaryAggregator.MaxFloatAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for max operation.
FloatSummaryAggregator.MinFloatAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for min operation.
FloatSummaryAggregator.SumFloatAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for sum operation.
FloatValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
 
format(IN) - Method in interface org.apache.flink.api.java.io.TextOutputFormat.TextFormatter
Deprecated.
 
FormattingMapper<T> - Class in org.apache.flink.api.java.functions
Mapper that converts values to strings using a TextOutputFormat.TextFormatter.
FormattingMapper(TextOutputFormat.TextFormatter<T>) - Constructor for class org.apache.flink.api.java.functions.FormattingMapper
 
fromArgs(String[]) - Static method in class org.apache.flink.api.java.utils.MultipleParameterTool
Returns MultipleParameterTool for the given arguments.
fromArgs(String[]) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given arguments.
fromCollection(Collection<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet from the given non-empty collection.
fromCollection(Collection<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet from the given non-empty collection.
fromCollection(Iterator<X>, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet from the given iterator.
fromCollection(Iterator<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet from the given iterator.
fromElements(X...) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a new data set that contains the given elements.
fromElements(Class<X>, X...) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a new data set that contains the given elements.
fromMap(Map<String, String>) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given map.
fromMultiMap(Map<String, Collection<String>>) - Static method in class org.apache.flink.api.java.utils.MultipleParameterTool
Returns MultipleParameterTool for the given multi map.
fromParallelCollection(SplittableIterator<X>, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a new data set that contains elements in the iterator.
fromParallelCollection(SplittableIterator<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a new data set that contains elements in the iterator.
fromPropertiesFile(String) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given Properties file.
fromPropertiesFile(File) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given Properties file.
fromPropertiesFile(InputStream) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given InputStream from Properties file.
fromSystemProperties() - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool from the system properties.
fullOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Full Outer Join transformation.
fullOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Full Outer Join transformation.
function - Variable in class org.apache.flink.api.java.operators.FilterOperator
Deprecated.
 
function - Variable in class org.apache.flink.api.java.operators.FlatMapOperator
Deprecated.
 
function - Variable in class org.apache.flink.api.java.operators.MapOperator
Deprecated.
 
function - Variable in class org.apache.flink.api.java.operators.MapPartitionOperator
Deprecated.
 
FunctionAnnotation - Class in org.apache.flink.api.java.functions
Deprecated.
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 - Annotation Type in org.apache.flink.api.java.functions
Deprecated.
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 - Annotation Type in org.apache.flink.api.java.functions
Deprecated.
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 - Annotation Type in org.apache.flink.api.java.functions
Deprecated.
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 - Annotation Type in org.apache.flink.api.java.functions
Deprecated.
The NonForwardedFields annotation declares ALL fields which not preserved on the same position in a functions output.
FunctionAnnotation.NonForwardedFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
Deprecated.
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 - Annotation Type in org.apache.flink.api.java.functions
Deprecated.
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 - Annotation Type in org.apache.flink.api.java.functions
Deprecated.
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 - Annotation Type in org.apache.flink.api.java.functions
Deprecated.
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 - Annotation Type in org.apache.flink.api.java.functions
Deprecated.
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() - Method in class org.apache.flink.api.java.utils.PlanGenerator
 
generateSequence(long, long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a new data set that contains a sequence of numbers.
get(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the String value for the given key.
get(String, String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the String value for the given key.
get(String) - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
Returns the String value for the given key.
get(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the String value for the given key.
getAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
 
getAggregators() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Gets the registry for aggregators for the iteration.
getAggregators() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Deprecated.
Gets the registry for aggregators.
getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
getBitSize(long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
 
getBoolean(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Boolean value for the given key.
getBoolean(String, boolean) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Boolean value for the given key.
getBroadcastSets() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
getBroadcastSets() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
getBroadcastSets() - Method in interface org.apache.flink.api.java.operators.UdfOperator
Deprecated.
Gets the broadcast sets (name and data set) that have been added to context of the UDF.
getByte(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Byte value for the given key.
getByte(String, byte) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Byte value for the given key.
getCallLocationName() - Static method in class org.apache.flink.api.java.Utils
 
getCallLocationName(int) - Static method in class org.apache.flink.api.java.Utils
 
getCharset() - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Gets the character set for the reader.
getCharsetName() - Method in class org.apache.flink.api.java.io.TextInputFormat
Deprecated.
 
getCharsetName() - Method in class org.apache.flink.api.java.io.TextOutputFormat
Deprecated.
 
getCharsetName() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
Deprecated.
 
getChecksum() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
getConfig() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Gets the config object that defines execution parameters.
getConfiguration() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
 
getConfiguration() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns a Configuration object from this ParameterTool.
getCount() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
getCrossHint() - Method in class org.apache.flink.api.java.operators.CrossOperator
Deprecated.
 
getCustomPartitioner() - Method in class org.apache.flink.api.java.operators.Grouping
Deprecated.
Gets the custom partitioner to be used for this grouping, or null, if none was defined.
getCustomPartitioner() - Method in class org.apache.flink.api.java.operators.PartitionOperator
Deprecated.
Gets the custom partitioner from this partitioning.
getDataSet() - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
 
getDefaultLocalParallelism() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Gets the default parallelism that will be used for the local execution environment created by ExecutionEnvironment.createLocalEnvironment().
getDouble(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Double value for the given key.
getDouble(String, double) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Double value for the given key.
getElement() - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
 
getEmptyCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Deprecated.
Number of empty strings e.g.
getExecutionEnvironment() - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Returns the ExecutionEnvironment in which this DataSet is registered.
getExecutionEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
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) - Method in interface org.apache.flink.api.java.ExecutionPlanUtil.ExecutionPlanJSONGenerator
Returns the execution plan as a JSON string.
getExecutionPlanAsJSON(Plan) - Static method in class org.apache.flink.api.java.ExecutionPlanUtil
Extracts the execution plan (as JSON) from the given Plan.
getExecutorServiceLoader() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
 
getFactory() - Method in enum org.apache.flink.api.java.aggregation.Aggregations
Deprecated.
 
getFalseCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
Deprecated.
 
getFields() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
Deprecated.
 
getFieldTypes() - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
getFilePath() - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
getFloat(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Float value for the given key.
getFloat(String, float) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Float value for the given key.
getFormat() - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.FilterOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.FlatMapOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.MapOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.ReduceOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
getFunction() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
getGroupOrdering() - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
 
getGroupSortKeyPositions() - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
 
getGroupSortOrders() - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
 
getInfinityCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
Number of values that are positive or negative infinity.
getInitialSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Gets the initial solution set.
getInitialWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Gets the initial workset.
getInput() - Method in class org.apache.flink.api.java.operators.NoOpOperator
 
getInput() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
Deprecated.
Gets the data set that this operation uses as its input.
getInput1() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Deprecated.
Gets the data set that this operation uses as its first input.
getInput1Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Deprecated.
Gets the type information of the data type of the first input data set.
getInput2() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Deprecated.
Gets the data set that this operation uses as its second input.
getInput2Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Deprecated.
Gets the type information of the data type of the second input data set.
getInputDataSet() - Method in class org.apache.flink.api.java.operators.Grouping
Deprecated.
Returns the input DataSet of a grouping operation, that is the one before the grouping.
getInputFormat() - Method in class org.apache.flink.api.java.operators.DataSource
Deprecated.
Gets the input format that is executed by this data source.
getInputType() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
Deprecated.
Gets the type information of the data type of the input data set.
getInt(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Integer value for the given key.
getInt(String, int) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Integer value for the given key.
getIntermediateDataSetId() - Method in class org.apache.flink.api.java.io.BlockingShuffleOutputFormat
 
getIsFromFirst() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
Deprecated.
 
getIterationHead() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
 
getIterationHead() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
Deprecated.
 
getJobListeners() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Gets the config JobListeners.
getJoinHint() - Method in class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
Gets the JoinHint that describes how the join is executed.
getJoinType() - Method in class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
Gets the JoinType that describes this join operation (e.g.
getKeyFromArgs(String[], int) - Static method in class org.apache.flink.api.java.Utils
Get the key from the given args.
getKeyPositions() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
Deprecated.
 
getKeys() - Method in class org.apache.flink.api.java.operators.Grouping
Deprecated.
 
getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Deprecated.
 
getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
getKeys1() - Method in class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
 
getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Deprecated.
 
getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
getKeys2() - Method in class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
 
getLastGroupKey() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
getLastJobExecutionResult() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Returns the JobExecutionResult of the last executed job.
getLastKey() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
getLastSortKey() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
getLocalValue() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
getLong(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Long value for the given key.
getLong(String, long) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Long value for the given key.
getMax() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
 
getMaxIterations() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
Deprecated.
 
getMaxIterations() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Deprecated.
Gets the maximum number of iterations.
getMaxLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Deprecated.
Longest String length.
getMean() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
Null, NaN, and Infinite values are ignored in this calculation.
getMeanLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Deprecated.
 
getMin() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
 
getMinLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Deprecated.
Shortest String length.
getMinResources() - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
Returns the minimum resources of this data sink.
getMinResources() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Gets the minimum resources from this iteration.
getMinResources() - Method in class org.apache.flink.api.java.operators.Operator
Deprecated.
Returns the minimum resource of this operator.
getMissingCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
The number of "missing" values where "missing" is defined as null, NaN, or Infinity.
getMultiParameter(String) - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
Returns the Collection of String values for the given key.
getMultiParameterRequired(String) - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
Returns the Collection of String values for the given key.
getName() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Gets the name from this iteration.
getName() - Method in class org.apache.flink.api.java.operators.Operator
Deprecated.
Returns the name of the operator.
getNanCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
Number of values that are NaN.
getNextPartialSolution() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
 
getNextRegistrationId() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.FlinkChillPackageRegistrar
 
getNextSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
Deprecated.
 
getNextWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
Deprecated.
 
getNonMissingCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
The number of values that are not null, NaN, or Infinity.
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
Deprecated.
The number of non-null values in this column.
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
Deprecated.
The number of non-null values in this column.
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
The number of non-null values in this column.
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
Deprecated.
The number of non-null values in this column.
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Deprecated.
 
getNullCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
Deprecated.
 
getNullCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
Deprecated.
The number of null values in this column.
getNullCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
 
getNullCount() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
Deprecated.
 
getNullCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Deprecated.
 
getNumberOfExecutionRetries() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
This method will be replaced by ExecutionEnvironment.getRestartStrategy(). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of execution retries.
getNumberOfParameters() - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns number of parameters in AbstractParameterTool.
getNumberOfParameters() - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
Returns number of parameters in ParameterTool.
getNumberOfParameters() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns number of parameters in ParameterTool.
getParallelism() - Method in class org.apache.flink.api.java.CollectionEnvironment
Deprecated.
 
getParallelism() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Gets the parallelism with which operation are executed by default.
getParallelism() - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
Returns the parallelism of this data sink.
getParallelism() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Gets the iteration's parallelism.
getParallelism() - Method in class org.apache.flink.api.java.operators.Operator
Deprecated.
Returns the parallelism of this operator.
getParameters() - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
 
getParameters() - Method in class org.apache.flink.api.java.operators.DataSource
Deprecated.
 
getParameters() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
getParameters() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
getParameters() - Method in interface org.apache.flink.api.java.operators.UdfOperator
Deprecated.
Gets the configuration parameters that will be passed to the UDF's open method RichFunction.open(OpenContext).
getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Deprecated.
Gets the custom partitioner used by this join, or null, if none is set.
getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Deprecated.
Gets the custom partitioner used by this join, or null, if none is set.
getPartitioner() - Method in class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
Gets the custom partitioner used by this join, or null, if none is set.
getPreferredResources() - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
Returns the preferred resources of this data sink.
getPreferredResources() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Gets the preferred resources from this iteration.
getPreferredResources() - Method in class org.apache.flink.api.java.operators.Operator
Deprecated.
Returns the preferred resource of this operator.
getProducedType() - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
Deprecated.
 
getProducedType() - Method in class org.apache.flink.api.java.io.TypeSerializerInputFormat
Deprecated.
 
getProperties() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns a Properties object from this ParameterTool.
getRequired(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the String value for the given key.
getRestartStrategy() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Returns the specified restart strategy configuration.
getResultType() - Method in class org.apache.flink.api.java.operators.Operator
Deprecated.
Returns the type of the result of this operator.
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Deprecated.
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
Deprecated.
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
Deprecated.
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.ReduceOperator
Deprecated.
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
getSemanticProperties() - Method in interface org.apache.flink.api.java.operators.UdfOperator
Deprecated.
Gets the semantic properties that have been set for the user-defined functions (UDF).
getSemanticPropsDual(Set<Annotation>, TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>, boolean) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsSingle(Set<Annotation>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>, boolean) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSerializerTree(TypeInformation<T>) - Static method in class org.apache.flink.api.java.Utils
Debugging utility to understand the hierarchy of serializers created by the Java API.
getShort(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Short value for the given key.
getShort(String, short) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Returns the Short value for the given key.
getSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Gets the solution set of the delta iteration.
getSortSelectionFunctionKey() - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
 
getSplitDataProperties() - Method in class org.apache.flink.api.java.operators.DataSource
Deprecated.
Returns the SplitDataProperties for the InputSplits of this DataSource for configurations.
getSplitGroupKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
 
getSplitOrder() - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
 
getSplitPartitioner() - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
 
getSplitPartitionKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
 
getStandardDeviation() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
Standard Deviation is a measure of variation in a set of numbers.
getSum() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
 
getTerminationCriterion() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
 
getTotalCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
Deprecated.
The number of all rows in this column including both nulls and non-nulls.
getTrueCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
Deprecated.
 
getType() - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Returns the TypeInformation for the type of this DataSet.
getType() - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
 
getUnrequestedParameters() - Method in class 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() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
 
getValue(BooleanValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
 
getValue(DoubleValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
 
getValue(FloatValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
 
getValue(VT) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
Get the value out of a value type.
getValue(IntValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
 
getValue(LongValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
 
getValue(ShortValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
 
getValue(StringValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
 
getVariance() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
Variance is a measure of how far a set of numbers are spread out.
getWeight() - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
 
getWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Gets the working set of the delta iteration.
getWorksetType() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
Deprecated.
 
getWrappedFunction() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
groupBy(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Groups a DataSet using a KeySelector function.
groupBy(int...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Groups a Tuple DataSet using field position keys.
groupBy(String...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Groups a DataSet using field expressions.
GroupCombineOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.GroupCombineOperator
Deprecated.
Constructor for a non-grouped reduce (all reduce).
GroupCombineOperator(Grouping<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupCombineOperator
Deprecated.
Constructor for a grouped reduce.
Grouping<T> - Class in org.apache.flink.api.java.operators
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.Grouping
Deprecated.
 
GroupReduceIterator<IN,OUT> - Class in org.apache.flink.api.java.functions
Deprecated.
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() - Constructor for class org.apache.flink.api.java.functions.GroupReduceIterator
Deprecated.
 
GroupReduceOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
Deprecated.
Constructor for a non-grouped reduce (all reduce).
GroupReduceOperator(Grouping<IN>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
Deprecated.
Constructor for a grouped reduce.

H

has(String) - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
Check if value is set.
has(String) - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
Check if value is set.
has(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Check if value is set.
hashCode() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
hashCode() - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
 
hashCode() - Method in class org.apache.flink.api.java.utils.ParameterTool
 
hasNext() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
hasNext() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 

I

IdPartitioner - Class in org.apache.flink.api.java.functions
Partitioner that partitions by id.
IdPartitioner() - Constructor for class org.apache.flink.api.java.functions.IdPartitioner
 
ignoreComments(String) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Configures the string that starts comments.
ignoreFirstLine() - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Sets the CSV reader to ignore the first line.
ignoreInvalidLines - Variable in class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
ignoreInvalidLines() - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Sets the CSV reader to ignore any invalid lines.
includedMask - Variable in class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
includeFields(boolean...) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Configures which fields of the CSV file should be included and which should be skipped.
includeFields(String) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Configures which fields of the CSV file should be included and which should be skipped.
includeFields(long) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Configures which fields of the CSV file should be included and which should be skipped.
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
 
initializeContextEnvironment(ExecutionEnvironmentFactory) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Sets a context environment factory, that creates the context environment for running programs with pre-configured environments.
initializeSplit(FileInputSplit, Long) - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
initializeSplit(FileInputSplit, Long) - Method in class org.apache.flink.api.java.io.PojoCsvInputFormat
 
initializeSplit(FileInputSplit, Long) - Method in class org.apache.flink.api.java.io.PrimitiveInputFormat
Deprecated.
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
Initialize an aggregator that can be used for the underlying primitive in the Value type.
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
input1 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
 
input2 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
 
inputDataSet - Variable in class org.apache.flink.api.java.operators.Grouping
Deprecated.
 
IntegerSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Integer types.
IntegerSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
IntegerSummaryAggregator.MaxIntegerAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for max operation.
IntegerSummaryAggregator.MinIntegerAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for min operation.
IntegerSummaryAggregator.SumIntegerAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for sum operation.
IntegerValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
 
IntermediateSampleData<T> - Class in org.apache.flink.api.java.sampling
The data structure which is transferred between partitions and the coordinator for distributed random sampling.
IntermediateSampleData(double, T) - Constructor for class org.apache.flink.api.java.sampling.IntermediateSampleData
 
isCombinable() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
Deprecated.
 
isInfinite(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
isInfinite(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
isInfinite(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
isInfinite(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
isInfinite(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
isInfinite(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
isNan(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
isNan(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
isNan(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
isNan(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
isNan(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
isNan(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
isOuter() - Method in enum org.apache.flink.api.java.operators.join.JoinType
Deprecated.
 
isSkipInvalidLines() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
Deprecated.
 
isSolutionSetUnManaged() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
gets whether the solution set is in managed or unmanaged memory.
iterate(int) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates an iterative part of the program that executes multiple times and feeds back data sets.
iterateDelta(DataSet<R>, int, int...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a delta iteration.
IterativeDataSet<T> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.IterativeDataSet
Deprecated.
 
iterator() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
iterator() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
IteratorInputFormat<T> - Class in org.apache.flink.api.java.io
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.io.IteratorInputFormat
Deprecated.
 

J

join(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Join transformation.
join(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Join transformation.
join(IN1, IN2, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin.WrappingFlatJoinFunction
Deprecated.
 
join(Tuple2<K, I1>, I2, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.TupleLeftUnwrappingJoiner
 
join(I1, Tuple2<K, I2>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.TupleRightUnwrappingJoiner
 
join(Tuple2<K, I1>, Tuple2<K, I2>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingJoiner
 
JoinFunctionAssigner<I1,I2> - Interface in org.apache.flink.api.java.operators.join
Deprecated.
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 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
 
JoinOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
 
JoinOperator.DefaultJoin<I1,I2> - Class in org.apache.flink.api.java.operators
Deprecated.
A Join transformation that wraps pairs of joining elements into Tuple2.
JoinOperator.DefaultJoin.WrappingFlatJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
Wrapper around JoinFunction.
JoinOperator.EquiJoin<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
A Join transformation that applies a JoinFunction on each pair of joining elements.
JoinOperator.JoinOperatorSets<I1,I2> - Class in org.apache.flink.api.java.operators
Deprecated.
Intermediate step of a Join transformation.
JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate - Class in org.apache.flink.api.java.operators
Deprecated.
Intermediate step of a Join transformation.
JoinOperator.ProjectJoin<I1,I2,OUT extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.operators
Deprecated.
A Join transformation that projects joining elements or fields of joining Tuples into result Tuples.
JoinOperatorSets(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Deprecated.
 
JoinOperatorSets(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Deprecated.
 
JoinOperatorSetsBase<I1,I2> - Class in org.apache.flink.api.java.operators.join
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
 
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
 
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint, JoinType) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
 
JoinOperatorSetsBase.JoinOperatorSetsPredicateBase - Class in org.apache.flink.api.java.operators.join
Deprecated.
Intermediate step of a Join transformation.
JoinOperatorSetsPredicateBase(Keys<I1>) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Deprecated.
 
joinType - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
 
JoinType - Enum in org.apache.flink.api.java.operators.join
Deprecated.
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 - Variable in class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
 
joinWithHuge(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Join transformation.
joinWithTiny(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Join transformation.

K

KeyExtractingMapper<T,K> - Class in org.apache.flink.api.java.operators.translation
Mapper that extracts keys.
KeyExtractingMapper(KeySelector<T, K>) - Constructor for class org.apache.flink.api.java.operators.translation.KeyExtractingMapper
 
KeyFunctions - Class in org.apache.flink.api.java.operators
This class holds static utilities to append functions that extract and prune keys.
KeyFunctions() - Constructor for class org.apache.flink.api.java.operators.KeyFunctions
 
KeyRemovingMapper<T,K> - Class in org.apache.flink.api.java.operators.translation
Mapper that removes keys.
KeyRemovingMapper() - Constructor for class org.apache.flink.api.java.operators.translation.KeyRemovingMapper
 
keys - Variable in class org.apache.flink.api.java.operators.Grouping
Deprecated.
 
keys1 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Deprecated.
 
keys1 - Variable in class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
 
keys2 - Variable in class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
 

L

lastJobExecutionResult - Variable in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Result from the latest execution, to make it retrievable when using eager execution methods.
leftOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Left Outer Join transformation.
leftOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Left Outer Join transformation.
lineDelimiter - Variable in class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
lineDelimiter(String) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Configures the delimiter that separates the lines/rows.
LocalCollectionOutputFormat<T> - Class in org.apache.flink.api.java.io
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.io.LocalCollectionOutputFormat
Deprecated.
 
LocalEnvironment - Class in org.apache.flink.api.java
Deprecated.
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() - Constructor for class org.apache.flink.api.java.LocalEnvironment
Deprecated.
Creates a new local environment.
LocalEnvironment(Configuration) - Constructor for class org.apache.flink.api.java.LocalEnvironment
Deprecated.
Creates a new local environment that configures its local executor with the given configuration.
LOG - Static variable in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
The logger used by the environment and its subclasses.
LongSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Long types.
LongSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
LongSummaryAggregator.MaxLongAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for max operation.
LongSummaryAggregator.MinLongAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for min operation.
LongValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
 

M

map(MapFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Applies a Map transformation on this DataSet.
map(T) - Method in class org.apache.flink.api.java.functions.FormattingMapper
 
map(T) - Method in class org.apache.flink.api.java.operators.translation.KeyExtractingMapper
 
map(Tuple2<K, T>) - Method in class org.apache.flink.api.java.operators.translation.KeyRemovingMapper
 
map(T) - Method in class org.apache.flink.api.java.operators.translation.TwoKeyExtractingMapper
 
MapOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.MapOperator
Deprecated.
 
mapPartition(MapPartitionFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Applies a Map-style operation to the entire partition of the data.
mapPartition(Iterable<T>, Collector<IntermediateSampleData<T>>) - Method in class org.apache.flink.api.java.functions.SampleInPartition
 
mapPartition(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.SampleWithFraction
 
MapPartitionOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.MapPartitionOperator
Deprecated.
 
max(int) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Syntactic sugar for DataSet.aggregate(Aggregations, int) using Aggregations.MAX as the aggregation function.
max(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Syntactic sugar for aggregate (MAX, field).
max(Short, Short) - Static method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
Like Math.max() except for shorts.
MaxAggregationFunction<T extends Comparable<T>> - Class in org.apache.flink.api.java.aggregation
Implementation of AggregationFunction for max operation.
MaxAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction
 
MaxAggregationFunction.MaxAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
MaxAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MaxAggregationFunctionFactory
 
maxBy(int...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Selects an element with maximum value.
maxBy(int...) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Applies a special case of a reduce transformation (maxBy) on a grouped DataSet.
MaxDoubleAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
MaxFloatAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
MaxIntegerAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
MaxLongAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
MaxShortAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
merge(Accumulator<Utils.ChecksumHashCode, Utils.ChecksumHashCode>) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
mergeWith(MultipleParameterTool) - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
mergeWith(ParameterTool) - Method in class org.apache.flink.api.java.utils.ParameterTool
Merges two ParameterTool.
min(int) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Syntactic sugar for DataSet.aggregate(Aggregations, int) using Aggregations.MIN as the aggregation function.
min(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Syntactic sugar for aggregate (MIN, field).
min(Short, Short) - Static method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
Like Math.min() except for shorts.
MinAggregationFunction<T extends Comparable<T>> - Class in org.apache.flink.api.java.aggregation
Implementations of AggregationFunction for min operation.
MinAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction
 
MinAggregationFunction.MinAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
MinAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction.MinAggregationFunctionFactory
 
minBy(int...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Selects an element with minimum value.
minBy(int...) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Applies a special case of a reduce transformation (minBy) on a grouped DataSet.
MinDoubleAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
MinFloatAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
MinIntegerAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
MinLongAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
minResources - Variable in class org.apache.flink.api.java.operators.Operator
Deprecated.
 
MinShortAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
MultipleParameterTool - Class in org.apache.flink.api.java.utils
This class provides simple utility methods for reading and parsing program arguments from different sources.

N

name(String) - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
 
name(String) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Sets the name for the iteration.
name - Variable in class org.apache.flink.api.java.operators.Operator
Deprecated.
 
name(String) - Method in class org.apache.flink.api.java.operators.Operator
Deprecated.
Sets the name of this operator.
next() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
next() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
nextRecord(T) - Method in class org.apache.flink.api.java.io.CollectionInputFormat
Deprecated.
 
nextRecord(OUT) - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
nextRecord(T) - Method in class org.apache.flink.api.java.io.IteratorInputFormat
Deprecated.
 
nextRecord(T) - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
Deprecated.
 
NO_VALUE_KEY - Static variable in class org.apache.flink.api.java.utils.AbstractParameterTool
 
NoOpOperator<IN> - Class in org.apache.flink.api.java.operators
This operator will be ignored during translation.
NoOpOperator(DataSet<IN>, TypeInformation<IN>) - Constructor for class org.apache.flink.api.java.operators.NoOpOperator
 
NumericColumnSummary<T> - Class in org.apache.flink.api.java.summarize
Deprecated.
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) - Constructor for class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
 
NumericSummaryAggregator<T extends Number> - Class in org.apache.flink.api.java.summarize.aggregation
Generic aggregator for all numeric types creates a summary of a column of numbers.
NumericSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
numSamples - Variable in class org.apache.flink.api.java.sampling.DistributedRandomSampler
 

O

ObjectColumnSummary - Class in org.apache.flink.api.java.summarize
Deprecated.
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) - Constructor for class org.apache.flink.api.java.summarize.ObjectColumnSummary
Deprecated.
 
ObjectSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that calculates statistics for Object values.
ObjectSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
open(int, int) - Method in class org.apache.flink.api.java.io.BlockingShuffleOutputFormat
 
open(GenericInputSplit) - Method in class org.apache.flink.api.java.io.CollectionInputFormat
Deprecated.
 
open(int, int) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
 
open(int, int) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
Deprecated.
 
open(int, int) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
Deprecated.
 
open(GenericInputSplit) - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
Deprecated.
 
open(int, int) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
Deprecated.
 
open(int, int) - Method in class org.apache.flink.api.java.io.TextOutputFormat
Deprecated.
 
open(OpenContext) - Method in class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
 
open(OpenContext) - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
open(int, int) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
open(int, int) - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
open(int, int) - Method in class org.apache.flink.api.java.Utils.CountHelper
 
Operator<OUT,O extends Operator<OUT,O>> - Class in org.apache.flink.api.java.operators
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.Operator
Deprecated.
 
OperatorTranslation - Class in org.apache.flink.api.java.operators
Used for translating data sets into corresponding operators.
OperatorTranslation() - Constructor for class org.apache.flink.api.java.operators.OperatorTranslation
 
org.apache.flink.api.java - package org.apache.flink.api.java
 
org.apache.flink.api.java.aggregation - package org.apache.flink.api.java.aggregation
 
org.apache.flink.api.java.functions - package org.apache.flink.api.java.functions
 
org.apache.flink.api.java.io - package org.apache.flink.api.java.io
 
org.apache.flink.api.java.operators - package org.apache.flink.api.java.operators
 
org.apache.flink.api.java.operators.join - package org.apache.flink.api.java.operators.join
 
org.apache.flink.api.java.operators.translation - package org.apache.flink.api.java.operators.translation
 
org.apache.flink.api.java.sampling - package org.apache.flink.api.java.sampling
 
org.apache.flink.api.java.summarize - package org.apache.flink.api.java.summarize
 
org.apache.flink.api.java.summarize.aggregation - package org.apache.flink.api.java.summarize.aggregation
 
org.apache.flink.api.java.typeutils.runtime.kryo - package org.apache.flink.api.java.typeutils.runtime.kryo
 
org.apache.flink.api.java.utils - package org.apache.flink.api.java.utils
 
output(OutputFormat<T>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Emits a DataSet using an OutputFormat.

P

parallelism(int) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Sets the parallelism for the iteration.
parallelism - Variable in class org.apache.flink.api.java.operators.Operator
Deprecated.
 
ParallelIteratorInputFormat<T> - Class in org.apache.flink.api.java.io
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.io.ParallelIteratorInputFormat
Deprecated.
 
ParameterTool - Class in org.apache.flink.api.java.utils
This class provides simple utility methods for reading and parsing program arguments from different sources.
parsedValues - Variable in class org.apache.flink.api.java.io.CsvInputFormat
 
parseQuotedStrings - Variable in class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
parseQuotedStrings(char) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Enables quoted String parsing.
parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
Deprecated.
 
partition(Integer, int) - Method in class org.apache.flink.api.java.functions.IdPartitioner
 
partition(T, int) - Method in class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
Deprecated.
 
partitionByHash(int...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Hash-partitions a DataSet on the specified key fields.
partitionByHash(String...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Hash-partitions a DataSet on the specified key fields.
partitionByHash(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Partitions a DataSet using the specified KeySelector.
partitionByRange(int...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Range-partitions a DataSet on the specified key fields.
partitionByRange(String...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Range-partitions a DataSet on the specified key fields.
partitionByRange(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Range-partitions a DataSet using the specified KeySelector.
partitionByRange(DataSet<T>, DataDistribution, int...) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Range-partitions a DataSet on the specified tuple field positions.
partitionByRange(DataSet<T>, DataDistribution, String...) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Range-partitions a DataSet on the specified fields.
partitionByRange(DataSet<T>, DataDistribution, KeySelector<T, K>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Range-partitions a DataSet using the specified key selector function.
partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Partitions a tuple DataSet on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Partitions a POJO DataSet on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Partitions a DataSet on the key returned by the selector, using a custom partitioner.
PartitionOperator<T> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
Deprecated.
 
PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, DataDistribution, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
Deprecated.
 
PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
Deprecated.
 
PartitionOperator(DataSet<T>, Keys<T>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
Deprecated.
 
PartitionOperator(DataSet<T>, Keys<T>, Partitioner<P>, TypeInformation<P>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
Deprecated.
 
PlanBothUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in 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>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanBothUnwrappingCoGroupOperator
 
PlanFilterOperator<T> - Class in org.apache.flink.api.java.operators.translation
 
PlanFilterOperator(FilterFunction<T>, String, TypeInformation<T>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanFilterOperator
 
PlanFilterOperator.FlatMapFilter<T> - Class in org.apache.flink.api.java.operators.translation
 
PlanGenerator - Class in 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) - Constructor for class org.apache.flink.api.java.utils.PlanGenerator
 
PlanLeftUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in 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>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanLeftUnwrappingCoGroupOperator
 
PlanProjectOperator<T,R extends org.apache.flink.api.java.tuple.Tuple> - Class in 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) - Constructor for class org.apache.flink.api.java.operators.translation.PlanProjectOperator
 
PlanRightUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in 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>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanRightUnwrappingCoGroupOperator
 
PlanUnwrappingGroupCombineOperator<IN,OUT,K> - Class in 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>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingGroupCombineOperator
 
PlanUnwrappingReduceGroupOperator<IN,OUT,K> - Class in 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) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator
 
PlanUnwrappingReduceOperator<T,K> - Class in 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>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceOperator
 
PlanUnwrappingSortedGroupCombineOperator<IN,OUT,K1,K2> - Class in 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>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedGroupCombineOperator
 
PlanUnwrappingSortedReduceGroupOperator<IN,OUT,K1,K2> - Class in 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) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator
 
PoissonSampler<T> - Class in org.apache.flink.api.java.sampling
A sampler implementation based on the Poisson Distribution.
PoissonSampler(double, long) - Constructor for class org.apache.flink.api.java.sampling.PoissonSampler
Create a poisson sampler which can sample elements with replacement.
PoissonSampler(double) - Constructor for class org.apache.flink.api.java.sampling.PoissonSampler
Create a poisson sampler which can sample elements with replacement.
PojoCsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
Input format that reads csv into POJOs.
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[], int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[], int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[], boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[], boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
pojoType(Class<T>, String...) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Configures the reader to read the CSV data and parse it to the given type.
preferredResources - Variable in class org.apache.flink.api.java.operators.Operator
Deprecated.
 
PrimitiveInputFormat<OT> - Class in org.apache.flink.api.java.io
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
Deprecated.
 
PrimitiveInputFormat(Path, String, Class<OT>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
Deprecated.
 
print() - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Prints the elements in a DataSet to the standard output stream System.out of the JVM that calls the print() method.
print(String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
PrintingOutputFormat<T> - Class in org.apache.flink.api.java.io
Deprecated.
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() - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
Deprecated.
Instantiates a printing output format that prints to standard out.
PrintingOutputFormat(boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
Deprecated.
Instantiates a printing output format that prints to standard out.
PrintingOutputFormat(String, boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
Deprecated.
Instantiates a printing output format that prints to standard out with a prefixed message.
printOnTaskManager(String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a DataSet to the standard output streams (stdout) of the TaskManagers that execute the program (or more specifically, the data sink operators).
printToErr() - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Prints the elements in a DataSet to the standard error stream System.err of the JVM that calls the print() method.
printToErr(String) - Method in class org.apache.flink.api.java.DataSet
project(int...) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Applies a Project transformation on a Tuple DataSet.
ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
 
ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperator.CrossProjection<I1, I2>, CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
 
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Continues a ProjectCross transformation and adds fields of the first cross input.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Deprecated.
Initiates a ProjectCross transformation and projects the first cross input.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
Continues a ProjectCross transformation and adds fields of the first cross input to the projection.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Deprecated.
Applies a ProjectJoin transformation and projects the first join input
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
Continues a ProjectJoin transformation and adds fields of the first join input to the projection.
Projection(DataSet<T>, int[]) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
 
ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
 
ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>, JoinOperator.JoinProjection<I1, I2>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
 
ProjectOperator<IN,OUT extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.operators
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator
Deprecated.
 
ProjectOperator.Projection<T> - Class in org.apache.flink.api.java.operators
Deprecated.
A projection of DataSet.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Continues a ProjectCross transformation and adds fields of the second cross input.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Deprecated.
Initiates a ProjectCross transformation and projects the second cross input.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
Continues a ProjectCross transformation and adds fields of the second cross input to the projection.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Deprecated.
Applies a ProjectJoin transformation and projects the second join input
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
Continues a ProjectJoin transformation and adds fields of the second join input to the projection.
projectTuple1() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple1() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple10() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple10() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple11() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple11() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple12() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple12() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple13() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple13() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple14() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple14() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple15() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple15() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple16() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple16() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple17() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple17() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple18() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple18() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple19() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple19() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple2() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple2() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple20() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple20() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple21() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple21() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple22() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple22() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple23() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple23() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple24() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple24() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple25() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple25() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple3() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple3() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple4() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple4() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple5() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple5() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple6() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple6() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple7() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple7() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple8() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple8() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTuple9() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple9() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Projects a Tuple DataSet to the previously selected fields.
projectTupleX() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Deprecated.
Chooses a projectTupleX according to the length of CrossOperator.CrossProjection.fieldIndexes.
projectTupleX() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Deprecated.
Chooses a projectTupleX according to the length of ProjectOperator.Projection.fieldIndexes.

Q

quoteCharacter - Variable in class org.apache.flink.api.java.io.CsvReader
Deprecated.
 

R

RandomSampler<T> - Class in org.apache.flink.api.java.sampling
A data sample is a set of data selected from a statistical population by a defined procedure.
RandomSampler() - Constructor for class org.apache.flink.api.java.sampling.RandomSampler
 
reachedEnd() - Method in class org.apache.flink.api.java.io.CollectionInputFormat
Deprecated.
 
reachedEnd() - Method in class org.apache.flink.api.java.io.IteratorInputFormat
Deprecated.
 
reachedEnd() - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
Deprecated.
 
readCsvFile(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a CSV reader to read a comma separated value (CSV) file.
readDualForwardAnnotations(Class<?>) - Static method in class org.apache.flink.api.java.functions.FunctionAnnotation
Deprecated.
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) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
 
readFileOfPrimitives(String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet that represents the primitive type produced by reading the given file line wise.
readFileOfPrimitives(String, String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet that represents the primitive type produced by reading the given file in delimited way.
readRecord(OUT, byte[], int, int) - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
readRecord(OT, byte[], int, int) - Method in class org.apache.flink.api.java.io.PrimitiveInputFormat
Deprecated.
 
readRecord(String, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextInputFormat
Deprecated.
 
readRecord(StringValue, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
Deprecated.
 
readSingleForwardAnnotations(Class<?>) - Static method in class org.apache.flink.api.java.functions.FunctionAnnotation
Deprecated.
Reads the annotations of a user defined function with one input and returns semantic properties according to the forwarded fields annotated.
readTextFile(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet that represents the Strings produced by reading the given file line wise.
readTextFile(String, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet that represents the Strings produced by reading the given file line wise.
readTextFileWithValue(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet that represents the Strings produced by reading the given file line wise.
readTextFileWithValue(String, String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Creates a DataSet that represents the Strings produced by reading the given file line wise.
rebalance() - Method in class org.apache.flink.api.java.DataSet
Deprecated.
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>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Applies a Reduce transformation on a non-grouped DataSet.
reduce(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.FirstReducer
 
reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.GroupReduceIterator
Deprecated.
 
reduce(Iterable<IntermediateSampleData<T>>, Collector<T>) - Method in class org.apache.flink.api.java.functions.SampleInCoordinator
 
reduce(T, T) - Method in class org.apache.flink.api.java.functions.SelectByMaxFunction
Reduce implementation, returns bigger tuple or value1 if both tuples are equal.
reduce(T, T) - Method in class org.apache.flink.api.java.functions.SelectByMinFunction
Reduce implementation, returns smaller tuple or value1 if both tuples are equal.
reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
 
reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
 
reduce(ReduceFunction<T>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Applies a Reduce transformation on a grouped DataSet.
reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Applies a GroupReduce transformation on a non-grouped DataSet.
reduceGroup(Iterable<IN>) - Method in class org.apache.flink.api.java.functions.GroupReduceIterator
Deprecated.
 
reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
Applies a GroupReduce transformation on a grouped and sorted DataSet.
reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Applies a GroupReduce transformation on a grouped DataSet.
ReduceOperator<IN> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
Deprecated.
This is the case for a reduce-all case (in contrast to the reduce-per-group case).
ReduceOperator(Grouping<IN>, ReduceFunction<IN>, String) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
Deprecated.
 
registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Registers an Aggregator for the iteration together with a ConvergenceCriterion.
registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Deprecated.
Registers an Aggregator for the iteration together with a ConvergenceCriterion.
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Registers an Aggregator for the iteration.
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Deprecated.
Registers an Aggregator for the iteration.
registerCachedFile(String, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Registers a file at the distributed cache under the given name.
registerJobListener(JobListener) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Register a JobListener in this environment.
registerSerializers(Kryo) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.FlinkChillPackageRegistrar
 
registerType(Class<?>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Registers the given type with the serialization stack.
registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Registers the given type with a Kryo Serializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer.
RemoteEnvironment - Class in org.apache.flink.api.java
Deprecated.
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...) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
Deprecated.
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteEnvironment(String, int, Configuration, String[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
Deprecated.
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
Deprecated.
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteEnvironmentConfigUtils - Class in org.apache.flink.api.java
A set of tools used by batch and streaming remote environments when preparing their configurations.
RemoteEnvironmentConfigUtils() - Constructor for class org.apache.flink.api.java.RemoteEnvironmentConfigUtils
 
remove() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
remove() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
ReservoirSamplerWithoutReplacement<T> - Class in 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) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
Create a new sampler with reservoir size and a supplied random number generator.
ReservoirSamplerWithoutReplacement(int) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
Create a new sampler with reservoir size and a default random number generator.
ReservoirSamplerWithoutReplacement(int, long) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
Create a new sampler with reservoir size and the seed for random number generator.
ReservoirSamplerWithReplacement<T> - Class in 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) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
Create a sampler with fixed sample size and default random number generator.
ReservoirSamplerWithReplacement(int, long) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
Create a sampler with fixed sample size and random number generator seed.
ReservoirSamplerWithReplacement(int, Random) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
Create a sampler with fixed sample size and random number generator.
resetContextEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Un-sets the context environment factory.
resetLocal() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
resolveFactory(ThreadLocal<T>, T) - Static method in class org.apache.flink.api.java.Utils
Resolves the given factories.
result() - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
Provide the final result of the aggregation.
result() - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
returns(Class<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
Adds a type information hint about the return type of this operator.
returns(TypeHint<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
Adds a type information hint about the return type of this operator.
returns(TypeInformation<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
Adds a type information hint about the return type of this operator.
returns(Class<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
Adds a type information hint about the return type of this operator.
returns(TypeHint<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
Adds a type information hint about the return type of this operator.
returns(TypeInformation<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
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>> - Class 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) - Constructor for class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
 
rightOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Right Outer Join transformation.
rightOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Initiates a Right Outer Join transformation.
RNG - Static variable in class org.apache.flink.api.java.Utils
 
RowCsvInputFormat - Class in org.apache.flink.api.java.io
Deprecated.
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) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
Deprecated.
 
RowCsvInputFormat(Path, TypeInformation[], String, String, int[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
Deprecated.
 
RowCsvInputFormat(Path, TypeInformation[], String, String) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
Deprecated.
 
RowCsvInputFormat(Path, TypeInformation[], int[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
Deprecated.
 
RowCsvInputFormat(Path, TypeInformation[], boolean) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
Deprecated.
 
RowCsvInputFormat(Path, TypeInformation[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
Deprecated.
 
runOperation(CustomUnaryOperation<T, X>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Runs a CustomUnaryOperation on the data set.

S

sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.BernoulliSampler
Sample the input elements, for each input element, take a Bernoulli trail for sampling.
sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
Combine the first phase and second phase in sequence, implemented for test purpose only.
sample(Iterator<T>) - Method in class 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>) - Method in class 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) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Generate a sample of DataSet by the probability fraction of each element.
sample(DataSet<T>, boolean, double, long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Generate a sample of DataSet by the probability fraction of each element.
SampleInCoordinator<T> - Class in 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) - Constructor for class org.apache.flink.api.java.functions.SampleInCoordinator
Create a function instance of SampleInCoordinator.
sampleInCoordinator(Iterator<IntermediateSampleData<T>>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
Sample algorithm for the second phase.
SampleInPartition<T> - Class in 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) - Constructor for class org.apache.flink.api.java.functions.SampleInPartition
Create a function instance of SampleInPartition.
sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
Sample algorithm for the first phase.
sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
 
sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
 
SampleWithFraction<T> - Class in 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) - Constructor for class org.apache.flink.api.java.functions.SampleWithFraction
Create a function instance of SampleWithFraction.
sampleWithSize(DataSet<T>, boolean, int) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Generate a sample of DataSet which contains fixed size elements.
sampleWithSize(DataSet<T>, boolean, int, long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Generate a sample of DataSet which contains fixed size elements.
SelectByMaxFunction<T extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.functions
Function that enables selection by maximal value of a field.
SelectByMaxFunction(TupleTypeInfo<T>, int...) - Constructor for class org.apache.flink.api.java.functions.SelectByMaxFunction
Constructor which is overwriting the default constructor.
SelectByMinFunction<T extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.functions
Function that enables selection by minimal value of a field.
SelectByMinFunction(TupleTypeInfo<T>, int...) - Constructor for class org.apache.flink.api.java.functions.SelectByMinFunction
Constructor which is overwriting the default constructor.
SemanticPropUtil - Class in org.apache.flink.api.java.functions
Utility class that contains helper methods to work with SemanticProperties.
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
Deprecated.
 
set(Iterator<Tuple3<K1, K2, T>>) - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
set(Collector<Tuple3<K1, K2, IN>>) - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
set(Iterator<Tuple2<K, T>>) - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
set(Collector<Tuple2<K, IN>>) - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
setAllowNullValues(boolean) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
Configures the format to either allow null values (writing an empty field), or to throw an exception when encountering a null field.
setAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
setAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
setCharset(String) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Sets the charset of the reader.
setCharsetName(String) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
Sets the charset with which the CSV strings are written to the file.
setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextInputFormat
Deprecated.
 
setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextOutputFormat
Deprecated.
 
setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
Deprecated.
 
setCombinable(boolean) - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
Deprecated.
 
setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.java.operators.DistinctOperator
Deprecated.
Sets the strategy to use for the combine phase of the reduce.
setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.java.operators.ReduceOperator
Deprecated.
Sets the strategy to use for the combine phase of the reduce.
setDefaultLocalParallelism(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Sets the default parallelism that will be used for the local execution environment created by ExecutionEnvironment.createLocalEnvironment().
setInput(DataSet<IN>) - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
Deprecated.
 
setInput(DataSet<IN>) - Method in class org.apache.flink.api.java.operators.NoOpOperator
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
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) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
Deprecated.
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
Deprecated.
 
setJarURLsToConfig(String[], Configuration) - Static method in class org.apache.flink.api.java.RemoteEnvironmentConfigUtils
 
setJobManagerAddressToConfig(String, int, Configuration) - Static method in class org.apache.flink.api.java.RemoteEnvironmentConfigUtils
 
setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
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) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Sets the parallelism for operations executed through this environment.
setParallelism(int) - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
Sets the parallelism for this data sink.
setParallelism(int) - Method in class org.apache.flink.api.java.operators.Operator
Deprecated.
Sets the parallelism for this operator.
setParallelism(int) - Method in class org.apache.flink.api.java.operators.UnionOperator
Deprecated.
 
setQuoteStrings(boolean) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
Configures whether the output format should quote string values.
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Sets the restart strategy configuration.
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
setSemanticProperties(SingleInputSemanticProperties) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
Sets the semantic properties for the user-defined function (UDF).
setSemanticProperties(DualInputSemanticProperties) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
Sets the semantic properties for the user-defined function (UDF).
setSerializer(TypeSerializer<T>) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
Deprecated.
 
setSkipInvalidLines(boolean) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
Deprecated.
 
setSolutionSetUnManaged(boolean) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Deprecated.
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or unmanaged memory (objects on heap).
ShortSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Short types.
ShortSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
ShortSummaryAggregator.MaxShortAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for max operation.
ShortSummaryAggregator.MinShortAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for min operation.
ShortSummaryAggregator.SumShortAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator for sum operation.
ShortValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
 
SingleInputOperator<IN,OUT,O extends SingleInputOperator<IN,OUT,O>> - Class in org.apache.flink.api.java.operators
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.SingleInputOperator
Deprecated.
 
SingleInputUdfOperator<IN,OUT,O extends SingleInputUdfOperator<IN,OUT,O>> - Class in org.apache.flink.api.java.operators
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
Creates a new operators with the given data set as input.
skipFirstLineAsHeader - Variable in class org.apache.flink.api.java.io.CsvReader
Deprecated.
 
SortedGrouping<T> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
 
SortedGrouping(DataSet<T>, Keys<T>, String, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
 
SortedGrouping(DataSet<T>, Keys<T>, Keys.SelectorFunctionKeys<T, K>, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
 
sortFirstGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Deprecated.
Sorts Tuple elements within a group in the first input on the specified field in the specified Order.
sortFirstGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Deprecated.
Sorts Pojo or Tuple elements within a group in the first input on the specified field in the specified Order.
sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
Sorts Tuple elements within a group on the specified field in the specified Order.
sortGroup(String, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
Sorts Tuple or POJO elements within a group on the specified field in the specified Order.
sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Sorts Tuple elements within a group on the specified field in the specified Order.
sortGroup(String, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Sorts Pojos within a group on the specified field in the specified Order.
sortGroup(KeySelector<T, K>, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Sorts elements within a group on a key extracted by the specified KeySelector in the specified Order.
sortLocalOutput(int, Order) - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
sortLocalOutput(String, Order) - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
sortPartition(int, Order) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Locally sorts the partitions of the DataSet on the specified field in the specified order.
sortPartition(String, Order) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Locally sorts the partitions of the DataSet on the specified field in the specified order.
sortPartition(KeySelector<T, K>, Order) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Locally sorts the partitions of the DataSet on the extracted key in the specified order.
sortPartition(int, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Deprecated.
Appends an additional sort order with the specified field in the specified order to the local partition sorting of the DataSet.
sortPartition(String, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Deprecated.
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) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Deprecated.
 
SortPartitionOperator<T> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
Deprecated.
 
SortPartitionOperator(DataSet<T>, String, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
Deprecated.
 
SortPartitionOperator(DataSet<T>, Keys.SelectorFunctionKeys<T, K>, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
Deprecated.
 
sortSecondGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Deprecated.
Sorts Tuple elements within a group in the second input on the specified field in the specified Order.
sortSecondGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Deprecated.
Sorts Pojo or Tuple elements within a group in the second input on the specified field in the specified Order.
SourcePartitionerMarker(String) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
Deprecated.
 
SplitDataProperties<T> - Class in org.apache.flink.api.java.io
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
Creates SplitDataProperties for the given data types.
SplitDataProperties(DataSource<T>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
Creates SplitDataProperties for the given data types.
SplitDataProperties.SourcePartitionerMarker<T> - Class in org.apache.flink.api.java.io
Deprecated.
A custom partitioner to mark compatible split partitionings.
splitsGroupedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
Defines that the data within an input split is grouped on the fields defined by the field positions.
splitsGroupedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
Defines that the data within an input split is grouped on the fields defined by the field expressions.
splitsOrderedBy(int[], Order[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
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[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
Defines that the data within an input split is sorted on the fields defined by the field expressions in the specified orders.
splitsPartitionedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
Defines that data is partitioned across input splits on the fields defined by field positions.
splitsPartitionedBy(String, int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
Defines that data is partitioned using a specific partitioning method across input splits on the fields defined by field positions.
splitsPartitionedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
Defines that data is partitioned across input splits on the fields defined by field expressions.
splitsPartitionedBy(String, String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Deprecated.
Defines that data is partitioned using an identifiable method across input splits on the fields defined by field expressions.
StringColumnSummary - Class in org.apache.flink.api.java.summarize
Deprecated.
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) - Constructor for class org.apache.flink.api.java.summarize.StringColumnSummary
Deprecated.
 
StringSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that calculates statistics for String values.
StringSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
StringValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
 
sum(int) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Syntactic sugar for aggregate (SUM, field).
sum(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Syntactic sugar for aggregate (SUM, field).
SumAggregationFunction<T> - Class in org.apache.flink.api.java.aggregation
Definitions of sum functions for different numerical types.
SumAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction
 
SumAggregationFunction.SumAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
SumAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
 
SumDoubleAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
SumFloatAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
SumIntegerAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
summarize(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Summarize a DataSet of Tuples by collecting single pass statistics for all columns.
SummaryAggregatorFactory - Class in org.apache.flink.api.java.summarize.aggregation
Factory for creating Summary Aggregators.
SummaryAggregatorFactory() - Constructor for class org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
 
SumShortAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
supportsMultiPaths() - Method in class org.apache.flink.api.java.io.TextInputFormat
Deprecated.
 
supportsMultiPaths() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
Deprecated.
 

T

TextInputFormat - Class in org.apache.flink.api.java.io
Deprecated.
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) - Constructor for class org.apache.flink.api.java.io.TextInputFormat
Deprecated.
 
TextOutputFormat<T> - Class in org.apache.flink.api.java.io
Deprecated.
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) - Constructor for class org.apache.flink.api.java.io.TextOutputFormat
Deprecated.
 
TextOutputFormat(Path, String) - Constructor for class org.apache.flink.api.java.io.TextOutputFormat
Deprecated.
 
TextOutputFormat.TextFormatter<IN> - Interface in org.apache.flink.api.java.io
Deprecated.
Formatter that transforms values into their String representations.
TextValueInputFormat - Class in org.apache.flink.api.java.io
Deprecated.
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) - Constructor for class org.apache.flink.api.java.io.TextValueInputFormat
Deprecated.
 
toBooleanMask(int[]) - Static method in class org.apache.flink.api.java.io.CsvInputFormat
 
toMap() - Method in class org.apache.flink.api.java.utils.AbstractParameterTool
 
toMap() - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
 
toMap() - Method in class org.apache.flink.api.java.utils.ParameterTool
 
toMultiMap() - Method in class org.apache.flink.api.java.utils.MultipleParameterTool
Return MultiMap of all the parameters processed by MultipleParameterTool.
toString() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction
 
toString() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction
 
toString() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction
 
toString() - Method in class org.apache.flink.api.java.io.CollectionInputFormat
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
toString() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.io.TextInputFormat
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.io.TextOutputFormat
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.LocalEnvironment
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.RemoteEnvironment
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.AggregateOperator
Deprecated.
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Deprecated.
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CrossOperator
Deprecated.
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
 
translateToDataFlow() - Method in class org.apache.flink.api.java.operators.DataSource
Deprecated.
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DistinctOperator
Deprecated.
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.FilterOperator
Deprecated.
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.FlatMapOperator
Deprecated.
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
Deprecated.
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
Deprecated.
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Deprecated.
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapOperator
Deprecated.
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
Deprecated.
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.PartitionOperator
Deprecated.
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ProjectOperator
Deprecated.
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ReduceOperator
Deprecated.
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.SingleInputOperator
Deprecated.
Translates this operation to a data flow operator of the common data flow API.
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Deprecated.
 
translateToDataFlow(Operator<IN1>, Operator<IN2>) - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Deprecated.
Translates this java API operator into a common API operator with two inputs.
translateToDataFlow(Operator<T>, Operator<T>) - Method in class org.apache.flink.api.java.operators.UnionOperator
Deprecated.
Returns the BinaryNodeTranslation of the Union.
translateToPlan(List<DataSink<?>>, String) - Method in class org.apache.flink.api.java.operators.OperatorTranslation
 
Tuple3UnwrappingIterator<T,K1,K2> - Class in org.apache.flink.api.java.operators.translation
An iterator that reads 3-tuples (groupKey, sortKey, value) and returns only the values (third field).
Tuple3UnwrappingIterator() - Constructor for class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
Tuple3WrappingCollector<IN,K1,K2> - Class in 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>) - Constructor for class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
TupleCsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
Input format that reads csv into tuples.
TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleLeftUnwrappingJoiner<I1,I2,OUT,K> - Class in 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>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleLeftUnwrappingJoiner
 
TupleRightUnwrappingJoiner<I1,I2,OUT,K> - Class in 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>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleRightUnwrappingJoiner
 
TupleSummaryAggregator<R extends org.apache.flink.api.java.tuple.Tuple> - Class in 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[]) - Constructor for class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
tupleType(Class<T>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Configures the reader to read the CSV data and parse it to the given type.
TupleUnwrappingIterator<T,K> - Class in org.apache.flink.api.java.operators.translation
An iterator that reads 2-tuples (key value pairs) and returns only the values (second field).
TupleUnwrappingIterator() - Constructor for class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
TupleUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
Joiner that unwraps both values before applying the join operation.
TupleUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleUnwrappingJoiner
 
TupleWrappingCollector<IN,K> - Class in 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>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
TwoInputOperator<IN1,IN2,OUT,O extends TwoInputOperator<IN1,IN2,OUT,O>> - Class in org.apache.flink.api.java.operators
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.TwoInputOperator
Deprecated.
 
TwoInputUdfOperator<IN1,IN2,OUT,O extends TwoInputUdfOperator<IN1,IN2,OUT,O>> - Class in org.apache.flink.api.java.operators
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
Creates a new operators with the two given data sets as inputs.
TwoKeyExtractingMapper<T,K1,K2> - Class in org.apache.flink.api.java.operators.translation
Mapper that extracts two keys of a value.
TwoKeyExtractingMapper(KeySelector<T, K1>, KeySelector<T, K2>) - Constructor for class org.apache.flink.api.java.operators.translation.TwoKeyExtractingMapper
 
types(Class<T0>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
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>) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
Specifies the types for the CSV fields.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
Deprecated method only kept for compatibility.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
Deprecated method only kept for compatibility.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.ProjectOperator
Deprecated.
Deprecated method only kept for compatibility.
TypeSerializerInputFormat<T> - Class in org.apache.flink.api.java.io
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.io.TypeSerializerInputFormat
Deprecated.
 
TypeSerializerOutputFormat<T> - Class in org.apache.flink.api.java.io
Deprecated.
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() - Constructor for class org.apache.flink.api.java.io.TypeSerializerOutputFormat
Deprecated.
 

U

UdfOperator<O extends UdfOperator<O>> - Interface in org.apache.flink.api.java.operators
Deprecated.
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<?>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
udfWithForwardedFieldsFirstAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
udfWithForwardedFieldsFirstAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
udfWithForwardedFieldsSecondAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
Deprecated.
 
udfWithForwardedFieldsSecondAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
union(DataSet<T>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Creates a union of this DataSet with an other DataSet.
UnionOperator<T> - Class in org.apache.flink.api.java.operators
Deprecated.
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) - Constructor for class org.apache.flink.api.java.operators.UnionOperator
Deprecated.
Create an operator that produces the union of the two given data sets.
unrequestedParameters - Variable in class org.apache.flink.api.java.utils.AbstractParameterTool
 
UnsortedGrouping<T> - Class in org.apache.flink.api.java.operators
Deprecated.
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>) - Constructor for class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
 
UnsupportedAggregationTypeException - Exception in org.apache.flink.api.java.aggregation
Deprecated.
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) - Constructor for exception org.apache.flink.api.java.aggregation.UnsupportedAggregationTypeException
Deprecated.
 
useKeySelector() - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Deprecated.
Returns whether using key selector or not.
Utils - Class in org.apache.flink.api.java
Utility class that contains helper methods to work with Java APIs.
Utils.ChecksumHashCode - Class in org.apache.flink.api.java
Accumulator of Utils.ChecksumHashCode.
Utils.ChecksumHashCodeHelper<T> - Class in org.apache.flink.api.java
RichOutputFormat for Utils.ChecksumHashCode.
Utils.CollectHelper<T> - Class in 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> - Class in 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) - Static method in class org.apache.flink.api.java.RemoteEnvironmentConfigUtils
 
value() - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
The value of the sum.
valueOf(String) - Static method in enum org.apache.flink.api.java.aggregation.Aggregations
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.operators.join.JoinType
Deprecated.
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.flink.api.java.aggregation.Aggregations
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.operators.join.JoinType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
ValueSummaryAggregator<VT extends org.apache.flink.types.Value,PT,R,A extends Aggregator<PT,R>> - Class in org.apache.flink.api.java.summarize.aggregation
This is a generic Aggregator for Value types like StringValue, DoubleValue, etc.
ValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
ValueSummaryAggregator.BooleanValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
ValueSummaryAggregator.DoubleValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
ValueSummaryAggregator.FloatValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
ValueSummaryAggregator.IntegerValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
ValueSummaryAggregator.LongValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
ValueSummaryAggregator.ShortValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
ValueSummaryAggregator.StringValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation

W

where(int...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Deprecated.
Continues a CoGroup transformation.
where(String...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Deprecated.
Continues a CoGroup transformation.
where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Deprecated.
Continues a CoGroup transformation and defines a KeySelector function for the first co-grouped DataSet.
where(int...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
Continues a Join transformation.
where(String...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
Continues a Join transformation.
where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Deprecated.
Continues a Join transformation and defines a KeySelector function for the first join DataSet.
where(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Deprecated.
Continues a Join transformation.
where(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Deprecated.
Continues a Join transformation.
where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Deprecated.
Continues a Join transformation and defines a KeySelector function for the first join DataSet.
with(CoGroupFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Deprecated.
Finalizes a CoGroup transformation by applying a RichCoGroupFunction to groups of elements with identical keys.
with(CrossFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Deprecated.
Finalizes a Cross transformation by applying a CrossFunction to each pair of crossed elements.
with(JoinFunction<I1, I2, R>) - Method in interface org.apache.flink.api.java.operators.join.JoinFunctionAssigner
Deprecated.
 
with(FlatJoinFunction<I1, I2, R>) - Method in interface org.apache.flink.api.java.operators.join.JoinFunctionAssigner
Deprecated.
 
with(FlatJoinFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Deprecated.
Finalizes a Join transformation by applying a RichFlatJoinFunction to each pair of joined elements.
with(JoinFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Deprecated.
 
withBroadcastSet(DataSet<?>, String) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
withBroadcastSet(DataSet<?>, String) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
withBroadcastSet(DataSet<?>, String) - Method in interface org.apache.flink.api.java.operators.UdfOperator
Deprecated.
Adds a certain data set as a broadcast set to this operator.
withForwardedFields(String...) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
Adds semantic information about forwarded fields of the user-defined function.
withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
 
withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
 
withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
Adds semantic information about forwarded fields of the first input of the user-defined function.
withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
 
withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
 
withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
Adds semantic information about forwarded fields of the second input of the user-defined function.
withOrders(Order...) - Method in class org.apache.flink.api.java.operators.PartitionOperator
Deprecated.
Sets the order of keys for range partitioning.
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
Pass a configuration to the OutputFormat.
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.DataSource
Deprecated.
Pass a configuration to the InputFormat.
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Deprecated.
 
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Deprecated.
 
withParameters(Configuration) - Method in interface org.apache.flink.api.java.operators.UdfOperator
Deprecated.
Sets the configuration parameters for the UDF.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Deprecated.
Sets a custom partitioner for the CoGroup operation.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Deprecated.
Sets a custom partitioner for the CoGroup operation.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator
Deprecated.
Sets a custom partitioner for this join.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Deprecated.
Uses a custom partitioner for the grouping.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Deprecated.
Uses a custom partitioner for the grouping.
wrappedFunction - Variable in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
WrappingFlatJoinFunction(JoinFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin.WrappingFlatJoinFunction
Deprecated.
 
WrappingFunction<T extends org.apache.flink.api.common.functions.Function> - Class in org.apache.flink.api.java.operators.translation
Wrapper around Function.
WrappingFunction(T) - Constructor for class org.apache.flink.api.java.operators.translation.WrappingFunction
 
write(FileOutputFormat<T>, String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a DataSet using a FileOutputFormat to a specified location.
write(FileOutputFormat<T>, String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a DataSet using a FileOutputFormat to a specified location.
writeAsCsv(String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a Tuple DataSet as CSV file(s) to the specified location.
writeAsCsv(String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a Tuple DataSet as CSV file(s) to the specified location.
writeAsCsv(String, String, String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
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) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a Tuple DataSet as CSV file(s) to the specified location with the specified field and line delimiters.
writeAsFormattedText(String, TextOutputFormat.TextFormatter<T>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a DataSet as text file(s) to the specified location.
writeAsFormattedText(String, FileSystem.WriteMode, TextOutputFormat.TextFormatter<T>) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a DataSet as text file(s) to the specified location.
writeAsText(String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a DataSet as text file(s) to the specified location.
writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
Writes a DataSet as text file(s) to the specified location.
writeRecord(T) - Method in class org.apache.flink.api.java.io.BlockingShuffleOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Deprecated.
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
Deprecated.
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
Deprecated.
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
Deprecated.
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.TextOutputFormat
Deprecated.
 
writeRecord(T) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
writeRecord(T) - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
writeRecord(T) - Method in class org.apache.flink.api.java.Utils.CountHelper
 

Z

ZERO - Static variable in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
 
zipWithIndex(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
Method that assigns a unique Long value to all elements in the input data set.
zipWithUniqueId(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
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 
Skip navigation links

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