- canContainFields() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- canContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- canNotContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- checkCollection(Collection<X>, Class<X>) - Static method in class org.apache.flink.api.java.io.CollectionInputFormat
-
- checkJoinKeyFields(int[]) - Method in class org.apache.flink.api.java.operators.DeltaIteration.SolutionSetPlaceHolder
-
- checkSameExecutionContext(DataSet<?>, DataSet<?>) - Static method in class org.apache.flink.api.java.DataSet
-
- 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
-
- ChecksumHashCodeHelper(String) - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
-
- choices(String...) - Method in class org.apache.flink.api.java.utils.Option
-
Restrict the list of possible values of the parameter.
- clean(Object, boolean) - Static method in class org.apache.flink.api.java.ClosureCleaner
-
Tries to clean the closure of the given object, if the object is a non-static inner
class.
- clean(F) - Method in class org.apache.flink.api.java.DataSet
-
- clearContainerMappingMarkedFields() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- clientConfiguration - Variable in class org.apache.flink.api.java.RemoteEnvironment
-
The configuration used by the client that connects to the cluster.
- clone() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- clone() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- close() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
- close() - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
-
- close() - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
-
- close() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- 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
-
Closes the delta iteration.
- closeWith(DataSet<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
Closes the iteration.
- closeWith(DataSet<T>, DataSet<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
Closes the iteration and specifies a termination criterion.
- ClosureCleaner - Class in org.apache.flink.api.java
-
The closure cleaner is a utility that tries to truncate the closure (enclosing instance)
of non-static inner classes (created for inline transformation functions).
- ClosureCleaner() - Constructor for class org.apache.flink.api.java.ClosureCleaner
-
- CodeAnalyzerException - Exception in org.apache.flink.api.java.sca
-
Exception that is thrown if code analysis could not run properly.
- CodeAnalyzerException() - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
-
- CodeAnalyzerException(String, Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
-
- CodeAnalyzerException(String) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
-
- CodeAnalyzerException(Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
-
- CodeErrorException - Exception in org.apache.flink.api.java.sca
-
Exception that is thrown if code errors could be found during analysis.
- CodeErrorException() - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
-
- CodeErrorException(String, Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
-
- CodeErrorException(String) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
-
- CodeErrorException(Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
-
- coGroup(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a CoGroup transformation.
- CoGroupOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
-
A
DataSet
that is the result of a CoGroup transformation.
- CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
-
- CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, List<Pair<Integer, Order>>, List<Pair<Integer, Order>>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
-
- CoGroupOperator.CoGroupOperatorSets<I1,I2> - Class in org.apache.flink.api.java.operators
-
Intermediate step of a CoGroup transformation.
- CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate - Class in org.apache.flink.api.java.operators
-
Intermediate step of a CoGroup transformation.
- CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction - Class in org.apache.flink.api.java.operators
-
- CoGroupOperatorSets(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
-
- 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
-
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
-
Version of
ExecutionEnvironment
that allows serial, local, collection-based executions of Flink programs.
- CollectionEnvironment() - Constructor for class org.apache.flink.api.java.CollectionEnvironment
-
- CollectionInputFormat<T> - Class in org.apache.flink.api.java.io
-
An input format that returns objects from a collection.
- CollectionInputFormat(Collection<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.java.io.CollectionInputFormat
-
- ColumnSummary - Class in org.apache.flink.api.java.summarize
-
Summary for a column of values.
- ColumnSummary() - Constructor for class org.apache.flink.api.java.summarize.ColumnSummary
-
- 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
-
Applies a GroupCombineFunction on a non-grouped
DataSet
.
- combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
Applies a GroupCombineFunction on a grouped
DataSet
.
- combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Applies a GroupCombineFunction on a grouped
DataSet
.
- CombineToGroupCombineWrapper<IN,OUT,F extends org.apache.flink.api.common.functions.CombineFunction<IN,IN> & org.apache.flink.api.common.functions.GroupReduceFunction<IN,OUT>> - 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
-
- 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(Configuration) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- 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
-
- containerContains(String) - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- containerHasReferences() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- containsNonNull() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
True if this column contains any non-null values.
- containsNull() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
True if this column contains any null values.
- context - Variable in class org.apache.flink.api.java.DataSet
-
- convertTypeInfoToTaggedValue(TaggedValue.Input, TypeInformation<?>, String, List<CompositeType.FlatFieldDescriptor>, int[]) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- copy() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- copy(Type) - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- copyOperation(AbstractInsnNode, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
-
- count() - Method in class org.apache.flink.api.java.DataSet
-
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
-
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
-
- createDefaultJoin(Keys<I2>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
-
- createDefaultMask(int) - Static method in class org.apache.flink.api.java.io.CsvInputFormat
-
- createExecutionEnvironment() - Method in interface org.apache.flink.api.java.ExecutionEnvironmentFactory
-
Creates an ExecutionEnvironment from this factory.
- createInput(InputFormat<X, ?>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Generic method to create an input
DataSet
with in
InputFormat
.
- createInput(InputFormat<X, ?>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
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
-
- createLocalEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createLocalEnvironment(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createLocalEnvironment(Configuration) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
LocalEnvironment
for local program execution that also starts the
web monitoring UI.
- createProgramPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates the program's Plan
.
- createProgramPlan(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates the program's Plan
.
- createProgramPlan(String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
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
-
- createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createResult() - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
-
- 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
-
Initiates a Cross transformation.
- cross(T1, T2) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-
- CrossOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
-
A
DataSet
that is the result of a Cross transformation.
- CrossOperator(DataSet<I1>, DataSet<I2>, CrossFunction<I1, I2, OUT>, TypeInformation<OUT>, CrossOperatorBase.CrossHint, String) - Constructor for class org.apache.flink.api.java.operators.CrossOperator
-
- CrossOperator.CrossProjection<I1,I2> - Class in org.apache.flink.api.java.operators
-
- CrossOperator.DefaultCross<I1,I2> - Class in org.apache.flink.api.java.operators
-
A Cross transformation that wraps pairs of crossed elements into Tuple2
.
- CrossOperator.ProjectCross<I1,I2,OUT extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.operators
-
A Cross transformation that projects crossing elements or fields of crossing Tuples
into result Tuples
.
- CrossOperator.ProjectCrossFunction<T1,T2,R extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.operators
-
- CrossProjection(DataSet<I1>, DataSet<I2>, int[], int[], CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
- crossWithHuge(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Cross transformation.
- crossWithTiny(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
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
-
This is an OutputFormat to serialize Tuple
s to text.
- CsvOutputFormat(Path) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- CsvOutputFormat(Path, String) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- CsvOutputFormat(Path, String, String) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- CsvReader - Class in org.apache.flink.api.java.io
-
A builder class to instantiate a CSV parsing data source.
- CsvReader(Path, ExecutionEnvironment) - Constructor for class org.apache.flink.api.java.io.CsvReader
-
- CsvReader(String, ExecutionEnvironment) - Constructor for class org.apache.flink.api.java.io.CsvReader
-
- customPartitioner - Variable in class org.apache.flink.api.java.operators.Grouping
-
- CustomUnaryOperation<IN,OUT> - Interface in org.apache.flink.api.java.operators
-
- fieldDelimiter - Variable in class org.apache.flink.api.java.io.CsvReader
-
- fieldDelimiter(char) - Method in class org.apache.flink.api.java.io.CsvReader
-
- fieldDelimiter(String) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures the delimiter that separates the fields within a row.
- fields - Variable in class org.apache.flink.api.java.operators.ProjectOperator
-
- fillInType(TypeInformation<T>) - Method in class org.apache.flink.api.java.DataSet
-
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
-
- 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
-
Applies a Filter transformation on a
DataSet
.
- FilterOperator<T> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a "filter" function on a data set, and the
result data set produced by the function.
- FilterOperator(DataSet<T>, FilterFunction<T>, String) - Constructor for class org.apache.flink.api.java.operators.FilterOperator
-
- findMethodNode(String, Method) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- findMethodNode(String, String, String) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- first(int) - Method in class org.apache.flink.api.java.DataSet
-
Returns a new set containing the first n elements in this
DataSet
.
- first(int) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
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
-
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
-
Applies a FlatMap transformation on a
DataSet
.
- flatMap(IN) - Method in class org.apache.flink.api.java.functions.FlatMapIterator
-
The core method of the function.
- flatMap(IN, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.FlatMapIterator
-
- 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
-
A convenience variant of the RichFlatMapFunction
that returns elements through an iterator, rather then
through a collector.
- FlatMapIterator() - Constructor for class org.apache.flink.api.java.functions.FlatMapIterator
-
- FlatMapOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a "flatMap" function on a data set, and the
result data set produced by the function.
- FlatMapOperator(DataSet<IN>, TypeInformation<OUT>, FlatMapFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.FlatMapOperator
-
- 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
-
- FormattingMapper<T> - Class in org.apache.flink.api.java.functions
-
- 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.ParameterTool
-
- fromCollection(Collection<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a DataSet from the given non-empty collection.
- fromCollection(Collection<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a DataSet from the given non-empty collection.
- fromCollection(Iterator<X>, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a DataSet from the given iterator.
- fromCollection(Iterator<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a DataSet from the given iterator.
- fromElements(X...) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a new data set that contains the given elements.
- fromElements(Class<X>, X...) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
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
-
- fromParallelCollection(SplittableIterator<X>, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
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
-
Creates a new data set that contains elements in the iterator.
- fromPropertiesFile(String) - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fromPropertiesFile(File) - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fromPropertiesFile(InputStream) - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fromSystemProperties() - Static method in class org.apache.flink.api.java.utils.ParameterTool
-
- fullOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Full Outer Join transformation.
- fullOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Full Outer Join transformation.
- function - Variable in class org.apache.flink.api.java.operators.FilterOperator
-
- function - Variable in class org.apache.flink.api.java.operators.FlatMapOperator
-
- function - Variable in class org.apache.flink.api.java.operators.MapOperator
-
- function - Variable in class org.apache.flink.api.java.operators.MapPartitionOperator
-
- FunctionAnnotation - Class in org.apache.flink.api.java.functions
-
This class defines Java annotations for semantic assertions that can be added to Flink functions.
- FunctionAnnotation.ForwardedFields - Annotation Type in org.apache.flink.api.java.functions
-
The ForwardedFields annotation declares fields which are never modified by the annotated function and
which are forwarded at the same position to the output or unchanged copied to another position in the output.
- FunctionAnnotation.ForwardedFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
-
The ForwardedFieldsFirst annotation declares fields of the first input of a function which are
never modified by the annotated function and which are forwarded at the same position to the
output or unchanged copied to another position in the output.
- FunctionAnnotation.ForwardedFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
-
The ForwardedFieldsSecond annotation declares fields of the second input of a function which are
never modified by the annotated function and which are forwarded at the same position to the
output or unchanged copied to another position in the output.
- FunctionAnnotation.NonForwardedFields - Annotation Type in org.apache.flink.api.java.functions
-
The NonForwardedFields annotation declares ALL fields which not preserved on the same position in a functions output.
- FunctionAnnotation.NonForwardedFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
-
The NonForwardedFieldsFirst annotation declares for a function ALL fields of its first input
which are not preserved on the same position in its output.
- FunctionAnnotation.NonForwardedFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
-
The NonForwardedFieldsSecond annotation declares for a function ALL fields of its second input
which are not preserved on the same position in its output.
- FunctionAnnotation.ReadFields - Annotation Type in org.apache.flink.api.java.functions
-
The ReadFields annotation declares for a function all fields which it accesses and evaluates, i.e.,
all fields that are used by the function to compute its result.
- FunctionAnnotation.ReadFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
-
The ReadFieldsFirst annotation declares for a function all fields of the first input which it accesses and evaluates, i.e.,
all fields of the first input that are used by the function to compute its result.
- FunctionAnnotation.ReadFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
-
The ReadFieldsSecond annotation declares for a function all fields of the second input which it accesses and evaluates, i.e.,
all fields of the second input that are used by the function to compute its result.
- FunctionAnnotation.SkipCodeAnalysis - Annotation Type in org.apache.flink.api.java.functions
-
The SkipCodeAnalysis annotation declares that a function will not be analyzed by Flink's
code analysis capabilities independent of the configured CodeAnalysisMode
.
- generateSequence(long, long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a new data set that contains a sequence of numbers.
- get(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the String value for the given key.
- get(String, 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
-
Gets the registry for aggregators for the iteration.
- getAggregators() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
Gets the registry for aggregators.
- getAlt() - Method in class org.apache.flink.api.java.utils.Option
-
- getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getBitSize(long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
- getBoolean(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Boolean value for the given key.
- getBoolean(String, boolean) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Boolean value for the given key.
- getBroadcastSets() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getBroadcastSets() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getBroadcastSets() - Method in interface org.apache.flink.api.java.operators.UdfOperator
-
Gets the broadcast sets (name and data set) that have been added to context of the UDF.
- getByte(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Byte value for the given key.
- getByte(String, byte) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
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
-
Gets the character set for the reader.
- getCharsetName() - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- getCharsetName() - Method in class org.apache.flink.api.java.io.TextOutputFormat
-
- getCharsetName() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- getChecksum() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- getChoices() - Method in class org.apache.flink.api.java.utils.Option
-
- getCollectorValues() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getConfig() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the config object that defines execution parameters.
- getConfiguration() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- getContainerMapping() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getCount() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- getCrossHint() - Method in class org.apache.flink.api.java.operators.CrossOperator
-
- getCustomPartitioner() - Method in class org.apache.flink.api.java.operators.Grouping
-
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
-
Gets the custom partitioner from this partitioning.
- getDataSet() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getDefaultLocalParallelism() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- getDefaultValue() - Method in class org.apache.flink.api.java.utils.Option
-
- getDouble(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Double value for the given key.
- getDouble(String, double) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
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
-
Number of empty strings e.g.
- getExecutionEnvironment() - Method in class org.apache.flink.api.java.DataSet
-
- getExecutionEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates an execution environment that represents the context in which the program is currently executed.
- getExecutionPlan() - Method in class org.apache.flink.api.java.CollectionEnvironment
-
- getExecutionPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates the plan with which the system will execute the program, and returns it as
a String using a JSON representation of the execution data flow graph.
- getExecutionPlan() - Method in class org.apache.flink.api.java.LocalEnvironment
-
- getExecutionPlan() - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- getExecutor() - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- getFactory() - Method in enum org.apache.flink.api.java.aggregation.Aggregations
-
- getFalseCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
-
- getFields() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-
- getFieldTypes() - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- getFilePath() - Method in class org.apache.flink.api.java.io.CsvReader
-
- getFlatFieldExpr() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getFloat(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Float value for the given key.
- getFloat(String, float) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Float value for the given key.
- getFormat() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
- getFunction() - Method in class org.apache.flink.api.java.operators.FilterOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.FlatMapOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-
- getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
- getFunction() - Method in class org.apache.flink.api.java.operators.MapOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.ReduceOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getFunction() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getGroupOrdering() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getGroupSortKeyPositions() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getGroupSortOrders() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getHelp() - Method in class org.apache.flink.api.java.utils.RequiredParameters
-
Build a help text for the defined parameters.
- getHelp(List<String>) - Method in class org.apache.flink.api.java.utils.RequiredParameters
-
Build a help text for the defined parameters and list the missing arguments at the end of the text.
- getHelpText() - Method in class org.apache.flink.api.java.utils.Option
-
- getId() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the JobID by which this environment is identified.
- getId() - Method in enum org.apache.flink.api.java.sca.TaggedValue.Input
-
- getIdString() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the JobID by which this environment is identified, as a string.
- getInfinityCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
Number of values that are positive or negative infinity.
- getInitialSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the initial solution set.
- getInitialWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
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
-
Gets the data set that this operation uses as its input.
- getInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getInput1() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
Gets the data set that this operation uses as its first input.
- getInput1AsTaggedValue() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getInput1Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
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
-
Gets the data set that this operation uses as its second input.
- getInput2AsTaggedValue() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getInput2Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
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
-
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
-
Gets the input format that is executed by this data source.
- getInputType() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
-
Gets the type information of the data type of the input data set.
- getInt(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Integer value for the given key.
- getInt(String, int) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Integer value for the given key.
- getIntConstant() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getInternalUdfClassName() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getIsFromFirst() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-
- getIterationHead() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
-
- getIterationHead() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getJoinHint() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
Gets the JoinHint that describes how the join is executed.
- getJoinType() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
Gets the JoinType that describes this join operation (e.g.
- getKeyPositions() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getKeys() - Method in class org.apache.flink.api.java.operators.Grouping
-
- getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
-
- getKeys1() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
- getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
-
- getKeys2() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
- getLastGroupKey() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-
- getLastJobExecutionResult() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
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.ParameterTool
-
Returns the Long value for the given key.
- getLong(String, long) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Long value for the given key.
- getMax() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- getMaxIterations() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getMaxIterations() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
Gets the maximum number of iterations.
- getMaxLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
Longest String length.
- getMean() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
Null, NaN, and Infinite values are ignored in this calculation.
- getMeanLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
- getMin() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- getMinLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
Shortest String length.
- getMinResources() - Method in class org.apache.flink.api.java.operators.DataSink
-
Returns the minimum resources of this data sink.
- getMinResources() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the minimum resources from this iteration.
- getMinResources() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the minimum resource of this operator.
- getMissingArguments() - Method in exception org.apache.flink.api.java.utils.RequiredParametersException
-
- getMissingCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
The number of "missing" values where "missing" is defined as null, NaN, or Infinity.
- getName() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the name from this iteration.
- getName() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the name of the operator.
- getName() - Method in class org.apache.flink.api.java.utils.Option
-
- getNanCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
Number of values that are NaN.
- getNextPartialSolution() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
-
- getNextSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getNextWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getNonMissingCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
The number of values that are not null, NaN, or Infinity.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
-
The number of non-null values in this column.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
The number of non-null values in this column.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
The number of non-null values in this column.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
-
The number of non-null values in this column.
- getNonNullCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
- getNullCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
-
- getNullCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
The number of null values in this column.
- getNullCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- getNullCount() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
-
- getNullCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
- getNumberOfExecutionRetries() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
- getNumberOfParameters() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- getParallelism() - Method in class org.apache.flink.api.java.CollectionEnvironment
-
- getParallelism() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the parallelism with which operation are executed by default.
- getParallelism() - Method in class org.apache.flink.api.java.operators.DataSink
-
Returns the parallelism of this data sink.
- getParallelism() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the iteration's parallelism.
- getParallelism() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the parallelism of this operator.
- getParameters() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getParameters() - Method in class org.apache.flink.api.java.operators.DataSource
-
- getParameters() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getParameters() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getParameters() - Method in interface org.apache.flink.api.java.operators.UdfOperator
-
Gets the configuration parameters that will be passed to the UDF's open method
AbstractRichFunction.open(Configuration)
.
- getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Gets the custom partitioner used by this join, or null
, if none is set.
- getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
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
-
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
-
Returns the preferred resources of this data sink.
- getPreferredResources() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the preferred resources from this iteration.
- getPreferredResources() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the preferred resource of this operator.
- getProducedType() - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
-
- getProducedType() - Method in class org.apache.flink.api.java.io.TypeSerializerInputFormat
-
- getProperties() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- getRequired(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the String value for the given key.
- getRestartStrategy() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Returns the specified restart strategy configuration.
- getResultType() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the type of the result of this operator.
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.ReduceOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getSemanticProperties() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getSemanticProperties() - Method in interface org.apache.flink.api.java.operators.UdfOperator
-
Gets the semantic properties that have been set for the user-defined functions (UDF).
- getSemanticProperties() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- 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.
- getSessionTimeout() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the session timeout for this environment.
- getShort(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Short value for the given key.
- getShort(String, short) - Method in class org.apache.flink.api.java.utils.ParameterTool
-
Returns the Short value for the given key.
- getSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Gets the solution set of the delta iteration.
- getSortSelectionFunctionKey() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getSplitDataProperties() - Method in class org.apache.flink.api.java.operators.DataSource
-
- getSplitGroupKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
- getSplitOrder() - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
- getSplitPartitioner() - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
- getSplitPartitionKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
- getStandardDeviation() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
Standard Deviation is a measure of variation in a set of numbers.
- getState() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- getSum() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- getTag() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- getTerminationCriterion() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
-
- getTotalCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
-
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
-
- getType() - Method in class org.apache.flink.api.java.DataSet
-
Returns the TypeInformation
for the type of this DataSet.
- getType() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getType() - Method in class org.apache.flink.api.java.utils.Option
-
- getUnrequestedParameters() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- 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
-
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
-
Gets the working set of the delta iteration.
- getWorksetType() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
-
- getWrappedFunction() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
-
- globalClasspaths - Variable in class org.apache.flink.api.java.RemoteEnvironment
-
The classpaths that need to be attached to each job.
- groupBy(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
-
Groups a
DataSet
using a
KeySelector
function.
- groupBy(int...) - Method in class org.apache.flink.api.java.DataSet
-
Groups a
Tuple
DataSet
using field position keys.
- groupBy(String...) - Method in class org.apache.flink.api.java.DataSet
-
Groups a
DataSet
using field expressions.
- GroupCombineOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
-
This operator behaves like the GroupReduceOperator with Combine but only runs the Combine part which reduces all data
locally in their partitions.
- GroupCombineOperator(DataSet<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupCombineOperator
-
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
-
Constructor for a grouped reduce.
- Grouping<T> - Class in org.apache.flink.api.java.operators
-
Grouping is an intermediate step for a transformation on a grouped DataSet.
- Grouping(DataSet<T>, Keys<T>) - Constructor for class org.apache.flink.api.java.operators.Grouping
-
- GroupReduceIterator<IN,OUT> - Class in org.apache.flink.api.java.functions
-
Base class that simplifies reducing all values provided as
Iterable
.
- GroupReduceIterator() - Constructor for class org.apache.flink.api.java.functions.GroupReduceIterator
-
- GroupReduceOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a "reduceGroup" function on a data set, and the
result data set produced by the function.
- GroupReduceOperator(DataSet<IN>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
-
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
-
Constructor for a grouped reduce.
- parallelism(int) - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Sets the parallelism for the iteration.
- parallelism - Variable in class org.apache.flink.api.java.operators.Operator
-
- ParallelIteratorInputFormat<T> - Class in org.apache.flink.api.java.io
-
An input format that generates data in parallel through a SplittableIterator
.
- ParallelIteratorInputFormat(SplittableIterator<T>) - Constructor for class org.apache.flink.api.java.io.ParallelIteratorInputFormat
-
- 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
-
- parseQuotedStrings(char) - Method in class org.apache.flink.api.java.io.CsvReader
-
Enables quoted String parsing.
- parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
-
- 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
-
- partitionByHash(int...) - Method in class org.apache.flink.api.java.DataSet
-
Hash-partitions a DataSet on the specified key fields.
- partitionByHash(String...) - Method in class org.apache.flink.api.java.DataSet
-
Hash-partitions a DataSet on the specified key fields.
- partitionByHash(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
-
Partitions a DataSet using the specified KeySelector.
- partitionByRange(int...) - Method in class org.apache.flink.api.java.DataSet
-
Range-partitions a DataSet on the specified key fields.
- partitionByRange(String...) - Method in class org.apache.flink.api.java.DataSet
-
Range-partitions a DataSet on the specified key fields.
- partitionByRange(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
-
Range-partitions a DataSet using the specified KeySelector.
- partitionByRange(DataSet<T>, DataDistribution, int...) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
-
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
-
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
-
Range-partitions a DataSet using the specified key selector function.
- partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.api.java.DataSet
-
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
-
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
-
Partitions a DataSet on the key returned by the selector, using a custom partitioner.
- PartitionOperator<T> - Class in org.apache.flink.api.java.operators
-
This operator represents a partitioning.
- PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, DataDistribution, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- PartitionOperator(DataSet<T>, Keys<T>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- PartitionOperator(DataSet<T>, Keys<T>, Partitioner<P>, TypeInformation<P>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
-
- 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
-
- 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
-
Configures the reader to read the CSV data and parse it to the given type.
- port - Variable in class org.apache.flink.api.java.RemoteEnvironment
-
The port of the JobManager main actor system.
- preferredResources - Variable in class org.apache.flink.api.java.operators.Operator
-
- PrimitiveInputFormat<OT> - Class in org.apache.flink.api.java.io
-
An input format that reads single field primitive data from a given file.
- PrimitiveInputFormat(Path, Class<OT>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
-
- PrimitiveInputFormat(Path, String, Class<OT>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
-
- print() - Method in class org.apache.flink.api.java.DataSet
-
Prints the elements in a DataSet to the standard output stream
System.out
of the JVM that calls
the print() method.
- print(String) - Method in class org.apache.flink.api.java.DataSet
-
- PrintingOutputFormat<T> - Class in org.apache.flink.api.java.io
-
Output format that prints results into either stdout or stderr.
- PrintingOutputFormat() - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
-
Instantiates a printing output format that prints to standard out.
- PrintingOutputFormat(boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
-
Instantiates a printing output format that prints to standard out.
- PrintingOutputFormat(String, boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
-
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
-
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
-
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
-
- printToLogger(Logger) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- project(int...) - Method in class org.apache.flink.api.java.DataSet
-
Applies a Project transformation on a
Tuple
DataSet
.
- ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
- 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
-
- projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Initiates a ProjectCross transformation and projects the first cross input.
- projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
Continues a ProjectCross transformation and adds fields of the first cross input to the projection.
- projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
-
Applies a ProjectJoin transformation and projects the first join input
- projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
Continues a ProjectJoin transformation and adds fields of the first join input to the projection.
- Projection(DataSet<T>, int[]) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- 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
-
- 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
-
- ProjectOperator<IN,OUT extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a projection operation on a data set, and the
result data set produced by the function.
- ProjectOperator(DataSet<IN>, int[], TupleTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator
-
- ProjectOperator.Projection<T> - Class in org.apache.flink.api.java.operators
-
- projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Initiates a ProjectCross transformation and projects the second cross input.
- projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
Continues a ProjectCross transformation and adds fields of the second cross input to the projection.
- projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
-
Applies a ProjectJoin transformation and projects the second join input
- projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
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
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple10() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple11() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple12() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple13() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple14() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple15() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple16() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple17() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple18() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple19() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple2() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple20() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple21() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple22() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple23() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple24() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple25() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple3() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple4() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple5() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple6() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple7() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple8() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTuple9() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
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
-
Projects a
Tuple
DataSet
to the previously selected fields.
- projectTupleX() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
- projectTupleX() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- 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
-
- reachedEnd() - Method in class org.apache.flink.api.java.io.IteratorInputFormat
-
- reachedEnd() - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
-
- readCsvFile(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
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
-
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
-
- readFileOfPrimitives(String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
DataSet
that represents the primitive type produced by reading the given file line wise.
- readFileOfPrimitives(String, String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a
DataSet
that represents the primitive type produced by reading the given file in delimited way.
- readRecord(OUT, byte[], int, int) - 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
-
- readRecord(String, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- readRecord(StringValue, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- readSingleForwardAnnotations(Class<?>) - Static method in class org.apache.flink.api.java.functions.FunctionAnnotation
-
Reads the annotations of a user defined function with one input and returns semantic properties according to the forwarded fields annotated.
- readTextFile(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
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
-
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
-
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
-
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
-
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
-
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
-
- 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
-
Applies a Reduce transformation on a grouped
DataSet
.
- reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
-
Applies a GroupReduce transformation on a non-grouped
DataSet
.
- reduceGroup(Iterable<IN>) - Method in class org.apache.flink.api.java.functions.GroupReduceIterator
-
- reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
Applies a GroupReduce transformation on a grouped and sorted
DataSet
.
- reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Applies a GroupReduce transformation on a grouped
DataSet
.
- ReduceOperator<IN> - Class in org.apache.flink.api.java.operators
-
This operator represents the application of a "reduce" function on a data set, and the
result data set produced by the function.
- ReduceOperator(DataSet<IN>, ReduceFunction<IN>, String) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
-
This is the case for a reduce-all case (in contrast to the reduce-per-group case).
- ReduceOperator(Grouping<IN>, ReduceFunction<IN>, String) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
-
- registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
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
-
Registers an Aggregator
for the iteration together with a ConvergenceCriterion
.
- registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Registers an Aggregator
for the iteration.
- registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
Registers an Aggregator
for the iteration.
- registerCachedFile(String, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCachedFile(String, String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCachedFilesWithPlan(Plan) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers all files that were registered at this execution environment's cache registry of the
given plan's cache registry.
- registerType(Class<?>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers the given type with the serialization stack.
- registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Registers the given type with a Kryo Serializer.
- registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
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
-
- RemoteEnvironment(String, int, String...) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
-
Creates a new RemoteEnvironment that points to the master (JobManager) described by the
given host name and port.
- RemoteEnvironment(String, int, Configuration, String[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
-
Creates a new RemoteEnvironment that points to the master (JobManager) described by the
given host name and port.
- RemoteEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
-
Creates a new RemoteEnvironment that points to the master (JobManager) described by the
given host name and port.
- remove() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
-
- remove() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-
- removeUngroupedInputs(TaggedValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- removeUngroupedInputsFromContainer(TaggedValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- requestIFEQLoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
-
- requestIFNELoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
-
- RequiredParameters - Class in org.apache.flink.api.java.utils
-
Facility to manage required parameters in user defined functions.
- RequiredParameters() - Constructor for class org.apache.flink.api.java.utils.RequiredParameters
-
- RequiredParametersException - Exception in org.apache.flink.api.java.utils
-
- RequiredParametersException() - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- RequiredParametersException(String, List<String>) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- RequiredParametersException(String) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- RequiredParametersException(String, Throwable) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- RequiredParametersException(Throwable) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
-
- 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
-
Un-sets the context environment factory.
- resetLocal() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- 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
-
- returnOperation(AbstractInsnNode, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
-
- returns(Class<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
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
-
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
-
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
-
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
-
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
-
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
-
Initiates a Right Outer Join transformation.
- rightOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
-
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
-
Input format that reads csv into Row
.
- RowCsvInputFormat(Path, TypeInformation[], String, String, int[], boolean) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[], String, String, int[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[], String, String) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[], int[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[], boolean) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- RowCsvInputFormat(Path, TypeInformation[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
-
- runOperation(CustomUnaryOperation<T, X>) - Method in class org.apache.flink.api.java.DataSet
-
- 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
-
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
-
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
-
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
-
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
-
- sessionTimeout - Variable in class org.apache.flink.api.java.ExecutionEnvironment
-
The session timeout in seconds.
- 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
-
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
-
- setAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- setCharset(String) - Method in class org.apache.flink.api.java.io.CsvReader
-
Sets the charset of the reader.
- setCharsetName(String) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
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
-
- setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextOutputFormat
-
- setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- setCombinable(boolean) - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.java.operators.DistinctOperator
-
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
-
Sets the strategy to use for the combine phase of the reduce.
- setDefaultLocalParallelism(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- setInput(DataSet<IN>) - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
-
- 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
-
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
-
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
-
- setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
- setParallelism(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Sets the parallelism for operations executed through this environment.
- setParallelism(int) - Method in class org.apache.flink.api.java.operators.DataSink
-
Sets the parallelism for this data sink.
- setParallelism(int) - Method in class org.apache.flink.api.java.operators.Operator
-
Sets the parallelism for this operator.
- setParallelism(int) - Method in class org.apache.flink.api.java.operators.UnionOperator
-
- setQuoteStrings(boolean) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
Configures whether the output format should quote string values.
- setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
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
-
Sets the semantic properties for the user-defined function (UDF).
- setSemanticProperties(DualInputSemanticProperties) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
Sets the semantic properties for the user-defined function (UDF).
- setSerializer(TypeSerializer<T>) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
-
- setSessionTimeout(long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Sets the session timeout to hold the intermediate results of a job.
- setSkipInvalidLines(boolean) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- setSolutionSetUnManaged(boolean) - Method in class org.apache.flink.api.java.operators.DeltaIteration
-
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or unmanaged memory
(objects on heap).
- setState(int) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
-
- setTag(TaggedValue.Tag) - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- 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
-
Base class for operations that operates on a single input data set.
- SingleInputOperator(DataSet<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.SingleInputOperator
-
- SingleInputUdfOperator<IN,OUT,O extends SingleInputUdfOperator<IN,OUT,O>> - Class in org.apache.flink.api.java.operators
-
The SingleInputUdfOperator is the base class of all unary operators that execute
user-defined functions (UDFs).
- SingleInputUdfOperator(DataSet<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
Creates a new operators with the given data set as input.
- skipFirstLineAsHeader - Variable in class org.apache.flink.api.java.io.CsvReader
-
- SortedGrouping<T> - Class in org.apache.flink.api.java.operators
-
SortedGrouping is an intermediate step for a transformation on a grouped and sorted DataSet.
- SortedGrouping(DataSet<T>, Keys<T>, int, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
-
- SortedGrouping(DataSet<T>, Keys<T>, String, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
-
- SortedGrouping(DataSet<T>, Keys<T>, Keys.SelectorFunctionKeys<T, K>, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
-
- sortFirstGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Sorts Tuple
elements within a group in the first input on the
specified field in the specified Order
.
- sortFirstGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Sorts Pojo or Tuple
elements within a group in the first input on the
specified field in the specified Order
.
- sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
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
-
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
-
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
-
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
-
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
-
- sortLocalOutput(String, Order) - Method in class org.apache.flink.api.java.operators.DataSink
-
- sortPartition(int, Order) - Method in class org.apache.flink.api.java.DataSet
-
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
-
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
-
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
-
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
-
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
-
- SortPartitionOperator<T> - Class in org.apache.flink.api.java.operators
-
This operator represents a DataSet with locally sorted partitions.
- SortPartitionOperator(DataSet<T>, int, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
-
- SortPartitionOperator(DataSet<T>, String, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
-
- SortPartitionOperator(DataSet<T>, Keys.SelectorFunctionKeys<T, K>, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
-
- sortSecondGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Sorts Tuple
elements within a group in the second input on the
specified field in the specified Order
.
- sortSecondGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Sorts Pojo or Tuple
elements within a group in the second input on the
specified field in the specified Order
.
- SourcePartitionerMarker(String) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
-
- SplitDataProperties<T> - Class in org.apache.flink.api.java.io
-
SplitDataProperties define data properties on
InputSplit
generated by the
InputFormat
of a
DataSource
.
- SplitDataProperties(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
-
Creates SplitDataProperties for the given data types.
- SplitDataProperties(DataSource<T>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
-
Creates SplitDataProperties for the given data types.
- SplitDataProperties.SourcePartitionerMarker<T> - Class in org.apache.flink.api.java.io
-
A custom partitioner to mark compatible split partitionings.
- splitsGroupedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that the data within an input split is grouped on the fields defined by the field positions.
- splitsGroupedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that the data within an input split is grouped on the fields defined by the field expressions.
- splitsOrderedBy(int[], Order[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that the data within an input split is sorted on the fields defined by the field positions
in the specified orders.
- splitsOrderedBy(String, Order[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that the data within an input split is sorted on the fields defined by the field expressions
in the specified orders.
- splitsPartitionedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that data is partitioned across input splits on the fields defined by field positions.
- splitsPartitionedBy(String, int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that data is partitioned using a specific partitioning method
across input splits on the fields defined by field positions.
- splitsPartitionedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that data is partitioned across input splits on the fields defined by field expressions.
- splitsPartitionedBy(String, String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
-
Defines that data is partitioned using an identifiable method
across input splits on the fields defined by field expressions.
- startNewSession() - Method in class org.apache.flink.api.java.CollectionEnvironment
-
- startNewSession() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Starts a new session, discarding the previous data flow and all of its intermediate results.
- startNewSession() - Method in class org.apache.flink.api.java.LocalEnvironment
-
- startNewSession() - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- StringColumnSummary - Class in org.apache.flink.api.java.summarize
-
Summary for a column of Strings.
- StringColumnSummary(long, long, long, Integer, Integer, Double) - Constructor for class org.apache.flink.api.java.summarize.StringColumnSummary
-
- StringSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
-
- 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
-
Syntactic sugar for aggregate (SUM, field).
- sum(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
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
-
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
-
- supportsMultiPaths() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- tagged(Value) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
-
- TaggedValue - Class in org.apache.flink.api.java.sca
-
Extension of ASM's BasicValue that allows to assign "tags"
to values and add additional information depending on the tag to the Value.
- TaggedValue(Type) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue(Type, TaggedValue.Tag) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue(Type, TaggedValue.Input, String, boolean, boolean) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue(Type, Map<String, TaggedValue>) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue(int) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
-
- TaggedValue.Input - Enum in org.apache.flink.api.java.sca
-
Distinguishes between inputs in case of two input operators.
- TaggedValue.Tag - Enum in org.apache.flink.api.java.sca
-
Possible tags.
- ternaryOperation(AbstractInsnNode, BasicValue, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
-
- TextInputFormat - Class in org.apache.flink.api.java.io
-
Input Format that reads text files.
- TextInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextInputFormat
-
- TextOutputFormat<T> - Class in org.apache.flink.api.java.io
-
A FileOutputFormat
that writes objects to a text file.
- TextOutputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextOutputFormat
-
- TextOutputFormat(Path, String) - Constructor for class org.apache.flink.api.java.io.TextOutputFormat
-
- TextOutputFormat.TextFormatter<IN> - Interface in org.apache.flink.api.java.io
-
Formatter that transforms values into their
String
representations.
- TextValueInputFormat - Class in org.apache.flink.api.java.io
-
Input format that reads text files.
- TextValueInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextValueInputFormat
-
- toBooleanMask(int[]) - Static method in class org.apache.flink.api.java.io.CsvInputFormat
-
- toForwardedFieldsExpression(TaggedValue.Input) - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- toMap() - Method in class org.apache.flink.api.java.utils.ParameterTool
-
- 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
-
- toString() - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.TextInputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.TextOutputFormat
-
- toString() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- toString() - Method in class org.apache.flink.api.java.LocalEnvironment
-
- toString() - Method in class org.apache.flink.api.java.operators.DataSink
-
- toString() - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- toString() - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
-
- toString() - Method in class org.apache.flink.api.java.sca.TaggedValue
-
- toString() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
-
- toString() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
-
- toString() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
-
- toString() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
-
- toString() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.AggregateOperator
-
- translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- 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
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DataSink
-
- translateToDataFlow() - Method in class org.apache.flink.api.java.operators.DataSource
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DistinctOperator
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.FilterOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.FlatMapOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
-
- translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.PartitionOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ProjectOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ReduceOperator
-
- translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.SingleInputOperator
-
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
-
- translateToDataFlow(Operator<IN1>, Operator<IN2>) - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
Translates this java API operator into a common API operator with two inputs.
- translateToDataFlow(Operator<T>, Operator<T>) - Method in class org.apache.flink.api.java.operators.UnionOperator
-
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
-
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
-
Base class for operations that operates on two input data sets.
- TwoInputOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.TwoInputOperator
-
- TwoInputUdfOperator<IN1,IN2,OUT,O extends TwoInputUdfOperator<IN1,IN2,OUT,O>> - Class in org.apache.flink.api.java.operators
-
The TwoInputUdfOperator is the base class of all binary operators that execute
user-defined functions (UDFs).
- TwoInputUdfOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
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
-
- type(OptionType) - Method in class org.apache.flink.api.java.utils.Option
-
Define the type of the Option.
- types(Class<T0>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>) - Method in class org.apache.flink.api.java.io.CsvReader
-
Specifies the types for the CSV fields.
- types(Class<T0>, Class<T1>, Class<T2>) - Method in class org.apache.flink.api.java.io.CsvReader
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
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
-
Specifies the types for the CSV fields.
- types(Class<?>...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
- types(Class<?>...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
- types(Class<?>...) - Method in class org.apache.flink.api.java.operators.ProjectOperator
-
- TypeSerializerInputFormat<T> - Class in org.apache.flink.api.java.io
-
Reads elements by deserializing them with a given type serializer.
- TypeSerializerInputFormat(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.io.TypeSerializerInputFormat
-
- TypeSerializerOutputFormat<T> - Class in org.apache.flink.api.java.io
-
Stores elements by serializing them with their type serializer.
- TypeSerializerOutputFormat() - Constructor for class org.apache.flink.api.java.io.TypeSerializerOutputFormat
-
- where(int...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
-
Continues a CoGroup transformation.
- where(String...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
-
Continues a CoGroup transformation.
- where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
-
Continues a CoGroup transformation and defines a
KeySelector
function for the first co-grouped
DataSet
.
- where(int...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
-
Continues a Join transformation.
- where(String...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
-
Continues a Join transformation.
- where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
-
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
-
Continues a Join transformation.
- where(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
-
Continues a Join transformation.
- where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
-
Continues a Join transformation and defines a
KeySelector
function for the first join
DataSet
.
- with(CoGroupFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Finalizes a CoGroup transformation by applying a RichCoGroupFunction
to groups of elements with identical keys.
- with(CrossFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
-
Finalizes a Cross transformation by applying a CrossFunction
to each pair of crossed elements.
- with(JoinFunction<I1, I2, R>) - Method in interface org.apache.flink.api.java.operators.join.JoinFunctionAssigner
-
- with(FlatJoinFunction<I1, I2, R>) - Method in interface org.apache.flink.api.java.operators.join.JoinFunctionAssigner
-
- with(FlatJoinFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
-
Finalizes a Join transformation by applying a RichFlatJoinFunction
to each pair of joined elements.
- with(JoinFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
-
- withBroadcastSet(DataSet<?>, String) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- withBroadcastSet(DataSet<?>, String) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- withBroadcastSet(DataSet<?>, String) - Method in interface org.apache.flink.api.java.operators.UdfOperator
-
Adds a certain data set as a broadcast set to this operator.
- withForwardedFields(String...) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
Adds semantic information about forwarded fields of the user-defined function.
- withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
-
- withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
- withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
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
-
- withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
-
- withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
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
-
Sets the order of keys for range partitioning.
- withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.DataSink
-
Pass a configuration to the OutputFormat.
- withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.DataSource
-
Pass a configuration to the InputFormat.
- withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- withParameters(Configuration) - Method in interface org.apache.flink.api.java.operators.UdfOperator
-
Sets the configuration parameters for the UDF.
- withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
-
Sets a custom partitioner for the CoGroup operation.
- withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
Sets a custom partitioner for the CoGroup operation.
- withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator
-
Sets a custom partitioner for this join.
- withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
Uses a custom partitioner for the grouping.
- withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
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
-
- 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
-
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
-
Writes a DataSet using a FileOutputFormat
to a specified location.
- writeAsCsv(String) - Method in class org.apache.flink.api.java.DataSet
-
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
-
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
-
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
-
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
-
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
-
Writes a DataSet as text file(s) to the specified location.
- writeAsText(String) - Method in class org.apache.flink.api.java.DataSet
-
Writes a DataSet as text file(s) to the specified location.
- writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
-
Writes a DataSet as text file(s) to the specified location.
- writeRecord(T) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
- writeRecord(T) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
-
- writeRecord(T) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
-
- writeRecord(T) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- writeRecord(T) - Method in class org.apache.flink.api.java.io.TextOutputFormat
-
- 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
-