- CHAR_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- CHAR_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- CHAR_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- CHARSET_NAME - Static variable in class org.apache.flink.api.java.record.io.TextInputFormat
-
- 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.DeltaIteration.SolutionSetPlaceHolder
-
- checkJoinKeyFields(int[]) - Method in class org.apache.flink.api.java.record.operators.DeltaIteration.SolutionSetPlaceHolder
-
- checkSameExecutionContext(DataSet<?>, DataSet<?>) - Static method in class org.apache.flink.api.java.DataSet
-
- close() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
- close() - Method in class org.apache.flink.api.java.io.DiscardingOuputFormat
-
- 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.TupleWrappingCollector
-
- close() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
-
- close() - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat
-
- close() - Method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat
-
- close() - Method in class org.apache.flink.api.java.record.io.ExternalProcessInputFormat
-
- closeWith(DataSet<ST>, DataSet<WT>) - Method in class org.apache.flink.api.java.DeltaIteration
-
Closes the delta iteration.
- closeWith(DataSet<T>) - Method in class org.apache.flink.api.java.IterativeDataSet
-
Closes the iteration.
- closeWith(DataSet<T>, DataSet<?>) - Method in class org.apache.flink.api.java.IterativeDataSet
-
Closes the iteration and specifies a termination criterion.
- coGroup(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a CoGroup transformation.
A CoGroup transformation combines the elements of
two
DataSets
into one DataSet.
- coGroup(Iterable<IN1>, Iterable<IN2>, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.RichCoGroupFunction
-
- coGroup(Iterable<Tuple2<K, I1>>, Iterable<Tuple2<K, I2>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingCoGroupOperator.TupleUnwrappingCoGrouper
-
- coGroup(Iterator<Record>, Iterator<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.functions.CoGroupFunction
-
This method must be implemented to provide a user implementation of a
matcher.
- coGroup(Iterable<Record>, Iterable<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.WrappingCoGroupFunction
-
- CoGroupFunction - Class in org.apache.flink.api.java.record.functions
-
The CoGroupFunction is the base class for functions that are invoked by a
CoGroupOperator
.
- CoGroupFunction() - Constructor for class org.apache.flink.api.java.record.functions.CoGroupFunction
-
- 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>) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
-
- CoGroupOperator - Class in org.apache.flink.api.java.record.operators
-
CoGroupOperator that applies a
CoGroupFunction
to groups of records sharing
the same key (one group per input).
- CoGroupOperator(CoGroupOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator
-
The private constructor that only gets invoked from the Builder.
- CoGroupOperator.Builder - Class in org.apache.flink.api.java.record.operators
-
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
- CoGroupOperator.Builder(UserCodeWrapper<CoGroupFunction<Record, Record, Record>>, Class<? extends Key<?>>, int, int) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
- CoGroupOperator.Builder(UserCodeWrapper<CoGroupFunction<Record, Record, Record>>) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
- CoGroupOperator.CoGroupOperatorSets<I1,I2> - Class in org.apache.flink.api.java.operators
-
Intermediate step of a CoGroup transformation.
- CoGroupOperator.CoGroupOperatorSets(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
-
- 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
-
- CoGroupOperator.WrappingClassCoGroupFunction - Class in org.apache.flink.api.java.record.operators
-
- CoGroupOperator.WrappingClassCoGroupFunction(Class<? extends CoGroupFunction>) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator.WrappingClassCoGroupFunction
-
- CoGroupOperator.WrappingCoGroupFunction - Class in org.apache.flink.api.java.record.operators
-
- CoGroupOperator.WrappingCoGroupFunction(CoGroupFunction) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator.WrappingCoGroupFunction
-
- collect(IN) - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
-
- CollectionDataSource - Class in org.apache.flink.api.java.record.operators
-
Operator for input nodes which reads data from collection or iterator.
- CollectionDataSource(CollectionInputFormat, String, Object...) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
Creates a new instance for the given input using the given input format.
- CollectionDataSource(CollectionInputFormat, String, Object[][]) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
- CollectionDataSource(CollectionInputFormat, Collection<?>, String) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
- CollectionDataSource(CollectionInputFormat, T, String) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
- CollectionDataSource(String, Object...) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
Creates a new instance for the given input using the given input format.
- CollectionDataSource(String, Object[][]) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
- CollectionDataSource(Collection<?>, String) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
- CollectionDataSource(T, String) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
- CollectionDataSource(Object...) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
for scala compatible, scala-to-java type conversion always has an object wrapper
- CollectionDataSource(CollectionInputFormat, Object...) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
-
- 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
-
- CollectionInputFormat - Class in org.apache.flink.api.java.record.io
-
input format for java collection input.
- CollectionInputFormat() - Constructor for class org.apache.flink.api.java.record.io.CollectionInputFormat
-
- combine(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.RichFlatCombineFunction
-
- combine(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.api.java.functions.RichGroupReduceFunction
-
The combine methods pre-reduces elements.
- combine(Iterable<Tuple2<K, IN>>, Collector<Tuple2<K, IN>>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingFlatCombinableGroupReducer
-
- combine(Iterator<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.functions.ReduceFunction
-
No default implementation provided.
- combine(Iterable<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.WrappingReduceFunction
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- compare(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- compare(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- compare(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- compare(Record, Record) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- compare(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- compare(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- compare(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- compare(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- compare(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- compareAgainstReference(Comparable[]) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- compareToReference(T2) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoPairComparator
-
- compareToReference(TypeComparator<Record>) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- compareToReference(Record) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordPairComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- compareToReference(T2) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldPairComparator
-
- compareToReference(T2) - Method in class org.apache.flink.api.java.typeutils.runtime.TuplePairComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- CompositeType<T> - Interface in org.apache.flink.api.java.typeutils
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.java.operators.Keys
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.java.operators.Keys.ExpressionKeys
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.java.operators.Keys.FieldPositionKeys
-
- computeLogicalKeyPositions() - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
-
- configure(Configuration) - Method in class org.apache.flink.api.java.io.DiscardingOuputFormat
-
- 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.record.io.CsvInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat
-
Calls the super classes to configure themselves and reads the config parameters for the delimiter and
the write buffer size.
- configure(Configuration) - Method in class org.apache.flink.api.java.record.io.ExternalProcessFixedLengthInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.record.io.ExternalProcessInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
-
- configure(Configuration) - Method in class org.apache.flink.api.java.record.io.TextInputFormat
-
- configureDelimitedFormat(FileDataSink) - Static method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat
-
Creates a configuration builder that can be used to set the input format's parameters to the config in a fluent
fashion.
- configureRecordFormat(FileDataSource) - Static method in class org.apache.flink.api.java.record.io.CsvInputFormat
-
Creates a configuration builder that can be used to set the input format's parameters to the config in a fluent
fashion.
- configureRecordFormat(FileDataSink) - Static method in class org.apache.flink.api.java.record.io.CsvOutputFormat
-
Creates a configuration builder that can be used to set the input
format's parameters to the config in a fluent fashion.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Shallow tuple copy.
- copy() - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Shallow tuple copy.
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- copy(C[], C[]) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericArraySerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericArraySerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- copy(Record, Record) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- CopyableValueComparator<T extends CopyableValue<T> & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
Comparator for all Value types that extend Key
- CopyableValueComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- CopyableValueSerializer<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
- CopyableValueSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- 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
-
- createComparator(boolean) - Method in interface org.apache.flink.api.java.typeutils.AtomicType
-
- createComparator(boolean) - Method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- createComparator(int[], boolean[]) - Method in interface org.apache.flink.api.java.typeutils.CompositeType
-
- createComparator(boolean) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- createComparator(int[], boolean[]) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- createComparator() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparatorFactory
-
- createComparator() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
-
- createComparator(int[], boolean[]) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- createComparator(boolean) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- createComparator(boolean) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- createComparator12(TypeComparator<Record>, TypeComparator<Record>) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordPairComparatorFactory
-
- createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
-
- createComparator21(TypeComparator<Record>, TypeComparator<Record>) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordPairComparatorFactory
-
- createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
-
- 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
.
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericArraySerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- createJoinOperator(Keys<I2>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
-
- createLocalEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- createLocalEnvironment(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- 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
.
- createProjectionPropertiesDual(int[], boolean[]) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- createProjectionPropertiesSingle(int[]) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- createRemoteEnvironment(String, int, 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
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- createSerializer() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- createTypeInfo(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- createTypeInfo(Class<?>, Class<?>, int, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- cross(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Cross transformation.
A Cross transformation combines the elements of two
DataSets
into one DataSet.
- cross(IN1, IN2) - Method in class org.apache.flink.api.java.functions.RichCrossFunction
-
- cross(T1, T2) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCrossFunction
-
- cross(T1, T2) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-
- cross(Record, Record) - Method in class org.apache.flink.api.java.record.functions.CrossFunction
-
This method must be implemented to provide a user implementation of a cross.
- CrossFunction - Class in org.apache.flink.api.java.record.functions
-
The CrossFunction is the base class for functions that are invoked by a
CrossOperator
.
- CrossFunction() - Constructor for class org.apache.flink.api.java.record.functions.CrossFunction
-
- 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>) - Constructor for class org.apache.flink.api.java.operators.CrossOperator
-
- CrossOperator - Class in org.apache.flink.api.java.record.operators
-
CrossOperator that applies a
CrossFunction
to each element of the Cartesian Product.
- CrossOperator(CrossOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.CrossOperator
-
The private constructor that only gets eIinvoked from the Builder.
- CrossOperator.Builder - Class in org.apache.flink.api.java.record.operators
-
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
- CrossOperator.Builder(UserCodeWrapper<CrossFunction>) - Constructor for class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
Creates a Builder with the provided
CrossFunction
implementation.
- CrossOperator.CrossProjection<I1,I2> - Class in org.apache.flink.api.java.operators
-
- CrossOperator.CrossProjection(DataSet<I1>, DataSet<I2>, int[], int[]) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
-
- CrossOperator.DefaultCross<I1,I2> - Class in org.apache.flink.api.java.operators
-
A Cross transformation that wraps pairs of crossed elements into
Tuple2
.
It also represents the
DataSet
that is the result of a Cross transformation.
- CrossOperator.DefaultCross(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
-
- CrossOperator.DefaultCrossFunction<T1,T2> - Class in org.apache.flink.api.java.operators
-
- CrossOperator.DefaultCrossFunction() - Constructor for class org.apache.flink.api.java.operators.CrossOperator.DefaultCrossFunction
-
- CrossOperator.ProjectCrossFunction<T1,T2,R extends Tuple> - Class in org.apache.flink.api.java.operators
-
- crossWithHuge(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Cross transformation.
A Cross transformation combines the elements of two
DataSets
into one DataSet.
- CrossWithLargeOperator - Class in org.apache.flink.api.java.record.operators
-
This operator represents a Cartesian-Product operation.
- CrossWithLargeOperator(CrossWithLargeOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.CrossWithLargeOperator
-
The private constructor that only gets invoked from the Builder.
- CrossWithLargeOperator.Builder - Class in org.apache.flink.api.java.record.operators
-
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
- CrossWithSmallOperator - Class in org.apache.flink.api.java.record.operators
-
This operator represents a Cartesian-Product operation.
- CrossWithSmallOperator(CrossWithSmallOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.CrossWithSmallOperator
-
The private constructor that only gets invoked from the Builder.
- CrossWithSmallOperator.Builder - Class in org.apache.flink.api.java.record.operators
-
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
- crossWithTiny(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a Cross transformation.
A Cross transformation combines the elements of two
DataSets
into one DataSet.
- CsvInputFormat<OUT extends Tuple> - Class in org.apache.flink.api.java.io
-
- CsvInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.CsvInputFormat
-
- CsvInputFormat(Path, Class<?>...) - Constructor for class org.apache.flink.api.java.io.CsvInputFormat
-
- CsvInputFormat(Path, String, char, Class<?>...) - Constructor for class org.apache.flink.api.java.io.CsvInputFormat
-
- CsvInputFormat - Class in org.apache.flink.api.java.record.io
-
Input format to parse text files and generate Records.
- CsvInputFormat() - Constructor for class org.apache.flink.api.java.record.io.CsvInputFormat
-
- CsvInputFormat(char) - Constructor for class org.apache.flink.api.java.record.io.CsvInputFormat
-
- CsvInputFormat(Class<? extends Value>...) - Constructor for class org.apache.flink.api.java.record.io.CsvInputFormat
-
- CsvInputFormat(char, Class<? extends Value>...) - Constructor for class org.apache.flink.api.java.record.io.CsvInputFormat
-
- CsvInputFormat.AbstractConfigBuilder<T> - Class in org.apache.flink.api.java.record.io
-
An abstract builder used to set parameters to the input format's configuration in a fluent way.
- CsvInputFormat.AbstractConfigBuilder(Operator<?>, Configuration) - Constructor for class org.apache.flink.api.java.record.io.CsvInputFormat.AbstractConfigBuilder
-
Creates a new builder for the given configuration.
- CsvInputFormat.ConfigBuilder - Class in org.apache.flink.api.java.record.io
-
A builder used to set parameters to the input format's configuration in a fluent way.
- CsvInputFormat.ConfigBuilder(Operator<?>, Configuration) - Constructor for class org.apache.flink.api.java.record.io.CsvInputFormat.ConfigBuilder
-
- CsvOutputFormat<T extends 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.
- CsvOutputFormat - Class in org.apache.flink.api.java.record.io
-
This is an OutputFormat to serialize
Record
s to text.
- CsvOutputFormat() - Constructor for class org.apache.flink.api.java.record.io.CsvOutputFormat
-
- CsvOutputFormat(Class<? extends Value>...) - Constructor for class org.apache.flink.api.java.record.io.CsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- CsvOutputFormat(String, Class<? extends Value>...) - Constructor for class org.apache.flink.api.java.record.io.CsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- CsvOutputFormat(String, String, Class<? extends Value>...) - Constructor for class org.apache.flink.api.java.record.io.CsvOutputFormat
-
Creates an instance of CsvOutputFormat.
- CsvOutputFormat.AbstractConfigBuilder<T> - Class in org.apache.flink.api.java.record.io
-
Abstract builder used to set parameters to the input format's
configuration in a fluent way.
- CsvOutputFormat.AbstractConfigBuilder(Configuration) - Constructor for class org.apache.flink.api.java.record.io.CsvOutputFormat.AbstractConfigBuilder
-
Creates a new builder for the given configuration.
- CsvOutputFormat.ConfigBuilder - Class in org.apache.flink.api.java.record.io
-
A builder used to set parameters to the input format's configuration in a
fluent way.
- CsvOutputFormat.ConfigBuilder(Configuration) - Constructor for class org.apache.flink.api.java.record.io.CsvOutputFormat.ConfigBuilder
-
Creates a new builder for the given configuration.
- 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
-
- CustomUnaryOperation<IN,OUT> - Interface in org.apache.flink.api.java.operators
-
- enableLogging() - Method in class org.apache.flink.api.java.LocalEnvironment
-
Causes the local environment to print INFO level log messages to the standard error output.
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Deep equality for tuples by calling equals() on the tuple members
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericArraySerializer
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializerFactory
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeStatefulSerializerFactory
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeStatelessSerializerFactory
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- equals(Object) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- equalTo(int...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
-
Continues a CoGroup transformation and defines the
Tuple
fields of the second co-grouped
DataSet
that should be used as grouping keys.
Note: Fields can only be selected as grouping keys on Tuple DataSets.
- equalTo(KeySelector<I2, K>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
-
Continues a CoGroup transformation and defines a
KeySelector
function for the second co-grouped
DataSet
.
The KeySelector function is called for each element of the second DataSet and extracts a single
key value on which the DataSet is grouped.
- equalTo(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
-
Continues a Join transformation and defines the
Tuple
fields of the second join
DataSet
that should be used as join keys.
Note: Fields can only be selected as join keys on Tuple DataSets.
The resulting
JoinOperator.DefaultJoin
wraps each pair of joining elements into a
Tuple2
, with
the element of the first input being the first field of the tuple and the element of the
second input being the second field of the tuple.
- equalTo(KeySelector<I2, K>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
-
Continues a Join transformation and defines a
KeySelector
function for the second join
DataSet
.
The KeySelector function is called for each element of the second DataSet and extracts a single
key value on which the DataSet is joined.
- equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- equalToReference(T2) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoPairComparator
-
- equalToReference(Record) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- equalToReference(Record) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordPairComparator
-
- equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- equalToReference(T2) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldPairComparator
-
- equalToReference(T2) - Method in class org.apache.flink.api.java.typeutils.runtime.TuplePairComparator
-
- equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- execute() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Triggers the program execution.
- execute(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Triggers the program execution.
- execute(String) - Method in class org.apache.flink.api.java.LocalEnvironment
-
- execute(String) - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- ExecutionEnvironment - Class in org.apache.flink.api.java
-
The ExecutionEnviroment is the context in which a program is executed.
- ExecutionEnvironment() - Constructor for class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a new Execution Environment.
- ExternalProcessFixedLengthInputFormat<T extends ExternalProcessInputSplit> - Class in org.apache.flink.api.java.record.io
-
This input format starts an external process and reads its input from the standard out (stdout) of the started process.
- ExternalProcessFixedLengthInputFormat() - Constructor for class org.apache.flink.api.java.record.io.ExternalProcessFixedLengthInputFormat
-
- ExternalProcessInputFormat<T extends ExternalProcessInputSplit> - Class in org.apache.flink.api.java.record.io
-
This input format starts an external process and reads its input from the standard out (stdout) of the started process.
- ExternalProcessInputFormat() - Constructor for class org.apache.flink.api.java.record.io.ExternalProcessInputFormat
-
- ExternalProcessInputSplit - Class in org.apache.flink.api.java.record.io
-
The ExternalProcessInputSplit contains all informations for
InputFormat
that read their data from external processes.
- ExternalProcessInputSplit() - Constructor for class org.apache.flink.api.java.record.io.ExternalProcessInputSplit
-
- ExternalProcessInputSplit(int, int, String) - Constructor for class org.apache.flink.api.java.record.io.ExternalProcessInputSplit
-
Instantiates an ExternalProcessInputSplit
- extProcErrStream - Variable in class org.apache.flink.api.java.record.io.ExternalProcessInputFormat
-
The stderr stream of the external process
- extProcOutStream - Variable in class org.apache.flink.api.java.record.io.ExternalProcessInputFormat
-
The stdout stream of the external process
- extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple1
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple2
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple3
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 0 of the tuple.
- f0 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 0 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple2
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple3
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 1 of the tuple.
- f1 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 1 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 10 of the tuple.
- f10 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 10 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 11 of the tuple.
- f11 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 11 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 12 of the tuple.
- f12 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 12 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 13 of the tuple.
- f13 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 13 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 14 of the tuple.
- f14 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 14 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 15 of the tuple.
- f15 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 15 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 16 of the tuple.
- f16 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 16 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 17 of the tuple.
- f17 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 17 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 18 of the tuple.
- f18 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 18 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 19 of the tuple.
- f19 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 19 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple3
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 2 of the tuple.
- f2 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 2 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 20 of the tuple.
- f20 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 20 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 21 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 21 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 21 of the tuple.
- f21 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 21 of the tuple.
- f22 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 22 of the tuple.
- f22 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 22 of the tuple.
- f22 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 22 of the tuple.
- f23 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 23 of the tuple.
- f23 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 23 of the tuple.
- f24 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 24 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple4
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 3 of the tuple.
- f3 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 3 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple5
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 4 of the tuple.
- f4 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 4 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple6
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 5 of the tuple.
- f5 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 5 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple7
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 6 of the tuple.
- f6 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 6 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple8
-
Field 7 of the tuple.
- f7 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 7 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 8 of the tuple.
- f8 - Variable in class org.apache.flink.api.java.tuple.Tuple9
-
Field 8 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple10
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple11
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple12
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple13
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple14
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple15
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple16
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple17
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple18
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple19
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple20
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple21
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple22
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple23
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple24
-
Field 9 of the tuple.
- f9 - Variable in class org.apache.flink.api.java.tuple.Tuple25
-
Field 9 of the tuple.
- field(Class<? extends Value>, int) - Method in class org.apache.flink.api.java.record.io.CsvInputFormat.AbstractConfigBuilder
-
- field(Class<? extends Value>, int, float) - Method in class org.apache.flink.api.java.record.io.CsvInputFormat.AbstractConfigBuilder
-
- field(Class<? extends Value>, int) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat.AbstractConfigBuilder
-
Adds a field of the record to be serialized to the output.
- FIELD_DELIMITER_PARAMETER - Static variable in class org.apache.flink.api.java.record.io.CsvOutputFormat
-
- FIELD_POS - Static variable in class org.apache.flink.api.java.record.io.TextInputFormat
-
- FIELD_TYPE_PARAMETER_PREFIX - Static variable in class org.apache.flink.api.java.record.io.CsvOutputFormat
-
- fieldDelimiter - Variable in class org.apache.flink.api.java.io.CsvReader
-
- fieldDelimiter(char) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures the delimiter that separates the fields within a row.
- fieldDelimiter(char) - Method in class org.apache.flink.api.java.record.io.CsvInputFormat.AbstractConfigBuilder
-
Sets the delimiter that delimits the individual fields in the records textual input representation.
- fieldDelimiter(char) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat.AbstractConfigBuilder
-
Sets the delimiter that delimits the individual fields in the records
textual output representation.
- fields - Variable in class org.apache.flink.api.java.operators.ProjectOperator
-
- FileDataSink - Class in org.apache.flink.api.java.record.operators
-
Operator for nodes which act as data sinks, storing the data they receive in a file instead of sending it to another
contract.
- FileDataSink(FileOutputFormat<Record>, String, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation
and the given name, writing to the file indicated by the given path.
- FileDataSink(FileOutputFormat<Record>, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation
and a default name, writing to the file indicated by the given path.
- FileDataSink(FileOutputFormat<Record>, String, Operator<Record>) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation the default name,
writing to the file indicated by the given path.
- FileDataSink(FileOutputFormat<Record>, String, List<Operator<Record>>) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- FileDataSink(FileOutputFormat<Record>, String, Operator<Record>, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation and the given name,
writing to the file indicated by the given path.
- FileDataSink(FileOutputFormat<Record>, String, List<Operator<Record>>, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- FileDataSink(Class<? extends FileOutputFormat<Record>>, String, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation
and the given name, writing to the file indicated by the given path.
- FileDataSink(Class<? extends FileOutputFormat<Record>>, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation
and a default name, writing to the file indicated by the given path.
- FileDataSink(Class<? extends FileOutputFormat<Record>>, String, Operator<Record>) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation the default name,
writing to the file indicated by the given path.
- FileDataSink(Class<? extends FileOutputFormat<Record>>, String, List<Operator<Record>>) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- FileDataSink(Class<? extends FileOutputFormat<Record>>, String, Operator<Record>, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Creates a FileDataSink with the provided
FileOutputFormat
implementation and the given name,
writing to the file indicated by the given path.
- FileDataSink(Class<? extends FileOutputFormat<Record>>, String, List<Operator<Record>>, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- FileDataSource - Class in org.apache.flink.api.java.record.operators
-
Operator for input nodes which read data from files.
- FileDataSource(FileInputFormat<Record>, String, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSource
-
Creates a new instance for the given file using the given file input format.
- FileDataSource(FileInputFormat<Record>, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSource
-
Creates a new instance for the given file using the given input format.
- FileDataSource(Class<? extends FileInputFormat<Record>>, String, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSource
-
Creates a new instance for the given file using the given file input format.
- FileDataSource(Class<? extends FileInputFormat<Record>>, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSource
-
Creates a new instance for the given file using the given input format.
- FileInputFormat - Class in org.apache.flink.api.java.record.io
-
The base interface for input formats that read
Record
s from a
file.
- FileInputFormat() - Constructor for class org.apache.flink.api.java.record.io.FileInputFormat
-
- FileOutputFormat - Class in org.apache.flink.api.java.record.io
-
The abstract base class for all output formats that are file based.
- FileOutputFormat() - Constructor for class org.apache.flink.api.java.record.io.FileOutputFormat
-
- filter(FilterFunction<T>) - Method in class org.apache.flink.api.java.DataSet
-
Applies a Filter transformation on a
DataSet
.
The transformation calls a
RichFilterFunction
for each element of the DataSet
and retains only those element for which the function returns true.
- filter(T) - Method in class org.apache.flink.api.java.functions.RichFilterFunction
-
- 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>) - Constructor for class org.apache.flink.api.java.operators.FilterOperator
-
- FixedLengthInputFormat - Class in org.apache.flink.api.java.record.io
-
- FixedLengthInputFormat() - Constructor for class org.apache.flink.api.java.record.io.FixedLengthInputFormat
-
Constructor only sets the key and value classes
- flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.api.java.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(IN, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.RichFlatMapFunction
-
- 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>, FlatMapFunction<IN, OUT>) - Constructor for class org.apache.flink.api.java.operators.FlatMapOperator
-
- FLOAT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- FLOAT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- FLOAT_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- flush() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
-
- 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.
- 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.
- 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
-
- FunctionAnnotation - Class in org.apache.flink.api.java.functions
-
This class defines the semantic assertions that can be added to functions.
- FunctionAnnotation - Class in org.apache.flink.api.java.record.functions
-
This class defines the semantic assertions that can be added to functions.
- FunctionAnnotation.AllFieldsConstants - Annotation Type in org.apache.flink.api.java.record.functions
-
- FunctionAnnotation.ConstantFields - Annotation Type in org.apache.flink.api.java.functions
-
This annotation declares that a function leaves certain fields of its input values unmodified and
only "forwards" or "copies" them to the return value.
- FunctionAnnotation.ConstantFields - Annotation Type in org.apache.flink.api.java.record.functions
-
Specifies the fields of an input record that are unchanged in the output of
a stub with a single input (
MapFunction
,
ReduceFunction
).
- FunctionAnnotation.ConstantFieldsExcept - Annotation Type in org.apache.flink.api.java.functions
-
This annotation declares that a function changes certain fields of its input values, while leaving all
others unmodified and in place in the return value.
- FunctionAnnotation.ConstantFieldsExcept - Annotation Type in org.apache.flink.api.java.record.functions
-
Specifies the fields of an input record that are changed in the output of
a stub with a single input (
MapFunction
,
ReduceFunction
).
- FunctionAnnotation.ConstantFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
-
This annotation declares that a function leaves certain fields of its first input values unmodified and
only "forwards" or "copies" them to the return value.
- FunctionAnnotation.ConstantFieldsFirst - Annotation Type in org.apache.flink.api.java.record.functions
-
Specifies the fields of an input record of the first input that are unchanged in
the output of a stub with two inputs (
CrossFunction
,
JoinFunction
,
CoGroupFunction
)
A field is considered to be constant if its value is not changed and copied to the same position of
output record.
- FunctionAnnotation.ConstantFieldsFirstExcept - Annotation Type in org.apache.flink.api.java.functions
-
This annotation declares that a function changes certain fields of its first input value, while leaving all
others unmodified and in place in the return value.
- FunctionAnnotation.ConstantFieldsFirstExcept - Annotation Type in org.apache.flink.api.java.record.functions
-
Specifies the fields of an input record of the first input that are changed in
the output of a stub with two inputs (
CrossFunction
,
JoinFunction
,
CoGroupFunction
)
All other fields are assumed to be constant.
- FunctionAnnotation.ConstantFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
-
This annotation declares that a function leaves certain fields of its second input values unmodified and
only "forwards" or "copies" them to the return value.
- FunctionAnnotation.ConstantFieldsSecond - Annotation Type in org.apache.flink.api.java.record.functions
-
Specifies the fields of an input record of the second input that are unchanged in
the output of a stub with two inputs (
CrossFunction
,
JoinFunction
,
CoGroupFunction
)
A field is considered to be constant if its value is not changed and copied to the same position of
output record.
- FunctionAnnotation.ConstantFieldsSecondExcept - Annotation Type in org.apache.flink.api.java.functions
-
This annotation declares that a function changes certain fields of its second input value, while leaving all
others unmodified and in place in the return value.
- FunctionAnnotation.ConstantFieldsSecondExcept - Annotation Type in org.apache.flink.api.java.record.functions
-
Specifies the fields of an input record of the second input that are changed in
the output of a stub with two inputs (
CrossFunction
,
JoinFunction
,
CoGroupFunction
)
All other fields are assumed to be constant.
- FunctionAnnotation.ReadFields - Annotation Type in org.apache.flink.api.java.functions
-
Specifies the fields of the input value of a user-defined that are accessed in the code.
- FunctionAnnotation.ReadFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
-
Specifies the fields of the second input value of a user-defined that are accessed in the code.
- FunctionAnnotation.ReadFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
-
Specifies the fields of the first input value of a user-defined that are accessed in the code.
- generateProjectionProperties(CrossOperator.ProjectCrossFunction<?, ?, ?>) - Method in class org.apache.flink.api.java.operators.CrossOperator
-
- generateProjectionProperties(JoinOperator.ProjectFlatJoinFunction<?, ?, ?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
-
- generateSequence(long, long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a new data set that contains a sequence of numbers.
- GenericArraySerializer<C> - Class in org.apache.flink.api.java.typeutils.runtime
-
- GenericArraySerializer(Class<C>, TypeSerializer<C>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.GenericArraySerializer
-
- GenericDataSink - Class in org.apache.flink.api.java.record.operators
-
Operator for nodes that act as data sinks, storing the data they receive.
- GenericDataSink(OutputFormat<Record>, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Creates a GenericDataSink with the provided
OutputFormat
implementation
and the given name.
- GenericDataSink(OutputFormat<Record>) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Creates a GenericDataSink with the provided
OutputFormat
implementation
and a default name.
- GenericDataSink(OutputFormat<Record>, Operator<Record>) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Creates a GenericDataSink with the provided
OutputFormat
implementation the default name.
- GenericDataSink(OutputFormat<Record>, List<Operator<Record>>) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- GenericDataSink(OutputFormat<Record>, Operator<Record>, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Creates a GenericDataSink with the provided
OutputFormat
implementation and the given name.
- GenericDataSink(OutputFormat<Record>, List<Operator<Record>>, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- GenericDataSink(Class<? extends OutputFormat<Record>>, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Creates a GenericDataSink with the provided
OutputFormat
implementation
and the given name.
- GenericDataSink(Class<? extends OutputFormat<Record>>) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Creates a GenericDataSink with the provided
OutputFormat
implementation
and a default name.
- GenericDataSink(Class<? extends OutputFormat<Record>>, Operator<Record>) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Creates a GenericDataSink with the provided
OutputFormat
implementation the default name.
- GenericDataSink(Class<? extends OutputFormat<Record>>, List<Operator<Record>>) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- GenericDataSink(Class<? extends OutputFormat<Record>>, Operator<Record>, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Creates a GenericDataSink with the provided
OutputFormat
implementation and the given name.
- GenericDataSink(Class<? extends OutputFormat<Record>>, List<Operator<Record>>, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- GenericDataSource<T extends InputFormat<Record,?>> - Class in org.apache.flink.api.java.record.operators
-
Abstract superclass for data sources in a Pact plan.
- GenericDataSource(T, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSource
-
Creates a new instance for the given file using the given input format.
- GenericDataSource(T) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSource
-
Creates a new instance for the given file using the given input format, using the default name.
- GenericDataSource(Class<? extends T>, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSource
-
Creates a new instance for the given file using the given input format.
- GenericDataSource(Class<? extends T>) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSource
-
Creates a new instance for the given file using the given input format, using the default name.
- GenericInputFormat - Class in org.apache.flink.api.java.record.io
-
Generic base class for all inputs that are not based on files, specific to Record.
- GenericInputFormat() - Constructor for class org.apache.flink.api.java.record.io.GenericInputFormat
-
- GenericTypeComparator<T extends Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
TypeComparator for all types that extend Comparable.
- GenericTypeComparator(boolean, TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- GenericTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
-
- GenericTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- get() - Static method in class org.apache.flink.api.java.typeutils.runtime.record.RecordPairComparatorFactory
-
Gets an instance of the comparator factory.
- get() - Static method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializer
-
- get() - Static method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializerFactory
-
Gets an instance of the serializer factory.
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
-
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction
-
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction
-
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
-
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
-
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
-
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
-
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
-
- getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
-
- getAggregators() - Method in class org.apache.flink.api.java.DeltaIteration
-
Gets the registry for aggregators for the iteration.
- getAggregators() - Method in class org.apache.flink.api.java.IterativeDataSet
-
Gets the registry for aggregators.
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the number of field in the tuple (the tuple arity).
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple1
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple10
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple11
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple12
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple13
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple14
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple15
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple16
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple17
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple18
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple19
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple20
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple21
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple22
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple23
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple24
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple25
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple3
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple4
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple5
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple6
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple7
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple8
-
- getArity() - Method in class org.apache.flink.api.java.tuple.Tuple9
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- getArity() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- getBasicTupleTypeInfo(Class<?>...) - Static method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- 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.
- 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
-
- getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getComparator() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- getComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- getComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- getComponentInfo() - Method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- getComponentInfo() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getComponentType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getComponentTypeClass() - Method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getDataSet() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getDataSet() - Method in class org.apache.flink.api.java.operators.Grouping
-
- getDataType() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializerFactory
-
- getDataType() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeStatefulSerializerFactory
-
- getDataType() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeStatelessSerializerFactory
-
- getDegreeOfParallelism() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the degree of parallelism with which operation are executed by default.
- 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.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
-
- getExternalProcessCommand() - Method in class org.apache.flink.api.java.record.io.ExternalProcessInputSplit
-
Returns the command to be executed to derive the input for this split
- getFactory() - Method in enum org.apache.flink.api.java.aggregation.Aggregations
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple
-
Gets the field at the specified position.
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
- getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
- getFieldComparator() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- getFields() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-
- getFields() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectFlatJoinFunction
-
- getFieldTypes() - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- getFilePath() - Method in class org.apache.flink.api.java.io.CsvReader
-
- getFilePath() - Method in class org.apache.flink.api.java.record.operators.FileDataSink
-
Returns the configured file path where the output is written to.
- getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getForClass(Class<X>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getFormat() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getForObject(X) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getGroupReduceReturnTypes(GroupReduceFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getGroupSortKeyPositions() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getGroupSortOrders() - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- getId() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the UUID by which this environment is identified.
- getIdString() - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Gets the UUID by which this environment is identified, as a string.
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- getInfoFor(Type, TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getInfoFor(Type) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getInfoFor(Class<X>) - Static method in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- getInitialSolutionSet() - Method in class org.apache.flink.api.java.DeltaIteration
-
Gets the initial solution set.
- getInitialWorkset() - Method in class org.apache.flink.api.java.DeltaIteration
-
Gets the initial workset.
- getInput() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
-
Gets the data set that this operation uses as its input.
- getInput1() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
-
Gets the data set that this operation uses as its first input.
- 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.
- 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.
- getInputFormat() - Method in class org.apache.flink.api.java.operators.DataSource
-
Gets the input format that is executed by this data source.
- getInputFormatTypes(InputFormat<IN, ?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getInputType() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
-
Gets the type information of the data type of the input data set.
- getIsFromFirst() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
-
- getIsFromFirst() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectFlatJoinFunction
-
- getIterationHead() - Method in class org.apache.flink.api.java.BulkIterationResultSet
-
- getIterationHead() - Method in class org.apache.flink.api.java.DeltaIterationResultSet
-
- getJoinHint() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
- getJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getJoinReturnTypes(JoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getKey(IN) - Method in interface org.apache.flink.api.java.functions.KeySelector
-
User-defined function that extracts the key from an arbitrary object.
- getKeyClasses() - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator
-
- getKeyClasses() - Method in class org.apache.flink.api.java.record.operators.CrossOperator
-
- getKeyClasses() - Method in class org.apache.flink.api.java.record.operators.JoinOperator
-
- getKeyClasses() - Method in class org.apache.flink.api.java.record.operators.MapOperator
-
- getKeyClasses() - Method in class org.apache.flink.api.java.record.operators.ReduceOperator
-
- getKeyExtractor() - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
-
- getKeyFields() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- getKeyPositions() - Method in class org.apache.flink.api.java.DeltaIterationResultSet
-
- getKeyPositions() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- getKeyPositions() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- 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.JoinOperator
-
- getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
-
- getKeys2() - Method in class org.apache.flink.api.java.operators.JoinOperator
-
- getKeysAsCopy(Record) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getKeyType() - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
-
- getKeyTypes() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- getLastKey() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericArraySerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- getLogicalPosition(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getLogicalPositions(String[]) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getMaxIterations() - Method in class org.apache.flink.api.java.DeltaIterationResultSet
-
- getMaxIterations() - Method in class org.apache.flink.api.java.IterativeDataSet
-
Gets the maximum number of iterations.
- getName() - Method in class org.apache.flink.api.java.DeltaIteration
-
Gets the name from this iteration.
- getName() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the name of the operator.
- getNextPartialSolution() - Method in class org.apache.flink.api.java.BulkIterationResultSet
-
- getNextSolutionSet() - Method in class org.apache.flink.api.java.DeltaIterationResultSet
-
- getNextWorkset() - Method in class org.apache.flink.api.java.DeltaIterationResultSet
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.java.operators.Keys.ExpressionKeys
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.java.operators.Keys.FieldPositionKeys
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.java.operators.Keys
-
- getNumberOfKeyFields() - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
-
- getParallelism() - Method in class org.apache.flink.api.java.DeltaIteration
-
Gets the iteration's degree of parallelism.
- getParallelism() - Method in class org.apache.flink.api.java.operators.DataSink
-
Returns the degree of parallelism of this data sink.
- getParallelism() - Method in class org.apache.flink.api.java.operators.DataSource
-
Returns the degree of parallelism of this data source.
- getParallelism() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the degree of parallelism of this operator.
- 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
-
- getParameterType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
- getPostPassClassName() - Method in class org.apache.flink.api.java.operators.translation.JavaPlan
-
- getProducedType() - Method in interface org.apache.flink.api.java.typeutils.ResultTypeQueryable
-
Gets the data type (as a
TypeInformation
) produced by this function or input format.
- getReadBufferSize() - Method in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
-
Gets the size of the buffer internally used to parse record boundaries.
- getRecordLength() - Method in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
-
Returns the fixed length of a record.
- getResultType() - Method in class org.apache.flink.api.java.operators.Operator
-
Returns the type of the result of this operator.
- 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
-
- getSemanticPropsSingle(Set<Annotation>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- getSemanticPropsSingleFromString(String[], String[], String[], TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
-
- getSematicProperties() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
-
- getSematicProperties() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
-
- getSematicProperties() - Method in interface org.apache.flink.api.java.operators.UdfOperator
-
Gets the semantic properties that have been set for the user-defined functions (UDF).
- getSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializerFactory
-
- getSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeStatefulSerializerFactory
-
- getSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeStatelessSerializerFactory
-
- getSolutionSet() - Method in class org.apache.flink.api.java.DeltaIteration
-
Gets the solution set of the delta iteration.
- getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
- getTerminationCriterion() - Method in class org.apache.flink.api.java.BulkIterationResultSet
-
- getType() - Method in class org.apache.flink.api.java.DataSet
-
- getType() - Method in class org.apache.flink.api.java.operators.DataSink
-
- getType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getType(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- getTypeClass() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- getTypes(String[]) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- getWorkset() - Method in class org.apache.flink.api.java.DeltaIteration
-
Gets the working set of the delta iteration.
- getWorksetType() - Method in class org.apache.flink.api.java.DeltaIterationResultSet
-
- getWrappedFunction() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
-
- groupBy(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
-
- groupBy(int...) - Method in class org.apache.flink.api.java.DataSet
-
Groups a
Tuple
DataSet
using field position keys.
Note: Field position keys only be specified for Tuple DataSets.
The field position keys specify the fields of Tuples on which the DataSet is grouped.
- Grouping<T> - Class in org.apache.flink.api.java.operators
-
- 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
-
- 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>, GroupReduceFunction<IN, OUT>) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
-
Constructor for a non-grouped reduce (all reduce).
- GroupReduceOperator(Grouping<IN>, GroupReduceFunction<IN, OUT>) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
-
Constructor for a grouped reduce.
- ignoreFirstLine() - Method in class org.apache.flink.api.java.io.CsvReader
-
Sets the CSV reader to ignore the first line.
- includedMask - Variable in class org.apache.flink.api.java.io.CsvReader
-
- includeFields(boolean...) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures which fields of the CSV file should be included and which should be skipped.
- includeFields(String) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures which fields of the CSV file should be included and which should be skipped.
- includeFields(long) - Method in class org.apache.flink.api.java.io.CsvReader
-
Configures which fields of the CSV file should be included and which should be skipped.
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
-
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction
-
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction
-
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
-
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
-
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
-
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
-
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
-
- initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
-
- initializeContextEnvironment(ExecutionEnvironment) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- input(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
-
Sets the input.
- input(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
-
Sets one or several inputs (union).
- input(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.Builder
-
Sets the input.
- input(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.Builder
-
Sets one or several inputs (union).
- input1(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Sets the input operator for input 1.
- input1(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Sets one or several inputs (union) for input 1.
- input1(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
Sets the first input.
- input1(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
Sets one or several inputs (union) for input 1.
- input1(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
-
Sets the first input.
- input1(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
-
Sets one or several inputs (union) for input 1.
- input2(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Sets the input operator for input 2.
- input2(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Sets one or several inputs (union) for input 2.
- input2(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
Sets the second input.
- input2(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
Sets one or several inputs (union) for input 2.
- input2(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
-
Sets the second input.
- input2(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
-
Sets one or several inputs (union) for input 2.
- inputs(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
-
Sets the inputs.
- inputs(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.Builder
-
Sets the inputs.
- inputs1(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Sets the first inputs.
- inputs1(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
Sets the first inputs.
- inputs1(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
-
Sets the first inputs.
- inputs2(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Sets the second inputs.
- inputs2(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
Sets the second inputs.
- inputs2(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
-
Sets the second inputs.
- InputTypeConfigurable - Interface in org.apache.flink.api.java.typeutils
-
OutputFormat
s can implement this interface to be configured
with the data type they will operate on.
- INT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- INT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- INT_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- InvalidTypesException - Exception in org.apache.flink.api.java.functions
-
A special case of the
InvalidProgramException
, indicating that the types used in
an operation are invalid or inconsistent.
- InvalidTypesException() - Constructor for exception org.apache.flink.api.java.functions.InvalidTypesException
-
Creates a new exception with no message.
- InvalidTypesException(String) - Constructor for exception org.apache.flink.api.java.functions.InvalidTypesException
-
Creates a new exception with the given message.
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isBasicType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- isCombinable() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
-
- isCombinable() - Method in class org.apache.flink.api.java.record.operators.ReduceOperator
-
- isContextEnvironmentSet() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- isEmpty() - Method in class org.apache.flink.api.java.operators.Keys
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericArraySerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isKeyType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- isLoggingEnabled() - Method in class org.apache.flink.api.java.LocalEnvironment
-
Checks whether logging during the program execution is enabled or disabled.
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- isSkipInvalidLines() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- isStateful() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- isStateful() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericArraySerializer
-
- isStateful() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- isStateful() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializer
-
- isStateful() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- isStateful() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- isStateful() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- isTupleType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- iterate(int) - Method in class org.apache.flink.api.java.DataSet
-
Initiates an iterative part of the program that executes multiple times and feeds back data sets.
- iterateDelta(DataSet<R>, int, int...) - Method in class org.apache.flink.api.java.DataSet
-
Initiates a delta iteration.
- IterativeDataSet<T> - Class in org.apache.flink.api.java
-
The IterativeDataSet represents the start of an iteration.
- iterator() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-
- IteratorInputFormat<T> - Class in org.apache.flink.api.java.io
-
An input format that returns objects from an iterator.
- IteratorInputFormat(Iterator<T>) - Constructor for class org.apache.flink.api.java.io.IteratorInputFormat
-
- 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
-
- reachedEnd() - Method in class org.apache.flink.api.java.record.io.CollectionInputFormat
-
- reachedEnd() - Method in class org.apache.flink.api.java.record.io.ExternalProcessFixedLengthInputFormat
-
- reachedEnd() - Method in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
-
- read(DataInputView) - Method in class org.apache.flink.api.java.record.io.ExternalProcessInputSplit
-
- readArrayStart() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readBoolean() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readBytes(Record, byte[], int) - Method in class org.apache.flink.api.java.record.io.ExternalProcessFixedLengthInputFormat
-
Reads a record out of the given buffer.
- readBytes(Record, byte[], int) - Method in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
-
Reads a record out of the given buffer.
- readBytes(ByteBuffer) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readCsvFile(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Creates a CSV reader to read a comma separated value (CSV) file.
- readDouble() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readDualConstantAnnotations(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 constant fields annotated.
- readDualConstantAnnotations(UserCodeWrapper<?>) - Static method in class org.apache.flink.api.java.record.functions.FunctionAnnotation
-
- readEnum() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readFields(DataInput) - Method in interface org.apache.hadoop.io.Writable
-
Deserialize the fields of this object from in
.
- readFile(FileInputFormat<X>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
- readFixed(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readFloat() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readIndex() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readInt() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readLong() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readMapStart() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readNull() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparatorFactory
-
- readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializerFactory
-
- readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
-
- readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeStatefulSerializerFactory
-
- readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeStatelessSerializerFactory
-
- readRecord(OUT, byte[], int, int) - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- 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
-
- readRecord(Record, byte[], int, int) - Method in class org.apache.flink.api.java.record.io.CsvInputFormat
-
- readRecord(Record, byte[], int, int) - Method in class org.apache.flink.api.java.record.io.DelimitedInputFormat
-
This function parses the given byte array which represents a serialized key/value
pair.
- readRecord(Record, byte[], int, int) - Method in class org.apache.flink.api.java.record.io.TextInputFormat
-
- readSingleConstantAnnotations(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 constant fields annotated.
- readSingleConstantAnnotations(UserCodeWrapper<?>) - Static method in class org.apache.flink.api.java.record.functions.FunctionAnnotation
-
- readString(Utf8) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readString() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- 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.
- readVarLongCount(DataInput) - Static method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- readWithKeyDenormalization(Record, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- RECORD_DELIMITER - Static variable in class org.apache.flink.api.java.record.io.DelimitedOutputFormat
-
The configuration key for the entry that defines the record delimiter.
- RECORD_DELIMITER_PARAMETER - Static variable in class org.apache.flink.api.java.record.io.CsvOutputFormat
-
- RECORD_POSITION_PARAMETER_PREFIX - Static variable in class org.apache.flink.api.java.record.io.CsvOutputFormat
-
- RecordComparator - Class in org.apache.flink.api.java.typeutils.runtime.record
-
- RecordComparator(int[], Class<? extends Key<?>>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
Creates a new comparator that compares Pact Records by the subset of fields as described
by the given key positions and types.
- RecordComparator(int[], Class<? extends Key<?>>[], boolean[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
Creates a new comparator that compares Pact Records by the subset of fields as described
by the given key positions and types.
- RecordComparatorFactory - Class in org.apache.flink.api.java.typeutils.runtime.record
-
- RecordComparatorFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.record.RecordComparatorFactory
-
- RecordComparatorFactory(int[], Class<? extends Key<?>>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.record.RecordComparatorFactory
-
- RecordComparatorFactory(int[], Class<? extends Key<?>>[], boolean[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.record.RecordComparatorFactory
-
- recordDelimiter(char) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat.AbstractConfigBuilder
-
Sets the delimiter to be a single character, namely the given one.
- recordDelimiter(String) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat.AbstractConfigBuilder
-
Sets the delimiter to be the given string.
- recordDelimiter(String, String) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat.AbstractConfigBuilder
-
Sets the delimiter to be the given string.
- recordDelimiter(char) - Method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat.AbstractConfigBuilder
-
Sets the delimiter to be a single character, namely the given one.
- recordDelimiter(String) - Method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat.AbstractConfigBuilder
-
Sets the delimiter to be the given string.
- recordDelimiter(String, String) - Method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat.AbstractConfigBuilder
-
Sets the delimiter to be the given string.
- recordLength - Variable in class org.apache.flink.api.java.record.io.ExternalProcessFixedLengthInputFormat
-
fixed length of all records
- RECORDLENGTH_PARAMETER_KEY - Static variable in class org.apache.flink.api.java.record.io.ExternalProcessFixedLengthInputFormat
-
The config parameter which defines the fixed length of a record.
- RECORDLENGTH_PARAMETER_KEY - Static variable in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
-
The config parameter which defines the fixed length of a record.
- RecordPairComparator - Class in org.apache.flink.api.java.typeutils.runtime.record
-
- RecordPairComparator(int[], int[], Class<? extends Key<?>>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.record.RecordPairComparator
-
- RecordPairComparatorFactory - Class in org.apache.flink.api.java.typeutils.runtime.record
-
- RecordPairComparatorFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.record.RecordPairComparatorFactory
-
- RecordSerializer - Class in org.apache.flink.api.java.typeutils.runtime.record
-
Implementation of the (de)serialization and copying logic for the
Record
.
- RecordSerializerFactory - Class in org.apache.flink.api.java.typeutils.runtime.record
-
A factory that create a serializer for the
Record
data type.
- RecordSerializerFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializerFactory
-
- RecordTypeInfo - Class in org.apache.flink.api.java.typeutils
-
Type information for the record API.
- RecordTypeInfo() - Constructor for class org.apache.flink.api.java.typeutils.RecordTypeInfo
-
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.api.java.DataSet
-
Applies a Reduce transformation on a non-grouped
DataSet
.
The transformation consecutively calls a
RichReduceFunction
until only a single element remains which is the result of the transformation.
- reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.GroupReduceIterator
-
- reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.RichGroupReduceFunction
-
- reduce(T, T) - Method in class org.apache.flink.api.java.functions.RichReduceFunction
-
- reduce(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.operators.AggregateOperator.AggregatingUdf
-
- reduce(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.operators.DistinctOperator.DistinctFunction
-
- reduce(Iterable<Tuple2<K, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingFlatCombinableGroupReducer
-
- reduce(Iterable<Tuple2<K, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer
-
- reduce(Tuple2<K, T>, Tuple2<K, T>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceOperator.ReduceWrapper
-
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
Applies a Reduce transformation on a grouped
DataSet
.
For each group, the transformation consecutively calls a
RichReduceFunction
until only a single element for each group remains.
- reduce(Iterator<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.functions.ReduceFunction
-
The central function to be implemented for a reducer.
- reduce(Iterable<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.WrappingReduceFunction
-
- ReduceFunction - Class in org.apache.flink.api.java.record.functions
-
The ReduceFunction must be extended to provide a reducer implementation, as invoked by a
ReduceOperator
.
- ReduceFunction() - Constructor for class org.apache.flink.api.java.record.functions.ReduceFunction
-
- reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.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
.
The transformation calls a
RichGroupReduceFunction
for each group of the DataSet.
- reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
- 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>) - 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>) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
-
- ReduceOperator - Class in org.apache.flink.api.java.record.operators
-
ReduceOperator evaluating a
ReduceFunction
over each group of records that share the same key.
- ReduceOperator(ReduceOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.ReduceOperator
-
The private constructor that only gets invoked from the Builder.
- ReduceOperator.Builder - Class in org.apache.flink.api.java.record.operators
-
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
- ReduceOperator.Combinable - Annotation Type in org.apache.flink.api.java.record.operators
-
This annotation marks reduce stubs as eligible for the usage of a combiner.
- ReduceOperator.WrappingClassReduceFunction - Class in org.apache.flink.api.java.record.operators
-
- ReduceOperator.WrappingClassReduceFunction(Class<? extends ReduceFunction>) - Constructor for class org.apache.flink.api.java.record.operators.ReduceOperator.WrappingClassReduceFunction
-
- ReduceOperator.WrappingReduceFunction - Class in org.apache.flink.api.java.record.operators
-
- ReduceOperator.WrappingReduceFunction(ReduceFunction) - Constructor for class org.apache.flink.api.java.record.operators.ReduceOperator.WrappingReduceFunction
-
- registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - Method in class org.apache.flink.api.java.IterativeDataSet
-
- registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.DeltaIteration
-
- registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.IterativeDataSet
-
- 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.
- 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.
- remove() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
-
- ResultTypeQueryable<T> - Interface in org.apache.flink.api.java.typeutils
-
This interface can be implemented by functions and input formats to tell the framework
about their produced data type.
- RichCoGroupFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.java.functions
-
- RichCoGroupFunction() - Constructor for class org.apache.flink.api.java.functions.RichCoGroupFunction
-
- RichCrossFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.java.functions
-
- RichCrossFunction() - Constructor for class org.apache.flink.api.java.functions.RichCrossFunction
-
- RichFilterFunction<T> - Class in org.apache.flink.api.java.functions
-
- RichFilterFunction() - Constructor for class org.apache.flink.api.java.functions.RichFilterFunction
-
- RichFlatCombineFunction<T> - Class in org.apache.flink.api.java.functions
-
- RichFlatCombineFunction() - Constructor for class org.apache.flink.api.java.functions.RichFlatCombineFunction
-
- RichFlatJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.java.functions
-
- RichFlatJoinFunction() - Constructor for class org.apache.flink.api.java.functions.RichFlatJoinFunction
-
- RichFlatMapFunction<IN,OUT> - Class in org.apache.flink.api.java.functions
-
- RichFlatMapFunction() - Constructor for class org.apache.flink.api.java.functions.RichFlatMapFunction
-
- RichGroupReduceFunction<IN,OUT> - Class in org.apache.flink.api.java.functions
-
- RichGroupReduceFunction() - Constructor for class org.apache.flink.api.java.functions.RichGroupReduceFunction
-
- RichGroupReduceFunction.Combinable - Annotation Type in org.apache.flink.api.java.functions
-
- RichJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.java.functions
-
- RichJoinFunction() - Constructor for class org.apache.flink.api.java.functions.RichJoinFunction
-
- RichMapFunction<IN,OUT> - Class in org.apache.flink.api.java.functions
-
- RichMapFunction() - Constructor for class org.apache.flink.api.java.functions.RichMapFunction
-
- RichReduceFunction<T> - Class in org.apache.flink.api.java.functions
-
- RichReduceFunction() - Constructor for class org.apache.flink.api.java.functions.RichReduceFunction
-
- runOperation(CustomUnaryOperation<T, X>) - Method in class org.apache.flink.api.java.DataSet
-
- RuntimeComparatorFactory<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- RuntimeComparatorFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
-
- RuntimeComparatorFactory(TypeComparator<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
-
- RuntimePairComparatorFactory<T1 extends Tuple,T2 extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
-
- RuntimePairComparatorFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
-
- RuntimeStatefulSerializerFactory<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- RuntimeStatefulSerializerFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeStatefulSerializerFactory
-
- RuntimeStatefulSerializerFactory(TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeStatefulSerializerFactory
-
- RuntimeStatelessSerializerFactory<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
- RuntimeStatelessSerializerFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeStatelessSerializerFactory
-
- RuntimeStatelessSerializerFactory(TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeStatelessSerializerFactory
-
- secondaryOrder(Ordering) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.Builder
-
Sets the order of the elements within a group.
- secondaryOrder1(Ordering) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Sets the order of the elements within a group for the first input.
- secondaryOrder2(Ordering) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Sets the order of the elements within a group for the second input.
- SemanticPropUtil - Class in org.apache.flink.api.java.functions
-
- SemanticPropUtil() - Constructor for class org.apache.flink.api.java.functions.SemanticPropUtil
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
-
- serialize(C[], DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericArraySerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
- serialize(Record, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
-
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
-
- serializeRecord(Record, byte[]) - Method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat
-
This method is called for every record so serialize itself into the given target array.
- 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.
- setBroadcastVariable(String, Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Binds the result produced by a plan rooted at root
to a
variable used by the UDF wrapped in this operator.
- setBroadcastVariable(String, Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
Binds the result produced by a plan rooted at root
to a
variable used by the UDF wrapped in this operator.
- setBroadcastVariable(String, Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
-
Binds the result produced by a plan rooted at root
to a
variable used by the UDF wrapped in this operator.
- setBroadcastVariable(String, Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
-
Binds the result produced by a plan rooted at root
to a
variable used by the UDF wrapped in this operator.
- setBroadcastVariable(String, Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.Builder
-
Binds the result produced by a plan rooted at root
to a
variable used by the UDF wrapped in this operator.
- setBroadcastVariables(Map<String, Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
-
Binds multiple broadcast variables.
- setBroadcastVariables(Map<String, Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
Binds multiple broadcast variables.
- setBroadcastVariables(Map<String, Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
-
Binds multiple broadcast variables.
- setBroadcastVariables(Map<String, Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
-
Binds multiple broadcast variables.
- setBroadcastVariables(Map<String, Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.Builder
-
Binds multiple broadcast variables.
- 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
-
- setData(Collection<?>) - Method in class org.apache.flink.api.java.record.io.CollectionInputFormat
-
- setDefaultLocalParallelism(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
-
- setDegreeOfParallelism(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
-
Sets the degree of parallelism (DOP) for operations executed through this environment.
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple
-
Sets the field at the specified position.
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
- setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
- setFields(int[], Class<?>[]) - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- setFields(boolean[], Class<?>[]) - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- setFields(int[], Class<? extends Value>[]) - Method in class org.apache.flink.api.java.record.io.CsvInputFormat
-
- setFields(T0) - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Sets new values to all fields of the tuple.
- setFields(T0, T1) - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2) - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3) - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4) - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5) - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6) - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Sets new values to all fields of the tuple.
- setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Sets new values to all fields of the tuple.
- setFieldTypes(Class<?>...) - Method in class org.apache.flink.api.java.io.CsvInputFormat
-
- setFieldTypes(Class<? extends Value>...) - Method in class org.apache.flink.api.java.record.io.CsvInputFormat
-
- setFieldTypesArray(Class<? extends Value>[]) - Method in class org.apache.flink.api.java.record.io.CsvInputFormat
-
- setIn(DataInput) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- setInput(DataSet<IN>) - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
-
- setInputs(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.GenericDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- setInputs(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.GenericDataSink
-
Deprecated.
This method will be removed in future versions. Use the Union
operator instead.
- setInputType(TypeInformation<?>) - 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<?>) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
-
- setInputType(TypeInformation<?>) - Method in interface org.apache.flink.api.java.typeutils.InputTypeConfigurable
-
Method that is called on an
OutputFormat
when it is passed to
the DataSet's output method.
- setItemCount(long) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
-
- setIter(T) - Method in class org.apache.flink.api.java.record.io.CollectionInputFormat
-
- setLenient(boolean) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat
-
- setNameIfUnset() - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
-
- setOut(DataOutput) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
-
- setParallelism(int) - Method in class org.apache.flink.api.java.operators.DataSink
-
Sets the degree of parallelism for this data sink.
- setParallelism(int) - Method in class org.apache.flink.api.java.operators.DataSource
-
Sets the degree of parallelism for this data source.
- setParallelism(int) - Method in class org.apache.flink.api.java.operators.Operator
-
Sets the degree of parallelism for this operator.
- setQuoteStrings(boolean) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
-
Configures whether the output format should quote string values.
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- setReference(T1) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoPairComparator
-
- setReference(Record) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- setReference(Record) - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordPairComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- setReference(T1) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldPairComparator
-
- setReference(T1) - Method in class org.apache.flink.api.java.typeutils.runtime.TuplePairComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- 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).
- setSkipInvalidLines(boolean) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
-
- setTargetReadBufferSize(int) - Method in class org.apache.flink.api.java.record.io.ExternalProcessFixedLengthInputFormat
-
Sets the target size of the buffer to be used to read from the stdout stream.
- setTargetToStandardErr() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- setTargetToStandardOut() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
-
- setTypes(Class<? extends Value>...) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat
-
- SHORT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- SHORT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- SHORT_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- 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.
- skipArray() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- skipBytes() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- skipFirstLineAsHeader - Variable in class org.apache.flink.api.java.io.CsvReader
-
- skipFixed(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- skipMap() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- skipString() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
-
- SortedGrouping<T> - Class in org.apache.flink.api.java.operators
-
- SortedGrouping(DataSet<T>, Keys<T>, int, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
-
- sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
-
- sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
-
- source() - Static method in class org.apache.flink.api.java.record.operators.OperatorInfoHelper
-
- startItem() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
-
- STRING_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- STRING_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- 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
-
- SumAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction
-
- SumAggregationFunction.ByteSumAgg - Class in org.apache.flink.api.java.aggregation
-
- SumAggregationFunction.ByteSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
-
- SumAggregationFunction.DoubleSumAgg - Class in org.apache.flink.api.java.aggregation
-
- SumAggregationFunction.DoubleSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
-
- SumAggregationFunction.FloatSumAgg - Class in org.apache.flink.api.java.aggregation
-
- SumAggregationFunction.FloatSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
-
- SumAggregationFunction.IntSumAgg - Class in org.apache.flink.api.java.aggregation
-
- SumAggregationFunction.IntSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
-
- SumAggregationFunction.LongSumAgg - Class in org.apache.flink.api.java.aggregation
-
- SumAggregationFunction.LongSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
-
- SumAggregationFunction.ShortSumAgg - Class in org.apache.flink.api.java.aggregation
-
- SumAggregationFunction.ShortSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
-
- SumAggregationFunction.SumAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
-
- SumAggregationFunction.SumAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
-
- supportsCompareAgainstReference() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.record.RecordComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
-
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
-
- swap() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Returns a shallow copy of the tuple with swapped values.
- TextInputFormat - Class in org.apache.flink.api.java.io
-
- TextInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextInputFormat
-
- TextInputFormat - Class in org.apache.flink.api.java.record.io
-
Base implementation for an input format that returns each line as a separate record that contains
only a single string, namely the line.
- TextInputFormat() - Constructor for class org.apache.flink.api.java.record.io.TextInputFormat
-
- TextOutputFormat<T> - Class in org.apache.flink.api.java.io
-
- 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
-
- TextValueInputFormat - Class in org.apache.flink.api.java.io
-
- TextValueInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextValueInputFormat
-
- theString - Variable in class org.apache.flink.api.java.record.io.TextInputFormat
-
- 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.operators.Keys.FieldPositionKeys
-
- toString() - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
-
- toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingFlatCombinableGroupReducer
-
- toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer
-
- toString() - Method in class org.apache.flink.api.java.record.operators.FileDataSink
-
- toString() - Method in class org.apache.flink.api.java.RemoteEnvironment
-
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple1
-
Creates a string representation of the tuple in the form
(f0),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple10
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple11
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple12
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple13
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple14
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple15
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple16
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple17
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple18
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple19
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple2
-
Creates a string representation of the tuple in the form
(f0, f1),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple20
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple21
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple22
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple23
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple24
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22, f23),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple25
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22, f23, f24),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple3
-
Creates a string representation of the tuple in the form
(f0, f1, f2),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple4
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple5
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple6
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple7
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple8
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.tuple.Tuple9
-
Creates a string representation of the tuple in the form
(f0, f1, f2, f3, f4, f5, f6, f7, f8),
where the individual fields are the value returned by calling
Object.toString()
on that field.
- toString() - Method in class org.apache.flink.api.java.typeutils.BasicArrayTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.BasicTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.PrimitiveArrayTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
-
- toString() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
-
- translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.IterativeDataSet
-
- 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.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.GroupReduceOperator
-
- 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.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<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
-
- Tuple - Class in org.apache.flink.api.java.tuple
-
The base class of all tuples.
- Tuple() - Constructor for class org.apache.flink.api.java.tuple.Tuple
-
- Tuple1<T0> - Class in org.apache.flink.api.java.tuple
-
A tuple with 1 fields.
- Tuple1() - Constructor for class org.apache.flink.api.java.tuple.Tuple1
-
Creates a new tuple where all fields are null.
- Tuple1(T0) - Constructor for class org.apache.flink.api.java.tuple.Tuple1
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple10<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in org.apache.flink.api.java.tuple
-
A tuple with 10 fields.
- Tuple10() - Constructor for class org.apache.flink.api.java.tuple.Tuple10
-
Creates a new tuple where all fields are null.
- Tuple10(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Constructor for class org.apache.flink.api.java.tuple.Tuple10
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple10Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple10Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple10Builder
-
- Tuple11<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in org.apache.flink.api.java.tuple
-
A tuple with 11 fields.
- Tuple11() - Constructor for class org.apache.flink.api.java.tuple.Tuple11
-
Creates a new tuple where all fields are null.
- Tuple11(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Constructor for class org.apache.flink.api.java.tuple.Tuple11
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple11Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple11Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple11Builder
-
- Tuple12<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in org.apache.flink.api.java.tuple
-
A tuple with 12 fields.
- Tuple12() - Constructor for class org.apache.flink.api.java.tuple.Tuple12
-
Creates a new tuple where all fields are null.
- Tuple12(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Constructor for class org.apache.flink.api.java.tuple.Tuple12
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple12Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple12Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple12Builder
-
- Tuple13<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in org.apache.flink.api.java.tuple
-
A tuple with 13 fields.
- Tuple13() - Constructor for class org.apache.flink.api.java.tuple.Tuple13
-
Creates a new tuple where all fields are null.
- Tuple13(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Constructor for class org.apache.flink.api.java.tuple.Tuple13
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple13Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple13Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple13Builder
-
- Tuple14<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in org.apache.flink.api.java.tuple
-
A tuple with 14 fields.
- Tuple14() - Constructor for class org.apache.flink.api.java.tuple.Tuple14
-
Creates a new tuple where all fields are null.
- Tuple14(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Constructor for class org.apache.flink.api.java.tuple.Tuple14
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple14Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple14Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple14Builder
-
- Tuple15<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in org.apache.flink.api.java.tuple
-
A tuple with 15 fields.
- Tuple15() - Constructor for class org.apache.flink.api.java.tuple.Tuple15
-
Creates a new tuple where all fields are null.
- Tuple15(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Constructor for class org.apache.flink.api.java.tuple.Tuple15
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple15Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple15Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple15Builder
-
- Tuple16<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in org.apache.flink.api.java.tuple
-
A tuple with 16 fields.
- Tuple16() - Constructor for class org.apache.flink.api.java.tuple.Tuple16
-
Creates a new tuple where all fields are null.
- Tuple16(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Constructor for class org.apache.flink.api.java.tuple.Tuple16
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple16Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple16Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple16Builder
-
- Tuple17<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in org.apache.flink.api.java.tuple
-
A tuple with 17 fields.
- Tuple17() - Constructor for class org.apache.flink.api.java.tuple.Tuple17
-
Creates a new tuple where all fields are null.
- Tuple17(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Constructor for class org.apache.flink.api.java.tuple.Tuple17
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple17Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple17Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple17Builder
-
- Tuple18<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in org.apache.flink.api.java.tuple
-
A tuple with 18 fields.
- Tuple18() - Constructor for class org.apache.flink.api.java.tuple.Tuple18
-
Creates a new tuple where all fields are null.
- Tuple18(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Constructor for class org.apache.flink.api.java.tuple.Tuple18
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple18Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple18Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple18Builder
-
- Tuple19<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in org.apache.flink.api.java.tuple
-
A tuple with 19 fields.
- Tuple19() - Constructor for class org.apache.flink.api.java.tuple.Tuple19
-
Creates a new tuple where all fields are null.
- Tuple19(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Constructor for class org.apache.flink.api.java.tuple.Tuple19
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple19Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple19Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple19Builder
-
- Tuple1Builder<T0> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple1Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple1Builder
-
- Tuple2<T0,T1> - Class in org.apache.flink.api.java.tuple
-
A tuple with 2 fields.
- Tuple2() - Constructor for class org.apache.flink.api.java.tuple.Tuple2
-
Creates a new tuple where all fields are null.
- Tuple2(T0, T1) - Constructor for class org.apache.flink.api.java.tuple.Tuple2
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple20<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in org.apache.flink.api.java.tuple
-
A tuple with 20 fields.
- Tuple20() - Constructor for class org.apache.flink.api.java.tuple.Tuple20
-
Creates a new tuple where all fields are null.
- Tuple20(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Constructor for class org.apache.flink.api.java.tuple.Tuple20
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple20Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple20Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple20Builder
-
- Tuple21<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in org.apache.flink.api.java.tuple
-
A tuple with 21 fields.
- Tuple21() - Constructor for class org.apache.flink.api.java.tuple.Tuple21
-
Creates a new tuple where all fields are null.
- Tuple21(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Constructor for class org.apache.flink.api.java.tuple.Tuple21
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple21Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple21Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple21Builder
-
- Tuple22<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in org.apache.flink.api.java.tuple
-
A tuple with 22 fields.
- Tuple22() - Constructor for class org.apache.flink.api.java.tuple.Tuple22
-
Creates a new tuple where all fields are null.
- Tuple22(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Constructor for class org.apache.flink.api.java.tuple.Tuple22
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple22Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple22Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple22Builder
-
- Tuple23<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in org.apache.flink.api.java.tuple
-
A tuple with 23 fields.
- Tuple23() - Constructor for class org.apache.flink.api.java.tuple.Tuple23
-
Creates a new tuple where all fields are null.
- Tuple23(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Constructor for class org.apache.flink.api.java.tuple.Tuple23
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple23Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple23Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple23Builder
-
- Tuple24<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> - Class in org.apache.flink.api.java.tuple
-
A tuple with 24 fields.
- Tuple24() - Constructor for class org.apache.flink.api.java.tuple.Tuple24
-
Creates a new tuple where all fields are null.
- Tuple24(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Constructor for class org.apache.flink.api.java.tuple.Tuple24
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple24Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple24Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple24Builder
-
- Tuple25<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> - Class in org.apache.flink.api.java.tuple
-
A tuple with 25 fields.
- Tuple25() - Constructor for class org.apache.flink.api.java.tuple.Tuple25
-
Creates a new tuple where all fields are null.
- Tuple25(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Constructor for class org.apache.flink.api.java.tuple.Tuple25
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple25Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple25Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple25Builder
-
- Tuple2Builder<T0,T1> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple2Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple2Builder
-
- Tuple3<T0,T1,T2> - Class in org.apache.flink.api.java.tuple
-
A tuple with 3 fields.
- Tuple3() - Constructor for class org.apache.flink.api.java.tuple.Tuple3
-
Creates a new tuple where all fields are null.
- Tuple3(T0, T1, T2) - Constructor for class org.apache.flink.api.java.tuple.Tuple3
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple3Builder<T0,T1,T2> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple3Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple3Builder
-
- Tuple4<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple
-
A tuple with 4 fields.
- Tuple4() - Constructor for class org.apache.flink.api.java.tuple.Tuple4
-
Creates a new tuple where all fields are null.
- Tuple4(T0, T1, T2, T3) - Constructor for class org.apache.flink.api.java.tuple.Tuple4
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple4Builder<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple4Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple4Builder
-
- Tuple5<T0,T1,T2,T3,T4> - Class in org.apache.flink.api.java.tuple
-
A tuple with 5 fields.
- Tuple5() - Constructor for class org.apache.flink.api.java.tuple.Tuple5
-
Creates a new tuple where all fields are null.
- Tuple5(T0, T1, T2, T3, T4) - Constructor for class org.apache.flink.api.java.tuple.Tuple5
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple5Builder<T0,T1,T2,T3,T4> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple5Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple5Builder
-
- Tuple6<T0,T1,T2,T3,T4,T5> - Class in org.apache.flink.api.java.tuple
-
A tuple with 6 fields.
- Tuple6() - Constructor for class org.apache.flink.api.java.tuple.Tuple6
-
Creates a new tuple where all fields are null.
- Tuple6(T0, T1, T2, T3, T4, T5) - Constructor for class org.apache.flink.api.java.tuple.Tuple6
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple6Builder<T0,T1,T2,T3,T4,T5> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple6Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple6Builder
-
- Tuple7<T0,T1,T2,T3,T4,T5,T6> - Class in org.apache.flink.api.java.tuple
-
A tuple with 7 fields.
- Tuple7() - Constructor for class org.apache.flink.api.java.tuple.Tuple7
-
Creates a new tuple where all fields are null.
- Tuple7(T0, T1, T2, T3, T4, T5, T6) - Constructor for class org.apache.flink.api.java.tuple.Tuple7
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple7Builder<T0,T1,T2,T3,T4,T5,T6> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple7Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple7Builder
-
- Tuple8<T0,T1,T2,T3,T4,T5,T6,T7> - Class in org.apache.flink.api.java.tuple
-
A tuple with 8 fields.
- Tuple8() - Constructor for class org.apache.flink.api.java.tuple.Tuple8
-
Creates a new tuple where all fields are null.
- Tuple8(T0, T1, T2, T3, T4, T5, T6, T7) - Constructor for class org.apache.flink.api.java.tuple.Tuple8
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple8Builder<T0,T1,T2,T3,T4,T5,T6,T7> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple8Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple8Builder
-
- Tuple9<T0,T1,T2,T3,T4,T5,T6,T7,T8> - Class in org.apache.flink.api.java.tuple
-
A tuple with 9 fields.
- Tuple9() - Constructor for class org.apache.flink.api.java.tuple.Tuple9
-
Creates a new tuple where all fields are null.
- Tuple9(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Constructor for class org.apache.flink.api.java.tuple.Tuple9
-
Creates a new tuple and assigns the given values to the tuple's fields.
- Tuple9Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8> - Class in org.apache.flink.api.java.tuple.builder
-
- Tuple9Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple9Builder
-
- TupleComparator<T extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleComparator(int[], TypeComparator<?>[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparator
-
- TupleKeyExtractingMapper<T,K> - Class in org.apache.flink.api.java.operators.translation
-
- TupleKeyExtractingMapper(int) - Constructor for class org.apache.flink.api.java.operators.translation.TupleKeyExtractingMapper
-
- TupleLeadingFieldComparator<T extends Tuple,K> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleLeadingFieldComparator(TypeComparator<K>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldComparator
-
- TupleLeadingFieldPairComparator<K,T1 extends Tuple,T2 extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleLeadingFieldPairComparator(TypeComparator<K>, TypeComparator<K>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleLeadingFieldPairComparator
-
- TuplePairComparator<T1 extends Tuple,T2 extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TuplePairComparator(int[], int[], TypeComparator<Object>[], TypeComparator<Object>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TuplePairComparator
-
- TupleSerializer<T extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
-
- TupleSerializer(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
-
- 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.
- TupleTypeInfo<T extends Tuple> - Class in org.apache.flink.api.java.typeutils
-
- TupleTypeInfo(TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- TupleTypeInfo(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
-
- 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
-
- TupleWrappingCollector<IN,K> - Class in org.apache.flink.api.java.operators.translation
-
Needed to wrap tuples to Tuple2 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.
- TypeExtractor - Class in org.apache.flink.api.java.typeutils
-
- TypeInfoParser - Class in org.apache.flink.api.java.typeutils
-
- TypeInfoParser() - Constructor for class org.apache.flink.api.java.typeutils.TypeInfoParser
-
- 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<T0>) - 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.
- types(Class<T0>, Class<T1>) - 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.
- types(Class<T0>, Class<T1>, Class<T2>) - 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.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>) - 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.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>) - 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.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>) - 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.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>) - 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.
- 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected 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.operators.CrossOperator.CrossProjection
-
Projects a pair of crossed elements to a
Tuple
with the previously selected fields.
- types(Class<T0>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected fields.
- types(Class<T0>, Class<T1>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected fields.
- types(Class<T0>, Class<T1>, Class<T2>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected fields.
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected 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.operators.JoinOperator.JoinProjection
-
Projects a pair of joined elements to a
Tuple
with the previously selected fields.
- types(Class<T0>) - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- types(Class<T0>, Class<T1>) - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- types(Class<T0>, Class<T1>, Class<T2>) - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>) - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>) - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>) - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>) - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-
- 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.operators.ProjectOperator.Projection
-