Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Z 

A

AbstractConfigBuilder(Operator<?>, Configuration) - Constructor for class org.apache.flink.api.java.record.io.CsvInputFormat.AbstractConfigBuilder
Creates a new builder for the given configuration.
AbstractConfigBuilder(Configuration) - Constructor for class org.apache.flink.api.java.record.io.CsvOutputFormat.AbstractConfigBuilder
Creates a new builder for the given configuration.
AbstractConfigBuilder(Configuration) - Constructor for class org.apache.flink.api.java.record.io.DelimitedOutputFormat.AbstractConfigBuilder
Creates a new builder for the given configuration.
accessField(Field, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
This method is handling the IllegalAccess exceptions of Field.get()
add() - Method in class org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class org.apache.flink.api.java.tuple.builder.Tuple15Builder
 
add(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.builder.Tuple16Builder
 
add(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.builder.Tuple17Builder
 
add(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.builder.Tuple18Builder
 
add(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.builder.Tuple19Builder
 
add(T0) - Method in class org.apache.flink.api.java.tuple.builder.Tuple1Builder
 
add(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.builder.Tuple20Builder
 
add(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.builder.Tuple21Builder
 
add(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.builder.Tuple22Builder
 
add(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.builder.Tuple23Builder
 
add(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.builder.Tuple24Builder
 
add(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.builder.Tuple25Builder
 
add(T0, T1) - Method in class org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
add(T0, T1, T2) - Method in class org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
add(T0, T1, T2, T3) - Method in class org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
add(T0, T1, T2, T3, T4) - Method in class org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
add(T0, T1, T2, T3, T4, T5) - Method in class org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
add(T0, T1, T2, T3, T4, T5, T6) - Method in class org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
addContainerMapping(String, TaggedValue, ModifiedASMFrame) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addInput(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.
addInputs(List<? extends 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.
addSemanticPropertiesHints() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
addSerializerForType(ExecutionConfig, Class<?>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
addSourceFieldOffset(SingleInputSemanticProperties, int, int) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
Creates SemanticProperties by adding an offset to each input field index of the given SemanticProperties.
addSourceFieldOffsets(DualInputSemanticProperties, int, int, int, int) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
Creates SemanticProperties by adding offsets to each input field index of the given SemanticProperties.
addToDefaults(String, String) - Method in class org.apache.flink.api.java.utils.ParameterTool
 
aggregate(T) - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
 
aggregate(U) - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.ImmutableMaxAgg
 
aggregate(U) - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MutableMaxAgg
 
aggregate(U) - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.ImmutableMinAgg
 
aggregate(U) - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MutableMinAgg
 
aggregate(Byte) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
 
aggregate(ByteValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteValueSumAgg
 
aggregate(Double) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
 
aggregate(DoubleValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleValueSumAgg
 
aggregate(Float) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
 
aggregate(FloatValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatValueSumAgg
 
aggregate(Integer) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
 
aggregate(IntValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntValueSumAgg
 
aggregate(Long) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
 
aggregate(LongValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongValueSumAgg
 
aggregate(Short) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
 
aggregate(ShortValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortValueSumAgg
 
aggregate(Aggregations, int) - Method in class org.apache.flink.api.java.DataSet
Applies an Aggregate transformation on a non-grouped Tuple DataSet.
Note: Only Tuple DataSets can be aggregated. The transformation applies a built-in Aggregation on a specified field of a Tuple DataSet.
aggregate(Aggregations, int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies an Aggregate transformation on a grouped Tuple DataSet.
Note: Only Tuple DataSets can be aggregated. The transformation applies a built-in Aggregation on a specified field of a Tuple group.
AggregateOperator<IN> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "aggregate" operation on a data set, and the result data set produced by the function.
AggregateOperator(DataSet<IN>, Aggregations, int, String) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator
Non grouped aggregation
AggregateOperator(Grouping<IN>, Aggregations, int, String) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator
Grouped aggregation
AggregateOperator.AggregatingUdf<T extends Tuple> - Class in org.apache.flink.api.java.operators
 
AggregatingUdf(AggregationFunction<Object>[], int[]) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator.AggregatingUdf
 
AggregationFunction<T> - Class in org.apache.flink.api.java.aggregation
 
AggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.AggregationFunction
 
AggregationFunctionFactory - Interface in org.apache.flink.api.java.aggregation
 
Aggregations - Enum in org.apache.flink.api.java.aggregation
 
allowedExitCodes - Variable in class org.apache.flink.api.java.record.io.ExternalProcessInputFormat
Array of allowed exit codes
ALLOWEDEXITCODES_PARAMETER_KEY - Static variable in class org.apache.flink.api.java.record.io.ExternalProcessInputFormat
The config parameter lists (comma separated) all allowed exit codes
analyze() - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
analyze() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
analyzeDualInputUdf(TwoInputUdfOperator<?, ?, ?, ?>, Class<?>, String, Function, Keys<?>, Keys<?>) - Static method in class org.apache.flink.api.java.operators.UdfOperatorUtils
 
analyzePojo(Class<OUT>, ArrayList<Type>, ParameterizedType, TypeInformation<IN1>, TypeInformation<IN2>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
analyzeSingleInputUdf(SingleInputUdfOperator<?, ?, ?>, Class<?>, String, Function, Keys<?>) - Static method in class org.apache.flink.api.java.operators.UdfOperatorUtils
 
and(Aggregations, int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
andMax(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
andMin(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
andSum(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
applyIteratorTrueAssumption() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
areCompatible(Keys<?>) - Method in class org.apache.flink.api.java.operators.Keys
Check if two sets of keys are compatible to each other (matching types, key counts)
areCompatible(Keys<?>) - Method in class org.apache.flink.api.java.operators.Keys.ExpressionKeys
 
areCompatible(Keys<?>) - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
 
areExplicitEnvironmentsAllowed() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment or a RemoteEnvironment.
arity - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
arrayNext() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
ascii - Variable in class org.apache.flink.api.java.record.io.TextInputFormat
 
AvroSchemaSerializer() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.AvroSchemaSerializer
 
AvroSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
General purpose serialization.
AvroSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
AvroSerializer(Class<T>, Class<? extends T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
AvroTypeInfo<T extends org.apache.avro.specific.SpecificRecordBase> - Class in org.apache.flink.api.java.typeutils
Special type information to generate a special AvroTypeInfo for Avro POJOs (implementing SpecificRecordBase, the typed Avro POJOs) Proceeding: It uses a regular pojo type analysis and replaces all GenericType<CharSequence> with a GenericType<avro.Utf8>.
AvroTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.AvroTypeInfo
 

B

BernoulliSampler<T> - Class in org.apache.flink.api.java.sampling
A sampler implementation built upon a Bernoulli trail.
BernoulliSampler(double) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and default random number generator.
BernoulliSampler(double, long) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator seed.
BernoulliSampler(double, Random) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator.
binary() - Static method in class org.apache.flink.api.java.record.operators.OperatorInfoHelper
Deprecated.
 
binaryOperation(AbstractInsnNode, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
BOOLEAN_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
build() - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Creates and returns a CoGroupOperator from using the values given to the builder.
build() - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Creates and returns a CrossOperator from using the values given to the builder.
build() - Method in class org.apache.flink.api.java.record.operators.CrossWithLargeOperator.Builder
Deprecated.
Creates and returns a CrossOperator from using the values given to the builder.
build() - Method in class org.apache.flink.api.java.record.operators.CrossWithSmallOperator.Builder
Deprecated.
Creates and returns a CrossOperator from using the values given to the builder.
build() - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Creates and returns a JoinOperator from using the values given to the builder.
build() - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
Deprecated.
Creates and returns a MapOperator from using the values given to the builder.
build() - Method in class org.apache.flink.api.java.record.operators.MapPartitionOperator.Builder
Deprecated.
Creates and returns a MapOperator from using the values given to the builder.
build() - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.Builder
Creates and returns a ReduceOperator from using the values given to the builder.
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple15Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple16Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple17Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple18Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple1Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple20Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple21Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple22Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple23Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple24Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
builder(CoGroupFunction, Class<? extends Key<?>>, int, int) - Static method in class org.apache.flink.api.java.record.operators.CoGroupOperator
Deprecated.
Creates a Builder with the provided CoGroupFunction implementation.
builder(Class<? extends CoGroupFunction>, Class<? extends Key<?>>, int, int) - Static method in class org.apache.flink.api.java.record.operators.CoGroupOperator
Deprecated.
Creates a Builder with the provided CoGroupFunction implementation.
Builder(UserCodeWrapper<CoGroupFunction<Record, Record, Record>>, Class<? extends Key<?>>, int, int) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Creates a Builder with the provided CoGroupFunction implementation.
Builder(UserCodeWrapper<CoGroupFunction<Record, Record, Record>>) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Creates a Builder with the provided CoGroupFunction implementation.
builder(CrossFunction) - Static method in class org.apache.flink.api.java.record.operators.CrossOperator
Deprecated.
Creates a Builder with the provided CrossFunction implementation.
builder(Class<? extends CrossFunction>) - Static method in class org.apache.flink.api.java.record.operators.CrossOperator
Deprecated.
Creates a Builder with the provided CrossFunction implementation.
Builder(UserCodeWrapper<CrossFunction>) - Constructor for class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Creates a Builder with the provided CrossFunction implementation.
builder(CrossFunction) - Static method in class org.apache.flink.api.java.record.operators.CrossWithLargeOperator
Deprecated.
Creates a Builder with the provided CrossFunction implementation.
builder(Class<? extends CrossFunction>) - Static method in class org.apache.flink.api.java.record.operators.CrossWithLargeOperator
Deprecated.
Creates a Builder with the provided CrossFunction implementation.
builder(CrossFunction) - Static method in class org.apache.flink.api.java.record.operators.CrossWithSmallOperator
Deprecated.
Creates a Builder with the provided CrossFunction implementation.
builder(Class<? extends CrossFunction>) - Static method in class org.apache.flink.api.java.record.operators.CrossWithSmallOperator
Deprecated.
Creates a Builder with the provided CrossFunction implementation.
builder(JoinFunction, Class<? extends Key<?>>, int, int) - Static method in class org.apache.flink.api.java.record.operators.JoinOperator
Deprecated.
Creates a Builder with the provided JoinFunction implementation
builder(Class<? extends JoinFunction>, Class<? extends Key<?>>, int, int) - Static method in class org.apache.flink.api.java.record.operators.JoinOperator
Deprecated.
Creates a Builder with the provided JoinFunction implementation
Builder(UserCodeWrapper<JoinFunction>, Class<? extends Key<?>>, int, int) - Constructor for class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Creates a Builder with the provided JoinFunction implementation
Builder(UserCodeWrapper<JoinFunction>) - Constructor for class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Creates a Builder with the provided JoinFunction implementation.
builder(MapFunction) - Static method in class org.apache.flink.api.java.record.operators.MapOperator
Deprecated.
Creates a Builder with the provided MapFunction implementation.
builder(Class<? extends MapFunction>) - Static method in class org.apache.flink.api.java.record.operators.MapOperator
Deprecated.
Creates a Builder with the provided MapFunction implementation.
builder(MapPartitionFunction) - Static method in class org.apache.flink.api.java.record.operators.MapPartitionOperator
Deprecated.
Creates a Builder with the provided MapPartitionFunction implementation.
builder(Class<? extends MapPartitionFunction>) - Static method in class org.apache.flink.api.java.record.operators.MapPartitionOperator
Deprecated.
Creates a Builder with the provided MapPartitionFunction implementation.
builder(ReduceFunction) - Static method in class org.apache.flink.api.java.record.operators.ReduceOperator
Creates a Builder with the provided ReduceFunction implementation.
builder(ReduceFunction, Class<? extends Key<?>>, int) - Static method in class org.apache.flink.api.java.record.operators.ReduceOperator
Creates a Builder with the provided ReduceFunction implementation.
builder(Class<? extends ReduceFunction>) - Static method in class org.apache.flink.api.java.record.operators.ReduceOperator
Creates a Builder with the provided ReduceFunction implementation.
builder(Class<? extends ReduceFunction>, Class<? extends Key<?>>, int) - Static method in class org.apache.flink.api.java.record.operators.ReduceOperator
Creates a Builder with the provided ReduceFunction implementation.
BulkIteration - Class in org.apache.flink.api.java.record.operators
Deprecated.
BulkIteration() - Constructor for class org.apache.flink.api.java.record.operators.BulkIteration
Deprecated.
 
BulkIteration(String) - Constructor for class org.apache.flink.api.java.record.operators.BulkIteration
Deprecated.
 
BulkIteration.PartialSolutionPlaceHolder - Class in org.apache.flink.api.java.record.operators
Deprecated.
Specialized operator to use as a recognizable place-holder for the input to the step function when composing the nested data flow.
BulkIterationResultSet<T> - Class in org.apache.flink.api.java.operators
 
BYTE_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
ByteArrayInputView - Class in org.apache.flink.api.java.typeutils.runtime
 
ByteArrayInputView(byte[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ByteArrayInputView
 
ByteSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
 
ByteValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteValueSumAgg
 
byteWrapper - Variable in class org.apache.flink.api.java.record.io.TextInputFormat
 

C

canContainFields() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
canContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoField
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
canNotContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
canReadInt() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
canReadLong() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
CHAR_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
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.operators.DeltaIteration.SolutionSetPlaceHolder
 
checkJoinKeyFields(int[]) - Method in class org.apache.flink.api.java.record.operators.DeltaIteration.SolutionSetPlaceHolder
Deprecated.
 
checkSameExecutionContext(DataSet<?>, DataSet<?>) - Static method in class org.apache.flink.api.java.DataSet
 
clean(Object, boolean) - Static method in class org.apache.flink.api.java.ClosureCleaner
 
clean(F) - Method in class org.apache.flink.api.java.DataSet
 
clearContainerMappingMarkedFields() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
clone() - Method in class org.apache.flink.api.java.utils.ParameterTool
 
close() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
close() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
commit the task by moving the output file out from the temporary directory.
close() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
close() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
commit the task by moving the output file out from the temporary directory.
close() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
 
close() - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
 
close() - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
close() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
close() - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
close() - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
close() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
close() - Method in class org.apache.flink.api.java.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
 
close() - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
close() - Method in class org.apache.flink.api.java.Utils.CountHelper
 
closeWith(DataSet<ST>, DataSet<WT>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Closes the delta iteration.
closeWith(DataSet<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Closes the iteration.
closeWith(DataSet<T>, DataSet<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Closes the iteration and specifies a termination criterion.
ClosureCleaner - Class in org.apache.flink.api.java
 
ClosureCleaner() - Constructor for class org.apache.flink.api.java.ClosureCleaner
 
CodeAnalyzerException - Exception in org.apache.flink.api.java.sca
Exception that is thrown if code analysis could not run properly.
CodeAnalyzerException() - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
 
CodeAnalyzerException(String, Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
 
CodeAnalyzerException(String) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
 
CodeAnalyzerException(Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
 
CodeErrorException - Exception in org.apache.flink.api.java.sca
Exception that is thrown if code errors could be found during analysis.
CodeErrorException() - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
 
CodeErrorException(String, Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
 
CodeErrorException(String) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
 
CodeErrorException(Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
 
coGroup(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a CoGroup transformation.
A CoGroup transformation combines the elements of two DataSets into one DataSet.
coGroup(Iterable<Tuple2<K, I1>>, Iterable<Tuple2<K, I2>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanBothUnwrappingCoGroupOperator.TupleBothUnwrappingCoGrouper
 
coGroup(Iterable<Tuple2<K, I1>>, Iterable<I2>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanLeftUnwrappingCoGroupOperator.TupleLeftUnwrappingCoGrouper
 
coGroup(Iterable<I1>, Iterable<Tuple2<K, I2>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanRightUnwrappingCoGroupOperator.TupleRightUnwrappingCoGrouper
 
coGroup(Iterator<Record>, Iterator<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.functions.CoGroupFunction
Deprecated.
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
Deprecated.
 
CoGroupFunction - Class in org.apache.flink.api.java.record.functions
Deprecated.
CoGroupFunction() - Constructor for class org.apache.flink.api.java.record.functions.CoGroupFunction
Deprecated.
 
CoGroupOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A DataSet that is the result of a CoGroup transformation.
CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
 
CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, List<Pair<Integer, Order>>, List<Pair<Integer, Order>>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
 
CoGroupOperator - Class in org.apache.flink.api.java.record.operators
Deprecated.
CoGroupOperator(CoGroupOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator
Deprecated.
The private constructor that only gets invoked from the Builder.
CoGroupOperator.Builder - Class in org.apache.flink.api.java.record.operators
Deprecated.
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
CoGroupOperator.CoGroupOperatorSets<I1,I2> - Class in org.apache.flink.api.java.operators
Intermediate step of a CoGroup transformation.
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate - Class in org.apache.flink.api.java.operators
Intermediate step of a CoGroup transformation.
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction - Class in org.apache.flink.api.java.operators
 
CoGroupOperator.WrappingClassCoGroupFunction - Class in org.apache.flink.api.java.record.operators
Deprecated.
 
CoGroupOperator.WrappingCoGroupFunction - Class in org.apache.flink.api.java.record.operators
Deprecated.
 
CoGroupOperatorSets(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
 
CoGroupRawOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A DataSet that is the result of a CoGroup transformation.
CoGroupRawOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupRawOperator
 
collect() - Method in class org.apache.flink.api.java.DataSet
Convenience method to get the elements of a DataSet as a List.
collect(IN) - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
collect(IN) - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
CollectHelper(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.java.Utils.CollectHelper
 
CollectionDataSource - Class in org.apache.flink.api.java.record.operators
Deprecated.
CollectionDataSource(CollectionInputFormat, String, Object...) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
Deprecated.
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
Deprecated.
 
CollectionDataSource(CollectionInputFormat, Collection<?>, String) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
Deprecated.
 
CollectionDataSource(CollectionInputFormat, T, String) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
Deprecated.
 
CollectionDataSource(String, Object...) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
Deprecated.
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
Deprecated.
 
CollectionDataSource(Collection<?>, String) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
Deprecated.
 
CollectionDataSource(T, String) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
Deprecated.
 
CollectionDataSource(Object...) - Constructor for class org.apache.flink.api.java.record.operators.CollectionDataSource
Deprecated.
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
Deprecated.
 
CollectionEnvironment - Class in org.apache.flink.api.java
 
CollectionEnvironment() - Constructor for class org.apache.flink.api.java.CollectionEnvironment
 
CollectionInputFormat<T> - Class in org.apache.flink.api.java.io
An input format that returns objects from a collection.
CollectionInputFormat(Collection<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.java.io.CollectionInputFormat
 
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.FirstReducer
 
combine(Iterable<Tuple2<K, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingGroupCombineOperator.TupleUnwrappingGroupCombiner
 
combine(Iterable<Tuple2<K, IN>>, Collector<Tuple2<K, IN>>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
combine(Iterable<Tuple3<K1, K2, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedGroupCombineOperator.TupleUnwrappingGroupReducer
 
combine(Iterable<Tuple3<K1, K2, IN>>, Collector<Tuple3<K1, K2, IN>>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
combine(Iterator<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.functions.ReduceFunction
Deprecated.
No default implementation provided.
combine(Iterable<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.WrappingReduceFunction
 
combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Applies a GroupCombineFunction on a non-grouped DataSet.
combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Applies a GroupCombineFunction on a grouped DataSet.
combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies a GroupCombineFunction on a grouped DataSet.
commentPrefix - Variable in class org.apache.flink.api.java.io.CsvReader
 
CommonCsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
 
CommonCsvInputFormat(Path, CompositeType<OUT>) - Constructor for class org.apache.flink.api.java.io.CommonCsvInputFormat
 
CommonCsvInputFormat(Path, String, String, CompositeType<OUT>) - Constructor for class org.apache.flink.api.java.io.CommonCsvInputFormat
 
comparators - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
comparators for the key fields, in the same order as the key fields
compare(T, T) - 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(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
compare(T, T) - 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
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
compareTo(IntermediateSampleData<T>) - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
 
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(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
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
 
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.SelectorFunctionKeys
 
ConfigBuilder(Operator<?>, Configuration) - Constructor for class org.apache.flink.api.java.record.io.CsvInputFormat.ConfigBuilder
 
ConfigBuilder(Configuration) - Constructor for class org.apache.flink.api.java.record.io.CsvOutputFormat.ConfigBuilder
Creates a new builder for the given configuration.
ConfigBuilder(Configuration) - Constructor for class org.apache.flink.api.java.record.io.DelimitedOutputFormat.ConfigBuilder
Creates a new builder for the given configuration.
configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
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.
containerContains(String) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
containerHasReferences() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
context - Variable in class org.apache.flink.api.java.DataSet
 
convertTypeInfoToTaggedValue(TaggedValue.Input, TypeInformation<?>, String, List<CompositeType.FlatFieldDescriptor>, int[]) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
copy() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
copy(Type) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
copy() - Method in class org.apache.flink.api.java.tuple.Tuple
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple0
Shallow tuple copy.
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) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
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) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
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(T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
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(Tuple0) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
copy(Tuple0, Tuple0) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
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.TupleSerializerBase
 
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
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) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
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 org.apache.flink.types.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 org.apache.flink.types.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
 
copyOperation(AbstractInsnNode, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
count() - Method in class org.apache.flink.api.java.DataSet
Convenience method to get the count (number of elements) of a DataSet.
CountHelper(String) - Constructor for class org.apache.flink.api.java.Utils.CountHelper
 
create(Kryo, Input, Class<Collection>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
createAggregationFunction(Class<T>) - Method in interface org.apache.flink.api.java.aggregation.AggregationFunctionFactory
 
createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MaxAggregationFunctionFactory
 
createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MinAggregationFunctionFactory
 
createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
 
createCollectionsEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a CollectionEnvironment that uses Java Collections underneath.
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
createComparator() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
createCopy(Kryo, Collection) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
createDefaultJoin(Keys<I2>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
 
createExecutionEnvironment() - Method in interface org.apache.flink.api.java.ExecutionEnvironmentFactory
Creates an ExecutionEnvironment from this factory.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given InputFormat.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, Job) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given InputFormat.
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.
createInputSplits(int) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
createInputSplits(int) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
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.kryo.KryoSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
createJoinFunctionAssigner(Keys<I2>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
 
createLocalEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a LocalEnvironment.
createLocalEnvironment(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a LocalEnvironment.
createLocalEnvironment(Configuration) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a LocalEnvironment.
createProgramPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates the program's Plan.
createProgramPlan(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates the program's Plan.
createProgramPlan(String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates the program's Plan.
createProjectionPropertiesDual(int[], boolean[], TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
createProjectionPropertiesSingle(int[], CompositeType<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
createPropertiesFile(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Create a properties file with all the known parameters (call after the last get*() call).
createPropertiesFile(String, boolean) - Method in class org.apache.flink.api.java.utils.ParameterTool
Create a properties file with all the known parameters (call after the last get*() call).
createRemoteEnvironment(String, int, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
createResult() - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
createTuple(OUT) - Method in class org.apache.flink.api.java.io.CommonCsvInputFormat
 
createTuple(OUT) - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
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
 
credentials - Variable in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
 
credentials - Variable in class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
 
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(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
Deprecated.
This method must be implemented to provide a user implementation of a cross.
CrossFunction - Class in org.apache.flink.api.java.record.functions
Deprecated.
CrossFunction() - Constructor for class org.apache.flink.api.java.record.functions.CrossFunction
Deprecated.
 
CrossOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A DataSet that is the result of a Cross transformation.
CrossOperator(DataSet<I1>, DataSet<I2>, CrossFunction<I1, I2, OUT>, TypeInformation<OUT>, CrossOperatorBase.CrossHint, String) - Constructor for class org.apache.flink.api.java.operators.CrossOperator
 
CrossOperator - Class in org.apache.flink.api.java.record.operators
Deprecated.
CrossOperator(CrossOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.CrossOperator
Deprecated.
The private constructor that only gets eIinvoked from the Builder.
CrossOperator.Builder - Class in org.apache.flink.api.java.record.operators
Deprecated.
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
CrossOperator.CrossProjection<I1,I2> - Class in org.apache.flink.api.java.operators
 
CrossOperator.DefaultCross<I1,I2> - Class in org.apache.flink.api.java.operators
A Cross transformation that wraps pairs of crossed elements into Tuple2.
It also represents the DataSet that is the result of a Cross transformation.
CrossOperator.DefaultCrossFunction<T1,T2> - Class in org.apache.flink.api.java.operators
 
CrossOperator.ProjectCross<I1,I2,OUT extends Tuple> - Class in org.apache.flink.api.java.operators
A Cross transformation that projects crossing elements or fields of crossing Tuples into result Tuples.
CrossOperator.ProjectCrossFunction<T1,T2,R extends Tuple> - Class in org.apache.flink.api.java.operators
 
CrossProjection(DataSet<I1>, DataSet<I2>, int[], int[], CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
 
crossWithHuge(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Cross transformation.
A Cross transformation combines the elements of two DataSets into one DataSet.
CrossWithLargeOperator - Class in org.apache.flink.api.java.record.operators
Deprecated.
CrossWithLargeOperator(CrossWithLargeOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.CrossWithLargeOperator
Deprecated.
The private constructor that only gets invoked from the Builder.
CrossWithLargeOperator.Builder - Class in org.apache.flink.api.java.record.operators
Deprecated.
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
CrossWithSmallOperator - Class in org.apache.flink.api.java.record.operators
Deprecated.
CrossWithSmallOperator(CrossWithSmallOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.CrossWithSmallOperator
Deprecated.
The private constructor that only gets invoked from the Builder.
CrossWithSmallOperator.Builder - Class in org.apache.flink.api.java.record.operators
Deprecated.
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> - Class in org.apache.flink.api.java.io
 
CsvInputFormat(Path, CompositeType<OUT>) - Constructor for class org.apache.flink.api.java.io.CsvInputFormat
 
CsvInputFormat(Path, String, String, CompositeType<OUT>) - 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.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<T extends Tuple> - Class in org.apache.flink.api.java.io
This is an OutputFormat to serialize Tuples 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 Records 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.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.
CsvReader - Class in org.apache.flink.api.java.io
A builder class to instantiate a CSV parsing data source.
CsvReader(Path, ExecutionEnvironment) - Constructor for class org.apache.flink.api.java.io.CsvReader
 
CsvReader(String, ExecutionEnvironment) - Constructor for class org.apache.flink.api.java.io.CsvReader
 
customPartitioner - Variable in class org.apache.flink.api.java.operators.Grouping
 
CustomUnaryOperation<IN,OUT> - Interface in org.apache.flink.api.java.operators
 

D

data - Variable in class org.apache.flink.api.java.utils.ParameterTool
 
DataInputDecoder - Class in org.apache.flink.api.java.typeutils.runtime
 
DataInputDecoder() - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
DataInputViewStream - Class in org.apache.flink.api.java.typeutils.runtime
An input stream that draws its data from a DataInputView.
DataInputViewStream(DataInputView) - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
DataOutputEncoder - Class in org.apache.flink.api.java.typeutils.runtime
 
DataOutputEncoder() - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
DataOutputViewStream - Class in org.apache.flink.api.java.typeutils.runtime
 
DataOutputViewStream(DataOutputView) - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
DataSet<T> - Class in org.apache.flink.api.java
A DataSet represents a collection of elements of the same type.
A DataSet can be transformed into another DataSet by applying a transformation as for example DataSet.map(org.apache.flink.api.common.functions.MapFunction), DataSet.reduce(org.apache.flink.api.common.functions.ReduceFunction), DataSet.join(DataSet), or DataSet.coGroup(DataSet).
DataSet(ExecutionEnvironment, TypeInformation<T>) - Constructor for class org.apache.flink.api.java.DataSet
 
dataSet - Variable in class org.apache.flink.api.java.operators.Grouping
 
DataSetUtils - Class in org.apache.flink.api.java.utils
This class provides simple utility methods for zipping elements in a data set with an index or with a unique identifier.
DataSink<T> - Class in org.apache.flink.api.java.operators
 
DataSink(DataSet<T>, OutputFormat<T>, TypeInformation<T>) - Constructor for class org.apache.flink.api.java.operators.DataSink
 
DataSource<OUT> - Class in org.apache.flink.api.java.operators
An operation that creates a new data set (data source).
DataSource(ExecutionEnvironment, InputFormat<OUT, ?>, TypeInformation<OUT>, String) - Constructor for class org.apache.flink.api.java.operators.DataSource
Creates a new data source.
decoder - Variable in class org.apache.flink.api.java.record.io.TextInputFormat
 
DEFAULT_CHARSET_NAME - Static variable in class org.apache.flink.api.java.record.io.TextInputFormat
 
DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.flink.api.java.io.CommonCsvInputFormat
 
DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvOutputFormat
 
DEFAULT_LINE_DELIMITER - Static variable in class org.apache.flink.api.java.io.CommonCsvInputFormat
 
DEFAULT_LINE_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvOutputFormat
 
DEFAULT_UNDEFINED - Static variable in class org.apache.flink.api.java.utils.ParameterTool
 
DefaultCross(DataSet<I1>, DataSet<I2>, CrossOperatorBase.CrossHint, String) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
 
DefaultCrossFunction() - Constructor for class org.apache.flink.api.java.operators.CrossOperator.DefaultCrossFunction
 
defaultData - Variable in class org.apache.flink.api.java.utils.ParameterTool
 
DefaultFlatJoinFunction() - Constructor for class org.apache.flink.api.java.operators.JoinOperator.DefaultFlatJoinFunction
 
DefaultJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, String, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
 
defaultName - Variable in class org.apache.flink.api.java.operators.FilterOperator
 
defaultName - Variable in class org.apache.flink.api.java.operators.FlatMapOperator
 
defaultName - Variable in class org.apache.flink.api.java.operators.MapOperator
 
defaultName - Variable in class org.apache.flink.api.java.operators.MapPartitionOperator
 
DelimitedInputFormat - Class in org.apache.flink.api.java.record.io
Base implementation for input formats that split the input at a delimiter into records.
DelimitedInputFormat() - Constructor for class org.apache.flink.api.java.record.io.DelimitedInputFormat
 
DelimitedOutputFormat - Class in org.apache.flink.api.java.record.io
The base class for output formats that serialize their records into a delimited sequence.
DelimitedOutputFormat() - Constructor for class org.apache.flink.api.java.record.io.DelimitedOutputFormat
 
DelimitedOutputFormat.AbstractConfigBuilder<T> - 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.
DelimitedOutputFormat.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.
DeltaIteration<ST,WT> - Class in org.apache.flink.api.java.operators
The DeltaIteration represents the start of a delta iteration.
DeltaIteration(ExecutionEnvironment, TypeInformation<ST>, DataSet<ST>, DataSet<WT>, Keys<ST>, int) - Constructor for class org.apache.flink.api.java.operators.DeltaIteration
 
DeltaIteration - Class in org.apache.flink.api.java.record.operators
Deprecated.
DeltaIteration(int) - Constructor for class org.apache.flink.api.java.record.operators.DeltaIteration
Deprecated.
 
DeltaIteration(int[]) - Constructor for class org.apache.flink.api.java.record.operators.DeltaIteration
Deprecated.
 
DeltaIteration(int, String) - Constructor for class org.apache.flink.api.java.record.operators.DeltaIteration
Deprecated.
 
DeltaIteration(int[], String) - Constructor for class org.apache.flink.api.java.record.operators.DeltaIteration
Deprecated.
 
DeltaIteration.SolutionSetPlaceHolder<ST> - Class in org.apache.flink.api.java.operators
A DataSet that acts as a placeholder for the solution set during the iteration.
DeltaIteration.SolutionSetPlaceHolder - Class in org.apache.flink.api.java.record.operators
Deprecated.
Specialized operator to use as a recognizable place-holder for the solution set input to the step function.
DeltaIteration.WorksetPlaceHolder<WT> - Class in org.apache.flink.api.java.operators
A DataSet that acts as a placeholder for the workset during the iteration.
DeltaIteration.WorksetPlaceHolder - Class in org.apache.flink.api.java.record.operators
Deprecated.
Specialized operator to use as a recognizable place-holder for the working set input to the step function.
DeltaIterationResultSet<ST,WT> - Class in org.apache.flink.api.java.operators
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.io.TypeSerializerInputFormat
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
deserialize(Tuple0, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
deserializedFields1 - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
deserializedFields2 - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
DiscardingOutputFormat<T> - Class in org.apache.flink.api.java.io
An output format that simply discards all elements.
DiscardingOutputFormat() - Constructor for class org.apache.flink.api.java.io.DiscardingOutputFormat
 
dispose() - Method in class org.apache.flink.api.java.RemoteEnvironment
 
distinct(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Returns a distinct set of a DataSet using a KeySelector function.
distinct(int...) - Method in class org.apache.flink.api.java.DataSet
Returns a distinct set of a Tuple DataSet using field position keys.
distinct(String...) - Method in class org.apache.flink.api.java.DataSet
Returns a distinct set of a DataSet using expression keys.
distinct() - Method in class org.apache.flink.api.java.DataSet
Returns a distinct set of a DataSet.
DistinctFunction() - Constructor for class org.apache.flink.api.java.operators.DistinctOperator.DistinctFunction
 
DistinctOperator<T> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "distinct" function on a data set, and the result data set produced by the function.
DistinctOperator(DataSet<T>, Keys<T>, String) - Constructor for class org.apache.flink.api.java.operators.DistinctOperator
 
DistinctOperator.DistinctFunction<T> - Class in org.apache.flink.api.java.operators
 
DistributedRandomSampler<T> - Class in org.apache.flink.api.java.sampling
For sampling with fraction, the sample algorithms are natively distributed, while it's not true for fixed size sample algorithms.
DistributedRandomSampler(int) - Constructor for class org.apache.flink.api.java.sampling.DistributedRandomSampler
 
DOUBLE_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
DoubleSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
 
DoubleValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleValueSumAgg
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 

E

EMPTY_INTERMEDIATE_ITERABLE - Variable in class org.apache.flink.api.java.sampling.DistributedRandomSampler
 
EMPTY_ITERABLE - Variable in class org.apache.flink.api.java.sampling.RandomSampler
 
ensureSerializable(Object) - Static method in class org.apache.flink.api.java.ClosureCleaner
 
EnumTypeInfo<T extends Enum<T>> - Class in org.apache.flink.api.java.typeutils
A TypeInformation for java enumeration types.
EnumTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
eof() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
EPSILON - Static variable in class org.apache.flink.api.java.sampling.RandomSampler
 
equals(Object) - Method in class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
 
equals(Object) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple0
Deep equality for tuples by calling equals() on the tuple members
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.EnumTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.PojoField
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
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.RuntimeSerializerFactory
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
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(String...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
Continues a CoGroup transformation and defines the fields of the second co-grouped DataSet that should be used as grouping keys.
equalTo(KeySelector<I2, K>) - 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.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
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 JoinFunctionAssigner needs to be finished by providing a JoinFunction by calling JoinFunctionAssigner.with(JoinFunction)
equalTo(String...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Continues a Join transformation and defines the fields of the second join DataSet that should be used as join keys.
The resulting JoinFunctionAssigner needs to be finished by providing a JoinFunction by calling JoinFunctionAssigner.with(JoinFunction)
equalTo(KeySelector<I2, K>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
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.
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.
equalTo(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
Continues a Join transformation and defines the fields of the second join DataSet that should be used as join keys.
equalTo(KeySelector<I2, K>) - 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(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
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
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, JoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, JoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
execute(String) - Method in class org.apache.flink.api.java.CollectionEnvironment
 
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
 
execute(AbstractInsnNode, Interpreter) - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
ExecutionEnvironment - Class in org.apache.flink.api.java
The ExecutionEnvironment is the context in which a program is executed.
ExecutionEnvironment() - Constructor for class org.apache.flink.api.java.ExecutionEnvironment
Creates a new Execution Environment.
ExecutionEnvironmentFactory - Interface in org.apache.flink.api.java
Factory class for execution environments.
ExpressionKeys(int[], TypeInformation<T>) - Constructor for class org.apache.flink.api.java.operators.Keys.ExpressionKeys
two constructors for field-based (tuple-type) keys
ExpressionKeys(int[], TypeInformation<T>, boolean) - Constructor for class org.apache.flink.api.java.operators.Keys.ExpressionKeys
 
ExpressionKeys(String[], TypeInformation<T>) - Constructor for class org.apache.flink.api.java.operators.Keys.ExpressionKeys
Create ExpressionKeys from String-expressions
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 information for InputFormat that read their data from external processes.
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
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
extractSemanticAnnotations(Class<?>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 

F

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.
fetched - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
fetched - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
fetchNext() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
fetchNext() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
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
Deprecated.
fieldDelimiter(String) - 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.
fieldNames - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
fields - Variable in class org.apache.flink.api.java.operators.ProjectOperator
 
fieldSerializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
FileDataSink - Class in org.apache.flink.api.java.record.operators
Deprecated.
FileDataSink(FileOutputFormat<Record>, String, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSink
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
FileDataSource(FileInputFormat<Record>, String, String) - Constructor for class org.apache.flink.api.java.record.operators.FileDataSource
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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 Records 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
 
fillInType(TypeInformation<T>) - Method in class org.apache.flink.api.java.DataSet
Tries to fill in the type information.
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.
FilterOperator<T> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "filter" function on a data set, and the result data set produced by the function.
FilterOperator(DataSet<T>, FilterFunction<T>, String) - Constructor for class org.apache.flink.api.java.operators.FilterOperator
 
finalizeGlobal(int) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
finalizeGlobal(int) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
findMethodNode(String, Method) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
findMethodNode(String, String, String) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
first(int) - Method in class org.apache.flink.api.java.DataSet
Returns a new set containing the first n elements in this DataSet.
first(int) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Returns a new set containing the first n elements in this grouped and sorted DataSet.
first(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Returns a new set containing the first n elements in this grouped DataSet.
FirstReducer<T> - Class in org.apache.flink.api.java.functions
 
FirstReducer(int) - Constructor for class org.apache.flink.api.java.functions.FirstReducer
 
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
Applies a FlatMap transformation on a DataSet.
The transformation calls a RichFlatMapFunction for each element of the 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
Delegates calls to the FlatMapIterator.flatMap(Object) method.
flatMap(T, Collector<T>) - Method in class org.apache.flink.api.java.operators.translation.PlanFilterOperator.FlatMapFilter
 
flatMap(T, Collector<T>) - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
flatMap(T, Collector<Long>) - Method in class org.apache.flink.api.java.Utils.CountHelper
 
FlatMapIterator<IN,OUT> - Class in org.apache.flink.api.java.functions
A convenience variant of the RichFlatMapFunction that returns elements through an iterator, rather then through a collector.
FlatMapIterator() - Constructor for class org.apache.flink.api.java.functions.FlatMapIterator
 
FlatMapOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "flatMap" function on a data set, and the result data set produced by the function.
FlatMapOperator(DataSet<IN>, TypeInformation<OUT>, FlatMapFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.FlatMapOperator
 
FLOAT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
FloatSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
 
FloatValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatValueSumAgg
 
flush() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
format(IN) - Method in interface org.apache.flink.api.java.io.TextOutputFormat.TextFormatter
 
FormattingMapper<T> - Class in org.apache.flink.api.java.functions
 
FormattingMapper(TextOutputFormat.TextFormatter<T>) - Constructor for class org.apache.flink.api.java.functions.FormattingMapper
 
fromArgs(String[]) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given arguments.
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.
fromGenericOptionsParser(String[]) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the arguments parsed by GenericOptionsParser
fromMap(Map<String, String>) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given map
fromParallelCollection(SplittableIterator<X>, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a new data set that contains elements in the iterator.
fromParallelCollection(SplittableIterator<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a new data set that contains elements in the iterator.
fromPropertiesFile(String) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given Properties file
fromSystemProperties() - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool from the system properties.
fullOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Full Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of both DataSets that do not have a matching element on the opposing side are joined with null and emitted to the resulting DataSet.
fullOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Initiates a Full Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of both DataSets that do not have a matching element on the opposing side are joined with null and emitted to the resulting DataSet.
function - Variable in class org.apache.flink.api.java.operators.FilterOperator
 
function - Variable in class org.apache.flink.api.java.operators.FlatMapOperator
 
function - Variable in class org.apache.flink.api.java.operators.MapOperator
 
function - Variable in class org.apache.flink.api.java.operators.MapPartitionOperator
 
FunctionAnnotation - Class in org.apache.flink.api.java.functions
This class defines Java annotations for semantic assertions that can be added to Flink functions.
FunctionAnnotation - Class in org.apache.flink.api.java.record.functions
Deprecated.
FunctionAnnotation.AllFieldsConstants - Annotation Type in org.apache.flink.api.java.record.functions
Deprecated.
Specifies that all fields of an input record that are unchanged in the output of a MapFunction, or ReduceFunction).
FunctionAnnotation.ConstantFields - Annotation Type in org.apache.flink.api.java.record.functions
Deprecated.
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.record.functions
Deprecated.
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.record.functions
Deprecated.
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.record.functions
Deprecated.
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.record.functions
Deprecated.
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.record.functions
Deprecated.
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.ForwardedFields - Annotation Type in org.apache.flink.api.java.functions
The ForwardedFields annotation declares fields which are never modified by the annotated function and which are forwarded at the same position to the output or unchanged copied to another position in the output.
FunctionAnnotation.ForwardedFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
The ForwardedFieldsFirst annotation declares fields of the first input of a function which are never modified by the annotated function and which are forwarded at the same position to the output or unchanged copied to another position in the output.
FunctionAnnotation.ForwardedFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
The ForwardedFieldsSecond annotation declares fields of the second input of a function which are never modified by the annotated function and which are forwarded at the same position to the output or unchanged copied to another position in the output.
FunctionAnnotation.NonForwardedFields - Annotation Type in org.apache.flink.api.java.functions
The NonForwardedFields annotation declares ALL fields which not preserved on the same position in a functions output.
FunctionAnnotation.NonForwardedFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
The NonForwardedFieldsFirst annotation declares for a function ALL fields of its first input which are not preserved on the same position in its output.
FunctionAnnotation.NonForwardedFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
The NonForwardedFieldsSecond annotation declares for a function ALL fields of its second input which are not preserved on the same position in its output.
FunctionAnnotation.ReadFields - Annotation Type in org.apache.flink.api.java.functions
The ReadFields annotation declares for a function all fields which it accesses and evaluates, i.e., all fields that are used by the function to compute its result.
FunctionAnnotation.ReadFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
The ReadFieldsFirst annotation declares for a function all fields of the first input which it accesses and evaluates, i.e., all fields of the first input that are used by the function to compute its result.
FunctionAnnotation.ReadFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
The ReadFieldsSecond annotation declares for a function all fields of the second input which it accesses and evaluates, i.e., all fields of the second input that are used by the function to compute its result.
FunctionAnnotation.SkipCodeAnalysis - Annotation Type in org.apache.flink.api.java.functions
The SkipCodeAnalysis annotation declares that a function will not be analyzed by Flink's code analysis capabilities independent of the configured CodeAnalysisMode.

G

generateSequence(long, long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a new data set that contains a sequence of numbers.
GenericDataSink - Class in org.apache.flink.api.java.record.operators
Deprecated.
GenericDataSink(OutputFormat<Record>, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSink
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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 org.apache.flink.api.common.io.InputFormat<org.apache.flink.types.Record,?>> - Class in org.apache.flink.api.java.record.operators
Deprecated.
GenericDataSource(T, String) - Constructor for class org.apache.flink.api.java.record.operators.GenericDataSource
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the String value for the given key.
get(String, String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the String value for the given key.
getAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.ImmutableMaxAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MutableMaxAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.ImmutableMinAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MutableMinAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortValueSumAgg
 
getAggregators() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the registry for aggregators for the iteration.
getAggregators() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Gets the registry for aggregators.
getAllDeclaredFields(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
recursively determine all declared fields This is required because class.getFields() is not returning fields defined in parent classes.
getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
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.Tuple0
 
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.EnumTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
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.RecordTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getArity() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getArity() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
getBasicAndBasicValueTupleTypeInfo(Class<?>...) - Static method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getBasicTupleTypeInfo(Class<?>...) - Static method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getBinaryOperatorReturnType(Function, Class<?>, boolean, boolean, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getBitSize(long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
 
getBoolean(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Boolean value for the given key.
getBoolean(String, boolean) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Boolean value for the given key.
getBroadcastSets() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getBroadcastSets() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
getBroadcastSets() - Method in interface org.apache.flink.api.java.operators.UdfOperator
Gets the broadcast sets (name and data set) that have been added to context of the UDF.
getByte(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Byte value for the given key.
getByte(String, byte) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Byte value for the given key.
getCallLocationName() - Static method in class org.apache.flink.api.java.Utils
 
getCallLocationName(int) - Static method in class org.apache.flink.api.java.Utils
 
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
 
getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getCollectorValues() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getComponentInfo() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getConfig() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the config object that defines execution parameters.
getConfiguration() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
getConfiguration() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
getConfiguration() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns a Configuration object from this ParameterTool
getContainedGenericTypes(CompositeType, List<GenericTypeInfo<?>>) - Static method in class org.apache.flink.api.java.Utils
Returns all GenericTypeInfos contained in a composite type.
getContainerMapping() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getCounter(Enum<?>) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
getCounter(String, String) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
getCredentialsFromUGI(UserGroupInformation) - Static method in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
This method only exists because there is no UserGroupInformation.getCredentials() method in Hadoop 1.x Note that this method returns "null" in Hadoop 1.x environments.
getCrossHint() - Method in class org.apache.flink.api.java.operators.CrossOperator
 
getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getCustomPartitioner() - Method in class org.apache.flink.api.java.operators.Grouping
Gets the custom partitioner to be used for this grouping, or null, if none was defined.
getCustomPartitioner() - Method in class org.apache.flink.api.java.operators.PartitionOperator
Gets the custom partitioner from this partitioning.
getDataSet() - Method in class org.apache.flink.api.java.operators.DataSink
 
getDataSet() - Method in class org.apache.flink.api.java.operators.Grouping
 
getDataType() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
getDeclaredField(Class<?>, String) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getDouble(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Double value for the given key.
getDouble(String, double) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Double value for the given key.
getElement() - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
 
getExecutionEnvironment() - Method in class org.apache.flink.api.java.DataSet
Returns the ExecutionEnvironment in which this DataSet is registered.
getExecutionEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionPlan() - Method in class org.apache.flink.api.java.CollectionEnvironment
 
getExecutionPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates the plan with which the system will execute the program, and returns it as a String using a JSON representation of the execution data flow graph.
getExecutionPlan() - Method in class org.apache.flink.api.java.LocalEnvironment
 
getExecutionPlan() - Method in class org.apache.flink.api.java.RemoteEnvironment
 
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.Tuple0
 
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
 
getField() - Method in class org.apache.flink.api.java.typeutils.PojoField
 
getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getFieldName() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
getFieldNames() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFieldNames() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getFieldNotNull(int) - Method in class org.apache.flink.api.java.tuple.Tuple
Gets the field at the specified position, throws NullFieldException if the field is null.
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.CommonCsvInputFormat
 
getFilePath() - Method in class org.apache.flink.api.java.io.CsvReader
 
getFilePath() - Method in class org.apache.flink.api.java.record.operators.FileDataSink
Deprecated.
Returns the configured file path where the output is written to.
getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
getFlatFieldExpr() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFloat(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Float value for the given key.
getFloat(String, float) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Float value for the given key.
getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - 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
Creates type information from a given Class such as Integer, String[] or POJOs.
getFormat() - Method in class org.apache.flink.api.java.operators.DataSink
 
getForObject(X) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
getFunction() - Method in class org.apache.flink.api.java.operators.FilterOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.FlatMapOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
getFunction() - Method in class org.apache.flink.api.java.operators.MapOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.ReduceOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
getFunctionName() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - 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
 
getGroupReduceReturnTypes(GroupReduceFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - 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
 
getHadoopConfiguration() - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
Returns a new Hadoop Configuration object using the path to the hadoop conf configured in the main configuration (flink-conf.yaml).
getHadoopInputSplit() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
 
getHadoopInputSplit() - Method in class org.apache.flink.api.java.hadoop.mapreduce.wrapper.HadoopInputSplit
 
getHostnames() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
 
getHostnames() - Method in class org.apache.flink.api.java.hadoop.mapreduce.wrapper.HadoopInputSplit
 
getId() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the JobID by which this environment is identified.
getId() - Method in enum org.apache.flink.api.java.sca.TaggedValue.Input
 
getIdString() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the JobID by which this environment is identified, as a string.
getInfoFor(Class<T>, TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getInfoFor(TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
Creates a new ObjectArrayTypeInfo from a TypeInformation for the component type.
getInitialSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the initial solution set.
getInitialWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the initial workset.
getInput() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
Gets the data set that this operation uses as its input.
getInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getInput1() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Gets the data set that this operation uses as its first input.
getInput1AsTaggedValue() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getInput1Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Gets the type information of the data type of the first input data set.
getInput2() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Gets the data set that this operation uses as its second input.
getInput2AsTaggedValue() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getInput2Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Gets the type information of the data type of the second input data set.
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
 
getInputSplit() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
getInputSplitAssigner(HadoopInputSplit[]) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
getInputSplitAssigner(HadoopInputSplit[]) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
getInputType() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
Gets the type information of the data type of the input data set.
getInputView() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
getInt(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Integer value for the given key.
getInt(String, int) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Integer value for the given key.
getIntConstant() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getInternalUdfClassName() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getIsFromFirst() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
 
getIsFromFirst() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectFlatJoinFunction
 
getIterationHead() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
 
getIterationHead() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getJobConf() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
getJobConf() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
getJobConf() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
 
getJoinHint() - Method in class org.apache.flink.api.java.operators.JoinOperator
Gets the JoinHint that describes how the join is executed.
getJoinReturnTypes(JoinFunction<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>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getJoinType() - Method in class org.apache.flink.api.java.operators.JoinOperator
Gets the JoinType that describes this join operation (e.g.
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
Deprecated.
 
getKeyClasses() - Method in class org.apache.flink.api.java.record.operators.CrossOperator
Deprecated.
 
getKeyClasses() - Method in class org.apache.flink.api.java.record.operators.JoinOperator
Deprecated.
 
getKeyClasses() - Method in class org.apache.flink.api.java.record.operators.MapOperator
Deprecated.
 
getKeyClasses() - Method in class org.apache.flink.api.java.record.operators.MapPartitionOperator
Deprecated.
 
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.operators.DeltaIterationResultSet
 
getKeyPositions() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getKeys() - Method in class org.apache.flink.api.java.operators.Grouping
 
getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
getKeys1() - Method in class org.apache.flink.api.java.operators.JoinOperator
 
getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
getKeys2() - Method in class org.apache.flink.api.java.operators.JoinOperator
 
getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getKeyType() - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
 
getKryo() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
getLastGroupKey() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
getLastJobExecutionResult() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Returns the JobExecutionResult of the last executed job.
getLastKey() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
getLastSortKey() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
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.kryo.KryoSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
getLong(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Long value for the given key.
getLong(String, long) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Long value for the given key.
getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getMaxIterations() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getMaxIterations() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Gets the maximum number of iterations.
getName() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the name from this iteration.
getName() - Method in class org.apache.flink.api.java.operators.Operator
Returns the name of the operator.
getNextPartialSolution() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
 
getNextSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getNextWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
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.TupleComparatorBase
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
getNumberOfExecutionRetries() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the number of times the system will try to re-execute failed tasks.
getNumberOfKeyFields() - Method in class org.apache.flink.api.java.operators.Keys.ExpressionKeys
 
getNumberOfKeyFields() - Method in class org.apache.flink.api.java.operators.Keys
 
getNumberOfKeyFields() - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
 
getNumberOfParameters() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns number of parameters in ParameterTool.
getParallelism() - Method in class org.apache.flink.api.java.CollectionEnvironment
 
getParallelism() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the parallelism with which operation are executed by default.
getParallelism() - Method in class org.apache.flink.api.java.operators.DataSink
Returns the parallelism of this data sink.
getParallelism() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the iteration's parallelism.
getParallelism() - Method in class org.apache.flink.api.java.operators.Operator
Returns the parallelism of this operator.
getParameters() - Method in class org.apache.flink.api.java.operators.DataSink
 
getParameters() - Method in class org.apache.flink.api.java.operators.DataSource
 
getParameters() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getParameters() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
getParameters() - Method in interface org.apache.flink.api.java.operators.UdfOperator
Gets the configuration parameters that will be passed to the UDF's open method AbstractRichFunction.open(Configuration).
getParameterType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Gets the custom partitioner used by this join, or null, if none is set.
getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Gets the custom partitioner used by this join, or null, if none is set.
getPartitioner() - Method in class org.apache.flink.api.java.operators.JoinOperator
Gets the custom partitioner used by this join, or null, if none is set.
getPartitionerTypes(Partitioner<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getPartitionerTypes(Partitioner<T>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getPojoFieldAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getPostPassClassName() - Method in class org.apache.flink.api.java.operators.translation.JavaPlan
 
getProducedType() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormat
 
getProducedType() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormat
 
getProducedType() - Method in class org.apache.flink.api.java.io.TypeSerializerInputFormat
 
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.
getProgress() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
getProperties() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns a Properties object from this ParameterTool
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.
getRequired(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the String value for the given key.
getResultType() - Method in class org.apache.flink.api.java.operators.Operator
Returns the type of the result of this operator.
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.ReduceOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
getSemanticProperties() - Method in interface org.apache.flink.api.java.operators.UdfOperator
Gets the semantic properties that have been set for the user-defined functions (UDF).
getSemanticProperties() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getSemanticPropsDual(Set<Annotation>, TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>, boolean) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsSingle(Set<Annotation>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>, boolean) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
getSerializerTree(TypeInformation<T>) - Static method in class org.apache.flink.api.java.Utils
Debugging utility to understand the hierarchy of serializers created by the Java API.
getSessionTimeout() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the session timeout for this environment.
getShort(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Short value for the given key.
getShort(String, short) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Short value for the given key.
getSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the solution set of the delta iteration.
getSortSelectionFunctionKey() - Method in class org.apache.flink.api.java.operators.SortedGrouping
 
getSplitDataProperties() - Method in class org.apache.flink.api.java.operators.DataSource
Returns the SplitDataProperties for the InputSplits of this DataSource for configurations.
getSplitGroupKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
 
getSplitOrder() - Method in class org.apache.flink.api.java.io.SplitDataProperties
 
getSplitPartitioner() - Method in class org.apache.flink.api.java.io.SplitDataProperties
 
getSplitPartitionKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
 
getState() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
getTag() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getTerminationCriterion() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
getTupleClass(int) - Static method in class org.apache.flink.api.java.tuple.Tuple
Gets the class corresponding to the tuple of the given arity (dimensions).
getTupleClass() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getType() - Method in class org.apache.flink.api.java.DataSet
Returns the TypeInformation for the type of this DataSet.
getType() - Method in class org.apache.flink.api.java.operators.DataSink
 
getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
getTypeException() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTypeInformation() - Method in class org.apache.flink.api.java.typeutils.PojoField
 
getUnaryOperatorReturnType(Function, Class<?>, boolean, boolean, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getWeight() - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
 
getWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the working set of the delta iteration.
getWorksetType() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getWrappedFunction() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
groupBy(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Groups a DataSet using a KeySelector function.
groupBy(int...) - Method in class org.apache.flink.api.java.DataSet
Groups a Tuple DataSet using field position keys.
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.
groupBy(String...) - Method in class org.apache.flink.api.java.DataSet
Groups a DataSet using field expressions.
GroupCombineOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
This operator behaves like the GroupReduceOperator with Combine but only runs the Combine part which reduces all data locally in their partitions.
GroupCombineOperator(DataSet<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupCombineOperator
Constructor for a non-grouped reduce (all reduce).
GroupCombineOperator(Grouping<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupCombineOperator
Constructor for a grouped reduce.
Grouping<T> - Class in org.apache.flink.api.java.operators
Grouping(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>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
Constructor for a non-grouped reduce (all reduce).
GroupReduceOperator(Grouping<IN>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
Constructor for a grouped reduce.

H

HadoopDummyProgressable - Class in org.apache.flink.api.java.hadoop.mapred.wrapper
This is a dummy progress
HadoopDummyProgressable() - Constructor for class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyProgressable
 
HadoopDummyReporter - Class in org.apache.flink.api.java.hadoop.mapred.wrapper
This is a dummy progress monitor / reporter
HadoopDummyReporter() - Constructor for class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
HadoopInputFormat<K,V> - Class in org.apache.flink.api.java.hadoop.mapred
Wrapper for using HadoopInputFormats (mapred-variant) with Flink.
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormat
 
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormat
 
HadoopInputFormat<K,V> - Class in org.apache.flink.api.java.hadoop.mapreduce
InputFormat implementation allowing to use Hadoop (mapreduce) InputFormats with Flink.
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>, Job) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormat
 
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormat
 
HadoopInputFormatBase<K,V,T> - Class in org.apache.flink.api.java.hadoop.mapred
Common base for Java and Scala API for using Hadoop input formats with Flink.
HadoopInputFormatBase(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
HadoopInputFormatBase<K,V,T> - Class in org.apache.flink.api.java.hadoop.mapreduce
Base class shared between the Java and Scala API of Flink
HadoopInputFormatBase(InputFormat<K, V>, Class<K>, Class<V>, Job) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
HadoopInputFormatCommonBase<T,SPITTYPE extends org.apache.flink.core.io.InputSplit> - Class in org.apache.flink.api.java.hadoop.common
A common base for both "mapred" and "mapreduce" Hadoop input formats.
HadoopInputFormatCommonBase(Credentials) - Constructor for class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
 
HadoopInputSplit - Class in org.apache.flink.api.java.hadoop.mapred.wrapper
A wrapper that represents an input split from the Hadoop mapred API as a Flink InputSplit.
HadoopInputSplit(int, InputSplit, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
 
HadoopInputSplit - Class in org.apache.flink.api.java.hadoop.mapreduce.wrapper
A wrapper that represents an input split from the Hadoop mapreduce API as a Flink InputSplit.
HadoopInputSplit(int, InputSplit, JobContext) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.wrapper.HadoopInputSplit
 
HadoopOutputFormat<K,V> - Class in org.apache.flink.api.java.hadoop.mapred
Wrapper for using HadoopOutputFormats (mapred-variant) with Flink.
HadoopOutputFormat(OutputFormat<K, V>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormat
 
HadoopOutputFormat(OutputFormat<K, V>, Class<OutputCommitter>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormat
 
HadoopOutputFormat<K,V> - Class in org.apache.flink.api.java.hadoop.mapreduce
OutputFormat implementation allowing to use Hadoop (mapreduce) OutputFormats with Flink.
HadoopOutputFormat(OutputFormat<K, V>, Job) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormat
 
HadoopOutputFormatBase<K,V,T> - Class in org.apache.flink.api.java.hadoop.mapred
Common base for the mapred HadoopOutputFormat wrappers.
HadoopOutputFormatBase(OutputFormat<K, V>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
HadoopOutputFormatBase<K,V,T> - Class in org.apache.flink.api.java.hadoop.mapreduce
Base class shared between the Java and Scala API of Flink
HadoopOutputFormatBase(OutputFormat<K, V>, Job) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
HadoopOutputFormatCommonBase<T> - Class in org.apache.flink.api.java.hadoop.common
A common base for both "mapred" and "mapreduce" Hadoop output formats.
HadoopOutputFormatCommonBase(Credentials) - Constructor for class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
 
HadoopUtils - Class in org.apache.flink.api.java.hadoop.mapred.utils
Utility class to work with Apache Hadoop MapRed classes.
HadoopUtils - Class in org.apache.flink.api.java.hadoop.mapreduce.utils
Utility class to work with next generatio of Apache Hadoop MapReduce classes.
handleInvalidTupleAccess() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
handleNullReturn() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
handlePutStatic() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
has(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Check if value is set.
hasDeterministicFieldOrder() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
HASH_SALT - Static variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
A sequence of prime numbers to be used for salting the computed hash values.
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple0
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple1
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple10
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple11
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple12
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple13
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple14
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple15
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple16
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple17
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple18
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple19
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple2
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple20
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple21
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple22
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple23
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple24
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple25
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple3
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple4
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple5
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple6
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple7
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple8
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple9
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.PojoField
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
hasImportantDependencies(List<? extends BasicValue>, boolean) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
hasImportantDependencies(BasicValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
hasNext - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
hasNext - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
hasNext() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
hasNext() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
hasUdfCollector() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
hasUdfIterableInput() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
hints - Variable in class org.apache.flink.api.java.record.io.CsvInputFormat.AbstractConfigBuilder
 
host - Variable in class org.apache.flink.api.java.RemoteEnvironment
The hostname of the JobManager

I

ignoreComments(String) - Method in class org.apache.flink.api.java.io.CsvReader
Configures the string that starts comments.
ignoreFirstLine() - Method in class org.apache.flink.api.java.io.CsvReader
Sets the CSV reader to ignore the first line.
ignoreInvalidLines - Variable in class org.apache.flink.api.java.io.CsvReader
 
ignoreInvalidLines() - Method in class org.apache.flink.api.java.io.CsvReader
Sets the CSV reader to ignore any invalid lines.
ImmutableMaxAgg() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction.ImmutableMaxAgg
 
ImmutableMinAgg() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction.ImmutableMinAgg
 
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.
IncompatibleKeysException(String) - Constructor for exception org.apache.flink.api.java.operators.Keys.IncompatibleKeysException
 
IncompatibleKeysException(TypeInformation<?>, TypeInformation<?>) - Constructor for exception org.apache.flink.api.java.operators.Keys.IncompatibleKeysException
 
incrCounter(Enum<?>, long) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
incrCounter(String, String, long) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
incrNewOperationCounters(boolean) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
init(Frame) - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.ImmutableMaxAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MutableMaxAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.ImmutableMinAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MutableMinAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortValueSumAgg
 
initializeContextEnvironment(ExecutionEnvironmentFactory) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Sets a context environment factory, that creates the context environment for running programs with pre-configured environments.
initializeFields(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
input(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
Deprecated.
Sets the input.
input(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
Deprecated.
Sets one or several inputs (union).
input(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.MapPartitionOperator.Builder
Deprecated.
Sets the input.
input(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.MapPartitionOperator.Builder
Deprecated.
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 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
input1(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Sets the input operator for input 1.
input1(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Sets one or several inputs (union) for input 1.
input1(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Sets the first input.
input1(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Sets one or several inputs (union) for input 1.
input1(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Sets the first input.
input1(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Sets one or several inputs (union) for input 1.
input2 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
input2(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Sets the input operator for input 2.
input2(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Sets one or several inputs (union) for input 2.
input2(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Sets the second input.
input2(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Sets one or several inputs (union) for input 2.
input2(Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Sets the second input.
input2(Operator<Record>...) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
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
Deprecated.
Sets the inputs.
inputs(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.MapPartitionOperator.Builder
Deprecated.
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
Deprecated.
Sets the first inputs.
inputs1(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Sets the first inputs.
inputs1(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Sets the first inputs.
inputs2(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Sets the second inputs.
inputs2(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Sets the second inputs.
inputs2(List<Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Sets the second inputs.
InputTypeConfigurable - Interface in org.apache.flink.api.java.typeutils
OutputFormats can implement this interface to be configured with the data type they will operate on.
inputView - Variable in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
INSTANCE - Static variable in class org.apache.flink.api.java.tuple.Tuple0
An immutable reusable Tuple0 instance
INSTANCE - Static variable in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
instantiateDeserializationUtils() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
instantiateJobContext(JobConf, JobID) - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
 
instantiateJobContext(Configuration, JobID) - Static method in class org.apache.flink.api.java.hadoop.mapreduce.utils.HadoopUtils
 
instantiateTaskAttemptContext(JobConf, TaskAttemptID) - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
 
instantiateTaskAttemptContext(Configuration, TaskAttemptID) - Static method in class org.apache.flink.api.java.hadoop.mapreduce.utils.HadoopUtils
 
INT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
IntermediateSampleData<T> - Class in org.apache.flink.api.java.sampling
The data structure which is transferred between partitions and the coordinator for distributed random sampling.
IntermediateSampleData(double, T) - Constructor for class org.apache.flink.api.java.sampling.IntermediateSampleData
 
IntSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
 
IntValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntValueSumAgg
 
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.TupleComparatorBase
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
invertNormKey - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
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.RecordTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
isBasicValueType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isCallByValue() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isCaseClass() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isClassType(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
isCollector() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isCombinable() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
 
isCombinable() - Method in class org.apache.flink.api.java.record.operators.ReduceOperator
 
isContainer() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isEmpty() - Method in class org.apache.flink.api.java.operators.Keys
 
isGrouped() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
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.kryo.KryoSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
isInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInput1Iterable() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInput1Iterator() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInputIterable() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInputIterator() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isIntConstant() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isIteratorTrueAssumption() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isIteratorTrueAssumptionApplied() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
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.TupleComparatorBase
 
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
 
isNull() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isOuter() - Method in enum org.apache.flink.api.java.operators.join.JoinType
 
isRegular() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isSkipInvalidLines() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
isSolutionSetUnManaged() - Method in class org.apache.flink.api.java.operators.DeltaIteration
gets whether the solution set is in managed or unmanaged memory.
isSortKeyType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
isTagged(Value) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
isThis() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
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.RecordTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
isUdfBinary() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
isUdfReduceFunction() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
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.operators
The IterativeDataSet represents the start of an iteration.
IterativeDataSet(ExecutionEnvironment, TypeInformation<T>, DataSet<T>, int) - Constructor for class org.apache.flink.api.java.operators.IterativeDataSet
 
iterator() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
iterator() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
IteratorInputFormat<T> - Class in org.apache.flink.api.java.io
An input format that returns objects from an iterator.
IteratorInputFormat(Iterator<T>) - Constructor for class org.apache.flink.api.java.io.IteratorInputFormat
 

J

JavaPlan - Class in org.apache.flink.api.java.operators.translation
Plan subclass for the main Java api.
JavaPlan(List<GenericDataSinkBase<?>>) - Constructor for class org.apache.flink.api.java.operators.translation.JavaPlan
 
jobID - Variable in class org.apache.flink.api.java.ExecutionEnvironment
The ID of the session, defined by this execution environment.
join(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Join transformation.
join(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Initiates a Join transformation.
join(T1, T2, Collector<Tuple2<T1, T2>>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultFlatJoinFunction
 
join(IN1, IN2, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin.WrappingFlatJoinFunction
 
join(T1, T2, Collector<R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectFlatJoinFunction
 
join(Tuple2<K, I1>, I2, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.TupleLeftUnwrappingJoiner
 
join(I1, Tuple2<K, I2>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.TupleRightUnwrappingJoiner
 
join(Tuple2<K, I1>, Tuple2<K, I2>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingJoiner
 
join(Record, Record, Collector<Record>) - Method in class org.apache.flink.api.java.record.functions.JoinFunction
Deprecated.
 
JoinFunction - Class in org.apache.flink.api.java.record.functions
Deprecated.
JoinFunction() - Constructor for class org.apache.flink.api.java.record.functions.JoinFunction
Deprecated.
 
JoinFunctionAssigner<I1,I2> - Interface in org.apache.flink.api.java.operators.join
A Join transformation that needs to be finished by specifying either a JoinFunction or a FlatJoinFunction before it can be used as an input to other operators.
joinHint - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
JoinOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A DataSet that is the result of a Join transformation.
JoinOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator
 
JoinOperator - Class in org.apache.flink.api.java.record.operators
Deprecated.
JoinOperator(JoinOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.JoinOperator
Deprecated.
The private constructor that only gets invoked from the Builder.
JoinOperator.Builder - Class in org.apache.flink.api.java.record.operators
Deprecated.
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
JoinOperator.DefaultFlatJoinFunction<T1,T2> - Class in org.apache.flink.api.java.operators
 
JoinOperator.DefaultJoin<I1,I2> - Class in org.apache.flink.api.java.operators
A Join transformation that wraps pairs of joining elements into Tuple2.
It also represents the DataSet that is the result of a Join transformation.
JoinOperator.DefaultJoin.WrappingFlatJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.java.operators
 
JoinOperator.EquiJoin<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A Join transformation that applies a JoinFunction on each pair of joining elements.
It also represents the DataSet that is the result of a Join transformation.
JoinOperator.JoinOperatorSets<I1,I2> - Class in org.apache.flink.api.java.operators
Intermediate step of a Join transformation.
JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate - Class in org.apache.flink.api.java.operators
Intermediate step of a Join transformation.
JoinOperator.JoinProjection<I1,I2> - Class in org.apache.flink.api.java.operators
 
JoinOperator.ProjectFlatJoinFunction<T1,T2,R extends Tuple> - Class in org.apache.flink.api.java.operators
 
JoinOperator.ProjectJoin<I1,I2,OUT extends Tuple> - Class in org.apache.flink.api.java.operators
A Join transformation that projects joining elements or fields of joining Tuples into result Tuples.
JoinOperatorSets(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
 
JoinOperatorSets(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
 
JoinOperatorSetsBase<I1,I2> - Class in org.apache.flink.api.java.operators.join
Intermediate step of an Outer Join transformation.
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint, JoinType) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
JoinOperatorSetsBase.JoinOperatorSetsPredicateBase - Class in org.apache.flink.api.java.operators.join
Intermediate step of a Join transformation.
JoinOperatorSetsPredicateBase(Keys<I1>) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
 
JoinProjection(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], int[]) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
 
joinType - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
JoinType - Enum in org.apache.flink.api.java.operators.join
 
joinType - Variable in class org.apache.flink.api.java.operators.JoinOperator
 
joinWithHuge(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Join transformation.
A Join transformation joins the elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
This method also gives the hint to the optimizer that the second DataSet to join is much larger than the first one.
This method returns a JoinOperator.JoinOperatorSets on which one of the where methods can be called to define the join key of the first joining (i.e., this) DataSet.
joinWithTiny(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Join transformation.

K

key - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
keyClass - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
keyClass - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
KeyExtractingMapper<T,K> - Class in org.apache.flink.api.java.operators.translation
 
KeyExtractingMapper(KeySelector<T, K>) - Constructor for class org.apache.flink.api.java.operators.translation.KeyExtractingMapper
 
keyField(Class<? extends Key<?>>, int, int) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Adds additional key field.
keyField(Class<? extends Key<?>>, int, int) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Adds additional key field.
keyField(Class<? extends Key<?>>, int) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.Builder
Adds additional key field.
keyPositions - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
key positions describe which fields are keys in what order
KeyRemovingMapper<T,K> - Class in org.apache.flink.api.java.operators.translation
 
KeyRemovingMapper() - Constructor for class org.apache.flink.api.java.operators.translation.KeyRemovingMapper
 
keys - Variable in class org.apache.flink.api.java.operators.Grouping
 
Keys<T> - Class in org.apache.flink.api.java.operators
 
Keys() - Constructor for class org.apache.flink.api.java.operators.Keys
 
Keys.ExpressionKeys<T> - Class in org.apache.flink.api.java.operators
Represents (nested) field access through string and integer-based keys for Composite Types (Tuple or Pojo)
Keys.IncompatibleKeysException - Exception in org.apache.flink.api.java.operators
 
Keys.SelectorFunctionKeys<T,K> - Class in org.apache.flink.api.java.operators
 
keys1 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
 
keys1 - Variable in class org.apache.flink.api.java.operators.JoinOperator
 
keys2 - Variable in class org.apache.flink.api.java.operators.JoinOperator
 
KeySelector<IN,KEY> - Interface in org.apache.flink.api.java.functions
The KeySelector allows to use arbitrary objects for operations such as reduce, reduceGroup, join, coGoup, etc.
KryoSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
A type serializer that serializes its type using the Kryo serialization framework (https://github.com/EsotericSoftware/kryo).
KryoSerializer(Class<T>, ExecutionConfig) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
KryoSerializer(KryoSerializer<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
Copy-constructor that does not copy transient fields.

L

lastJobExecutionResult - Variable in class org.apache.flink.api.java.ExecutionEnvironment
Result from the latest execution, to make it retrievable when using eager execution methods
leftOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Left Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of the left DataSet (i.e.
leftOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Initiates a Left Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of the left DataSet (i.e.
lenient(boolean) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat.AbstractConfigBuilder
Sets the leniency for the serializer.
LENIENT_PARSING - Static variable in class org.apache.flink.api.java.record.io.CsvOutputFormat
 
lineDelimiter - Variable in class org.apache.flink.api.java.io.CsvReader
 
lineDelimiter(String) - Method in class org.apache.flink.api.java.io.CsvReader
Configures the delimiter that separates the lines/rows.
LocalCollectionOutputFormat<T> - Class in org.apache.flink.api.java.io
An output format that writes record into collection
LocalCollectionOutputFormat(Collection<T>) - Constructor for class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
LocalEnvironment - Class in org.apache.flink.api.java
An ExecutionEnvironment that runs the program locally, multi-threaded, in the JVM where the environment is instantiated.
LocalEnvironment() - Constructor for class org.apache.flink.api.java.LocalEnvironment
Creates a new local environment.
LocalEnvironment(Configuration) - Constructor for class org.apache.flink.api.java.LocalEnvironment
Creates a new local environment that configures its local executor with the given configuration.
LOG - Static variable in class org.apache.flink.api.java.ExecutionEnvironment
The logger used by the environment and its subclasses
LONG_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
LongSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
 
LongValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongValueSumAgg
 

M

makeRegular() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
map(MapFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Applies a Map transformation on this DataSet.
The transformation calls a MapFunction for each element of the DataSet.
map(T) - Method in class org.apache.flink.api.java.functions.FormattingMapper
 
map(T) - Method in class org.apache.flink.api.java.operators.translation.KeyExtractingMapper
 
map(Tuple2<K, T>) - Method in class org.apache.flink.api.java.operators.translation.KeyRemovingMapper
 
map(Tuple) - Method in class org.apache.flink.api.java.operators.translation.PlanProjectOperator.MapProjector
 
map(T) - Method in class org.apache.flink.api.java.operators.translation.TwoKeyExtractingMapper
 
map(Record, Collector<Record>) - Method in class org.apache.flink.api.java.record.functions.MapFunction
Deprecated.
This method must be implemented to provide a user implementation of a mapper.
MapFunction - Class in org.apache.flink.api.java.record.functions
Deprecated.
MapFunction() - Constructor for class org.apache.flink.api.java.record.functions.MapFunction
Deprecated.
 
mapNext() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
MapOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "map" function on a data set, and the result data set produced by the function.
MapOperator(DataSet<IN>, TypeInformation<OUT>, MapFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.MapOperator
 
MapOperator - Class in org.apache.flink.api.java.record.operators
Deprecated.
MapOperator(MapOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.MapOperator
Deprecated.
The private constructor that only gets invoked from the Builder.
MapOperator.Builder - Class in org.apache.flink.api.java.record.operators
Deprecated.
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
mapPartition(MapPartitionFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Applies a Map-style operation to the entire partition of the data.
mapPartition(Iterable<T>, Collector<IntermediateSampleData<T>>) - Method in class org.apache.flink.api.java.functions.SampleInPartition
 
mapPartition(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.SampleWithFraction
 
mapPartition(Iterable<Record>, Collector<Record>) - Method in class org.apache.flink.api.java.record.functions.MapPartitionFunction
Deprecated.
This method must be implemented to provide a user implementation of a MapPartitionFunction.
MapPartitionFunction - Class in org.apache.flink.api.java.record.functions
Deprecated.
MapPartitionFunction() - Constructor for class org.apache.flink.api.java.record.functions.MapPartitionFunction
Deprecated.
 
MapPartitionOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "mapPartition" function on a data set, and the result data set produced by the function.
MapPartitionOperator(DataSet<IN>, TypeInformation<OUT>, MapPartitionFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.MapPartitionOperator
 
MapPartitionOperator - Class in org.apache.flink.api.java.record.operators
Deprecated.
MapPartitionOperator(MapPartitionOperator.Builder) - Constructor for class org.apache.flink.api.java.record.operators.MapPartitionOperator
Deprecated.
The private constructor that only gets invoked from the Builder.
MapPartitionOperator.Builder - Class in org.apache.flink.api.java.record.operators
Deprecated.
Builder pattern, straight from Joshua Bloch's Effective Java (2nd Edition).
max(int) - Method in class org.apache.flink.api.java.DataSet
Syntactic sugar for DataSet.aggregate(Aggregations, int) using Aggregations.MAX as the aggregation function.
max(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Syntactic sugar for aggregate (MAX, field)
MAX_ARITY - Static variable in class org.apache.flink.api.java.tuple.Tuple
 
MaxAggregationFunction<T extends Comparable<T>> - Class in org.apache.flink.api.java.aggregation
 
MaxAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction
 
MaxAggregationFunction.ImmutableMaxAgg<U extends Comparable<U>> - Class in org.apache.flink.api.java.aggregation
 
MaxAggregationFunction.MaxAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
 
MaxAggregationFunction.MutableMaxAgg<U extends Comparable<U> & org.apache.flink.types.ResettableValue<U> & org.apache.flink.types.CopyableValue<U>> - Class in org.apache.flink.api.java.aggregation
 
MaxAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MaxAggregationFunctionFactory
 
maxBy(int...) - Method in class org.apache.flink.api.java.DataSet
Selects an element with maximum value.
maxBy(int...) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies a special case of a reduce transformation (maxBy) on a grouped DataSet.
The transformation consecutively calls a ReduceFunction until only a single element remains which is the result of the transformation.
merge(Frame, Interpreter) - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
merge(BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
mergeContainers(List<TaggedValue>) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
mergeHadoopConf(JobConf) - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
Merge HadoopConfiguration into JobConf.
mergeHadoopConf(Configuration) - Static method in class org.apache.flink.api.java.hadoop.mapreduce.utils.HadoopUtils
Merge HadoopConfiguration into Configuration.
mergeInputs(List<TaggedValue>) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
mergePriority - Variable in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
mergeReturnValues(List<TaggedValue>) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
mergeWith(ParameterTool) - Method in class org.apache.flink.api.java.utils.ParameterTool
Merges two ParameterTool
min(int) - Method in class org.apache.flink.api.java.DataSet
Syntactic sugar for DataSet.aggregate(Aggregations, int) using Aggregations.MIN as the aggregation function.
min(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Syntactic sugar for aggregate (MIN, field)
MinAggregationFunction<T extends Comparable<T>> - Class in org.apache.flink.api.java.aggregation
 
MinAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction
 
MinAggregationFunction.ImmutableMinAgg<U extends Comparable<U>> - Class in org.apache.flink.api.java.aggregation
 
MinAggregationFunction.MinAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
 
MinAggregationFunction.MutableMinAgg<U extends Comparable<U> & org.apache.flink.types.ResettableValue<U> & org.apache.flink.types.CopyableValue<U>> - Class in org.apache.flink.api.java.aggregation
 
MinAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction.MinAggregationFunctionFactory
 
minBy(int...) - Method in class org.apache.flink.api.java.DataSet
Selects an element with minimum value.
minBy(int...) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies a special case of a reduce transformation (minBy) on a grouped DataSet.
The transformation consecutively calls a ReduceFunction until only a single element remains which is the result of the transformation.
MissingTypeInfo - Class in org.apache.flink.api.java.typeutils
A special type information signifying that the type extraction failed.
MissingTypeInfo(String) - Constructor for class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
MissingTypeInfo(String, InvalidTypesException) - Constructor for class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
ModifiedASMAnalyzer - Class in org.apache.flink.api.java.sca
Modified version of ASMs Analyzer.
ModifiedASMAnalyzer(Interpreter) - Constructor for class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
ModifiedASMFrame - Class in org.apache.flink.api.java.sca
Modified version of ASMs Frame.
ModifiedASMFrame(int, int) - Constructor for class org.apache.flink.api.java.sca.ModifiedASMFrame
 
ModifiedASMFrame(Frame) - Constructor for class org.apache.flink.api.java.sca.ModifiedASMFrame
 
MutableMaxAgg() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MutableMaxAgg
 
MutableMinAgg() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction.MutableMinAgg
 

N

name(String) - Method in class org.apache.flink.api.java.operators.DataSink
 
name(String) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Sets the name for the iteration.
name - Variable in class org.apache.flink.api.java.operators.Operator
 
name(String) - Method in class org.apache.flink.api.java.operators.Operator
Sets the name of this operator.
name(String) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
Sets the name of this operator.
name(String) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Sets the name of this operator.
name(String) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Sets the name of this operator.
name(String) - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
Deprecated.
Sets the name of this operator.
name(String) - Method in class org.apache.flink.api.java.record.operators.MapPartitionOperator.Builder
Deprecated.
Sets the name of this operator.
name(String) - Method in class org.apache.flink.api.java.record.operators.ReduceOperator.Builder
Sets the name of this operator.
NamedFlatFieldDescriptor(String, int, TypeInformation<?>) - Constructor for class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
naryOperation(AbstractInsnNode, List) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
NestedMethodAnalyzer - Class in org.apache.flink.api.java.sca
Extends ASM's BasicInterpreter.
NestedMethodAnalyzer(UdfAnalyzer, String, MethodNode, List<BasicValue>, int, boolean) - Constructor for class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
newControlFlowEdge(int, int) - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
newFrame(int, int) - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
newFrame(Frame) - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
newOperation(AbstractInsnNode) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
newValue(Type) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
next() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
next() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
nextRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormat
 
nextRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormat
 
nextRecord(T) - Method in class org.apache.flink.api.java.io.CollectionInputFormat
 
nextRecord(OUT) - Method in class org.apache.flink.api.java.io.CommonCsvInputFormat
 
nextRecord(T) - Method in class org.apache.flink.api.java.io.IteratorInputFormat
 
nextRecord(T) - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
 
nextRecord(Record) - Method in class org.apache.flink.api.java.record.io.CollectionInputFormat
 
nextRecord(Record) - Method in class org.apache.flink.api.java.record.io.ExternalProcessFixedLengthInputFormat
 
nextRecord(Record) - Method in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
 
NO_VALUE_KEY - Static variable in class org.apache.flink.api.java.utils.ParameterTool
 
NoFetchingInput - Class in org.apache.flink.api.java.typeutils.runtime
 
NoFetchingInput(InputStream) - Constructor for class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
normalizableKeyPrefixLen - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
normalizedKeyLengths - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
NULL_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
NUM_FIELDS_PARAMETER - Static variable in class org.apache.flink.api.java.record.io.CsvOutputFormat
 
numLeadingNormalizableKeys - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
numSamples - Variable in class org.apache.flink.api.java.sampling.DistributedRandomSampler
 

O

ObjectArrayTypeInfo<T,C> - Class in org.apache.flink.api.java.typeutils
 
of(T0) - Static method in class org.apache.flink.api.java.tuple.Tuple1
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Static method in class org.apache.flink.api.java.tuple.Tuple10
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Static method in class org.apache.flink.api.java.tuple.Tuple11
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Static method in class org.apache.flink.api.java.tuple.Tuple12
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Static method in class org.apache.flink.api.java.tuple.Tuple13
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Static method in class org.apache.flink.api.java.tuple.Tuple14
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Static method in class org.apache.flink.api.java.tuple.Tuple15
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Static method in class org.apache.flink.api.java.tuple.Tuple16
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Static method in class org.apache.flink.api.java.tuple.Tuple17
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Static method in class org.apache.flink.api.java.tuple.Tuple18
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Static method in class org.apache.flink.api.java.tuple.Tuple19
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1) - Static method in class org.apache.flink.api.java.tuple.Tuple2
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Static method in class org.apache.flink.api.java.tuple.Tuple20
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Static method in class org.apache.flink.api.java.tuple.Tuple21
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Static method in class org.apache.flink.api.java.tuple.Tuple22
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Static method in class org.apache.flink.api.java.tuple.Tuple23
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Static method in class org.apache.flink.api.java.tuple.Tuple24
Creates a new tuple and assigns the given values to the tuple's fields.
of(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) - Static method in class org.apache.flink.api.java.tuple.Tuple25
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2) - Static method in class org.apache.flink.api.java.tuple.Tuple3
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3) - Static method in class org.apache.flink.api.java.tuple.Tuple4
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4) - Static method in class org.apache.flink.api.java.tuple.Tuple5
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5) - Static method in class org.apache.flink.api.java.tuple.Tuple6
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6) - Static method in class org.apache.flink.api.java.tuple.Tuple7
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7) - Static method in class org.apache.flink.api.java.tuple.Tuple8
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Static method in class org.apache.flink.api.java.tuple.Tuple9
Creates a new tuple and assigns the given values to the tuple's fields.
open(HadoopInputSplit) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
open(int, int) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
create the temporary output file for hadoop RecordWriter.
open(HadoopInputSplit) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
open(int, int) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
create the temporary output file for hadoop RecordWriter.
open(GenericInputSplit) - Method in class org.apache.flink.api.java.io.CollectionInputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.java.io.CommonCsvInputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
open(GenericInputSplit) - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.java.io.PrimitiveInputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.TextOutputFormat
 
open(Configuration) - Method in class org.apache.flink.api.java.operators.AggregateOperator.AggregatingUdf
 
open(Configuration) - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
open(GenericInputSplit) - Method in class org.apache.flink.api.java.record.io.CollectionInputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.java.record.io.CsvInputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat
 
open(GenericInputSplit) - Method in class org.apache.flink.api.java.record.io.ExternalProcessFixedLengthInputFormat
 
open(GenericInputSplit) - Method in class org.apache.flink.api.java.record.io.ExternalProcessInputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.java.record.io.FixedLengthInputFormat
 
open(Configuration) - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
Operator<OUT,O extends Operator<OUT,O>> - Class in org.apache.flink.api.java.operators
Base class of all operators in the Java API.
Operator(ExecutionEnvironment, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.Operator
 
OperatorInfoHelper - Class in org.apache.flink.api.java.record.operators
Deprecated.
OperatorInfoHelper() - Constructor for class org.apache.flink.api.java.record.operators.OperatorInfoHelper
Deprecated.
 
OperatorTranslation - Class in org.apache.flink.api.java.operators
 
OperatorTranslation() - Constructor for class org.apache.flink.api.java.operators.OperatorTranslation
 
org.apache.flink.api.java - package org.apache.flink.api.java
 
org.apache.flink.api.java.aggregation - package org.apache.flink.api.java.aggregation
 
org.apache.flink.api.java.functions - package org.apache.flink.api.java.functions
 
org.apache.flink.api.java.hadoop.common - package org.apache.flink.api.java.hadoop.common
 
org.apache.flink.api.java.hadoop.mapred - package org.apache.flink.api.java.hadoop.mapred
 
org.apache.flink.api.java.hadoop.mapred.utils - package org.apache.flink.api.java.hadoop.mapred.utils
 
org.apache.flink.api.java.hadoop.mapred.wrapper - package org.apache.flink.api.java.hadoop.mapred.wrapper
 
org.apache.flink.api.java.hadoop.mapreduce - package org.apache.flink.api.java.hadoop.mapreduce
 
org.apache.flink.api.java.hadoop.mapreduce.utils - package org.apache.flink.api.java.hadoop.mapreduce.utils
 
org.apache.flink.api.java.hadoop.mapreduce.wrapper - package org.apache.flink.api.java.hadoop.mapreduce.wrapper
 
org.apache.flink.api.java.io - package org.apache.flink.api.java.io
 
org.apache.flink.api.java.operators - package org.apache.flink.api.java.operators
 
org.apache.flink.api.java.operators.join - package org.apache.flink.api.java.operators.join
 
org.apache.flink.api.java.operators.translation - package org.apache.flink.api.java.operators.translation
 
org.apache.flink.api.java.record.functions - package org.apache.flink.api.java.record.functions
 
org.apache.flink.api.java.record.io - package org.apache.flink.api.java.record.io
 
org.apache.flink.api.java.record.operators - package org.apache.flink.api.java.record.operators
 
org.apache.flink.api.java.sampling - package org.apache.flink.api.java.sampling
 
org.apache.flink.api.java.sca - package org.apache.flink.api.java.sca
 
org.apache.flink.api.java.tuple - package org.apache.flink.api.java.tuple
 
org.apache.flink.api.java.tuple.builder - package org.apache.flink.api.java.tuple.builder
 
org.apache.flink.api.java.typeutils - package org.apache.flink.api.java.typeutils
 
org.apache.flink.api.java.typeutils.runtime - package org.apache.flink.api.java.typeutils.runtime
 
org.apache.flink.api.java.typeutils.runtime.kryo - package org.apache.flink.api.java.typeutils.runtime.kryo
 
org.apache.flink.api.java.utils - package org.apache.flink.api.java.utils
 
output(OutputFormat<T>) - Method in class org.apache.flink.api.java.DataSet
Emits a DataSet using an OutputFormat.
outputView - Variable in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 

P

parallelism(int) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Sets the parallelism for the iteration.
parallelism - Variable in class org.apache.flink.api.java.operators.Operator
 
ParallelIteratorInputFormat<T> - Class in org.apache.flink.api.java.io
An input format that generates data in parallel through a SplittableIterator.
ParallelIteratorInputFormat(SplittableIterator<T>) - Constructor for class org.apache.flink.api.java.io.ParallelIteratorInputFormat
 
ParameterTool - Class in org.apache.flink.api.java.utils
This class provides simple utility methods for reading and parsing program arguments from different sources
parse(String) - Static method in class org.apache.flink.api.java.typeutils.TypeInfoParser
Generates an instance of TypeInformation by parsing a type information string.
parsedValues - Variable in class org.apache.flink.api.java.io.CommonCsvInputFormat
 
parseQuotedStrings - Variable in class org.apache.flink.api.java.io.CsvReader
 
parseQuotedStrings(char) - Method in class org.apache.flink.api.java.io.CsvReader
Enables quoted String parsing.
PartialSolutionPlaceHolder(BulkIterationBase<Record>) - Constructor for class org.apache.flink.api.java.record.operators.BulkIteration.PartialSolutionPlaceHolder
Deprecated.
 
partition(T, int) - Method in class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
 
partitionByHash(int...) - Method in class org.apache.flink.api.java.DataSet
Hash-partitions a DataSet on the specified key fields.
partitionByHash(String...) - Method in class org.apache.flink.api.java.DataSet
Hash-partitions a DataSet on the specified key fields.
partitionByHash(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Partitions a DataSet using the specified KeySelector.
partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.api.java.DataSet
Partitions a tuple DataSet on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, String) - Method in class org.apache.flink.api.java.DataSet
Partitions a POJO DataSet on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Partitions a DataSet on the key returned by the selector, using a custom partitioner.
PartitionOperator<T> - Class in org.apache.flink.api.java.operators
This operator represents a partitioning.
PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
 
PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
 
PartitionOperator(DataSet<T>, Keys<T>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
 
PartitionOperator(DataSet<T>, Keys<T>, Partitioner<P>, TypeInformation<P>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
 
PlanBothUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanBothUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, Keys.SelectorFunctionKeys<I1, K>, Keys.SelectorFunctionKeys<I2, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, I1>>, TypeInformation<Tuple2<K, I2>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanBothUnwrappingCoGroupOperator
 
PlanBothUnwrappingCoGroupOperator.TupleBothUnwrappingCoGrouper<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanFilterOperator<T> - Class in org.apache.flink.api.java.operators.translation
 
PlanFilterOperator(FilterFunction<T>, String, TypeInformation<T>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanFilterOperator
 
PlanFilterOperator.FlatMapFilter<T> - Class in org.apache.flink.api.java.operators.translation
 
PlanLeftUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanLeftUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, Keys.SelectorFunctionKeys<I1, K>, int[], String, TypeInformation<OUT>, TypeInformation<Tuple2<K, I1>>, TypeInformation<I2>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanLeftUnwrappingCoGroupOperator
 
PlanLeftUnwrappingCoGroupOperator.TupleLeftUnwrappingCoGrouper<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanProjectOperator<T,R extends Tuple> - Class in org.apache.flink.api.java.operators.translation
 
PlanProjectOperator(int[], String, TypeInformation<T>, TypeInformation<R>, ExecutionConfig) - Constructor for class org.apache.flink.api.java.operators.translation.PlanProjectOperator
 
PlanProjectOperator.MapProjector<T extends Tuple,R extends Tuple> - Class in org.apache.flink.api.java.operators.translation
 
PlanRightUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanRightUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, int[], Keys.SelectorFunctionKeys<I2, K>, String, TypeInformation<OUT>, TypeInformation<I1>, TypeInformation<Tuple2<K, I2>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanRightUnwrappingCoGroupOperator
 
PlanRightUnwrappingCoGroupOperator.TupleRightUnwrappingCoGrouper<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingGroupCombineOperator<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
A group combine operator that takes 2-tuples (key-value pairs), and applies the group combine operation only on the unwrapped values.
PlanUnwrappingGroupCombineOperator(GroupCombineFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, IN>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingGroupCombineOperator
 
PlanUnwrappingGroupCombineOperator.TupleUnwrappingGroupCombiner<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingReduceGroupOperator<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
A reduce operator that takes 2-tuples (key-value pairs), and applies the group reduce operation only on the unwrapped values.
PlanUnwrappingReduceGroupOperator(GroupReduceFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, IN>>, boolean) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator
 
PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingReduceOperator<T,K> - Class in org.apache.flink.api.java.operators.translation
A reduce operator that takes 2-tuples (key-value pairs), and applies the reduce operation only on the unwrapped values.
PlanUnwrappingReduceOperator(ReduceFunction<T>, Keys.SelectorFunctionKeys<T, K>, String, TypeInformation<T>, TypeInformation<Tuple2<K, T>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceOperator
 
PlanUnwrappingReduceOperator.ReduceWrapper<T,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingSortedGroupCombineOperator<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted partial group reduce operation only on the unwrapped values.
PlanUnwrappingSortedGroupCombineOperator(GroupCombineFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K1>, Keys.SelectorFunctionKeys<IN, K2>, String, TypeInformation<OUT>, TypeInformation<Tuple3<K1, K2, IN>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedGroupCombineOperator
 
PlanUnwrappingSortedGroupCombineOperator.TupleUnwrappingGroupReducer<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingSortedReduceGroupOperator<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted group reduce operation only on the unwrapped values.
PlanUnwrappingSortedReduceGroupOperator(GroupReduceFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K1>, Keys.SelectorFunctionKeys<IN, K2>, String, TypeInformation<OUT>, TypeInformation<Tuple3<K1, K2, IN>>, boolean) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator
 
PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
 
PoissonSampler<T> - Class in org.apache.flink.api.java.sampling
A sampler implementation based on the Poisson Distribution.
PoissonSampler(double, long) - Constructor for class org.apache.flink.api.java.sampling.PoissonSampler
Create a poisson sampler which can sample elements with replacement.
PoissonSampler(double) - Constructor for class org.apache.flink.api.java.sampling.PoissonSampler
Create a poisson sampler which can sample elements with replacement.
PojoComparator<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
PojoComparator(Field[], TypeComparator<?>[], TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
PojoField - Class in org.apache.flink.api.java.typeutils
Represent a field definition for PojoTypeInfo type of objects.
PojoField(Field, TypeInformation<?>) - Constructor for class org.apache.flink.api.java.typeutils.PojoField
 
PojoSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
PojoSerializer(Class<T>, TypeSerializer<?>[], Field[], ExecutionConfig) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
pojoType(Class<T>, String...) - Method in class org.apache.flink.api.java.io.CsvReader
Configures the reader to read the CSV data and parse it to the given type.
PojoTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
TypeInformation for "Java Beans"-style types.
PojoTypeInfo(Class<T>, List<PojoField>) - Constructor for class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
PojoTypeInfo.NamedFlatFieldDescriptor - Class in org.apache.flink.api.java.typeutils
 
port - Variable in class org.apache.flink.api.java.RemoteEnvironment
The port of the JobManager main actor system
pos - Variable in class org.apache.flink.api.java.record.io.TextInputFormat
 
PrimitiveInputFormat<OT> - Class in org.apache.flink.api.java.io
An input format that reads single field primitive data from a given file.
PrimitiveInputFormat(Path, Class<OT>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
 
PrimitiveInputFormat(Path, String, Class<OT>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
 
print() - Method in class org.apache.flink.api.java.DataSet
Prints the elements in a DataSet to the standard output stream System.out of the JVM that calls the print() method.
print(String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
PrintingOutputFormat<T> - Class in org.apache.flink.api.java.io
 
PrintingOutputFormat() - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
Instantiates a printing output format that prints to standard out.
PrintingOutputFormat(boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
Instantiates a printing output format that prints to standard out.
PrintingOutputFormat(String, boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
Instantiates a printing output format that prints to standard out with a prefixed message.
printOnTaskManager(String) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet to the standard output streams (stdout) of the TaskManagers that execute the program (or more specifically, the data sink operators).
printToErr() - Method in class org.apache.flink.api.java.DataSet
Prints the elements in a DataSet to the standard error stream System.err of the JVM that calls the print() method.
printToErr(String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
printToLogger(Logger) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
privateDuplicate(TupleComparatorBase<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
progress() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyProgressable
 
progress() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
project(int...) - Method in class org.apache.flink.api.java.DataSet
Applies a Project transformation on a Tuple DataSet.
Note: Only Tuple DataSets can be projected using field indexes.
The transformation projects each Tuple of the DataSet onto a (sub)set of fields.
Additional fields can be added to the projection by calling DataSet.project(int[]).
ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperator.CrossProjection<I1, I2>, CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Continues a ProjectCross transformation and adds fields of the first cross input.
If the first cross input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Initiates a ProjectCross transformation and projects the first cross input
If the first cross input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Continues a ProjectCross transformation and adds fields of the first cross input to the projection.
If the first cross input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Applies a ProjectJoin transformation and projects the first join input
If the first join input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Continues a ProjectJoin transformation and adds fields of the first join input.
If the first join input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Continues a ProjectJoin transformation and adds fields of the first join input to the projection.
If the first join input is a Tuple DataSet, fields can be selected by their index.
Projection(DataSet<T>, int[]) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator.Projection
 
ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>, JoinOperator.JoinProjection<I1, I2>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
ProjectOperator<IN,OUT extends Tuple> - Class in org.apache.flink.api.java.operators
This operator represents the application of a projection operation on a data set, and the result data set produced by the function.
ProjectOperator(DataSet<IN>, int[], TupleTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator
 
ProjectOperator.Projection<T> - Class in org.apache.flink.api.java.operators
 
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Continues a ProjectCross transformation and adds fields of the second cross input.
If the second cross input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Initiates a ProjectCross transformation and projects the second cross input
If the second cross input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Continues a ProjectCross transformation and adds fields of the second cross input to the projection.
If the second cross input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Applies a ProjectJoin transformation and projects the second join input
If the second join input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Continues a ProjectJoin transformation and adds fields of the second join input.
If the second join input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Continues a ProjectJoin transformation and adds fields of the second join input to the projection.
If the second join input is a Tuple DataSet, fields can be selected by their index.
projectTuple1() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple1() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple1() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple10() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple10() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple10() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple11() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple11() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple11() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple12() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple12() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple12() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple13() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple13() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple13() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple14() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple14() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple14() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple15() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple15() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple15() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple16() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple16() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple16() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple17() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple17() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple17() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple18() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple18() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple18() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple19() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple19() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple19() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple2() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple2() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple2() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple20() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple20() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple20() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple21() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple21() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple21() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple22() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple22() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple22() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple23() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple23() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple23() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple24() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple24() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple24() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple25() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple25() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple25() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple3() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple3() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple3() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple4() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple4() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple4() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple5() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple5() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple5() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple6() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple6() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple6() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple7() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple7() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple7() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple8() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple8() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple8() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple9() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple9() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple9() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTupleX() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Chooses a projectTupleX according to the length of CrossOperator.CrossProjection.fieldIndexes
projectTupleX() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Chooses a projectTupleX according to the length of JoinOperator.JoinProjection.fieldIndexes
projectTupleX() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Chooses a projectTupleX according to the length of ProjectOperator.Projection.fieldIndexes
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 

Q

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

R

RandomSampler<T> - Class in org.apache.flink.api.java.sampling
A data sample is a set of data selected from a statistical population by a defined procedure.
RandomSampler() - Constructor for class org.apache.flink.api.java.sampling.RandomSampler
 
reachedEnd() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
reachedEnd() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
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(ObjectInputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
 
read(ObjectInputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
 
read() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
read(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
read(Kryo, Input, Class<Schema>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.AvroSchemaSerializer
 
read() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
read(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
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
 
readBytes(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
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(UserCodeWrapper<?>) - Static method in class org.apache.flink.api.java.record.functions.FunctionAnnotation
Deprecated.
 
readDualForwardAnnotations(Class<?>) - Static method in class org.apache.flink.api.java.functions.FunctionAnnotation
Reads the annotations of a user defined function with two inputs and returns semantic properties according to the forwarded fields annotated.
readEnum() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readFile(FileInputFormat<X>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
 
readFileOfPrimitives(String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet that represents the primitive type produced by reading the given file line wise.
readFileOfPrimitives(String, String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet that represents the primitive type produced by reading the given file in delimited way.
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
 
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, JobConf) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, Job) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given FileInputFormat.
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.RuntimeComparatorFactory
 
readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
readRecord(OUT, byte[], int, int) - Method in class org.apache.flink.api.java.io.CommonCsvInputFormat
 
readRecord(OT, byte[], int, int) - Method in class org.apache.flink.api.java.io.PrimitiveInputFormat
 
readRecord(String, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextInputFormat
 
readRecord(StringValue, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
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
 
readSequenceFile(Class<K>, Class<V>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from SequenceFileInputFormat A JobConf with the given inputPath is created.
readSingleConstantAnnotations(UserCodeWrapper<?>) - Static method in class org.apache.flink.api.java.record.functions.FunctionAnnotation
Deprecated.
 
readSingleForwardAnnotations(Class<?>) - Static method in class org.apache.flink.api.java.functions.FunctionAnnotation
Reads the annotations of a user defined function with one input and returns semantic properties according to the forwarded fields annotated.
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(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
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
 
rebalance() - Method in class org.apache.flink.api.java.DataSet
Enforces a re-balancing of the DataSet, i.e., the DataSet is evenly distributed over all parallel instances of the following task.
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
 
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.
recordReader - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
RecordTypeInfo - Class in org.apache.flink.api.java.typeutils
Type information for the Record data type.
RecordTypeInfo() - Constructor for class org.apache.flink.api.java.typeutils.RecordTypeInfo
 
recordWriter - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
recordWriter - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
recursivelyRegisterType(Class<?>, ExecutionConfig) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
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<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.FirstReducer
 
reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.GroupReduceIterator
 
reduce(Iterable<IntermediateSampleData<T>>, Collector<T>) - Method in class org.apache.flink.api.java.functions.SampleInCoordinator
 
reduce(T, T) - Method in class org.apache.flink.api.java.functions.SelectByMaxFunction
Reduce implementation, returns bigger tuple or value1 if both tuples are equal.
reduce(T, T) - Method in class org.apache.flink.api.java.functions.SelectByMinFunction
Reduce implementation, returns smaller tuple or value1 if both tuples are equal.
reduce(Iterable<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.TupleUnwrappingGroupCombinableGroupReducer
 
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(Iterable<Tuple3<K1, K2, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
reduce(Iterable<Tuple3<K1, K2, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer
 
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
Deprecated.
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
Deprecated.
ReduceFunction() - Constructor for class org.apache.flink.api.java.record.functions.ReduceFunction
Deprecated.
 
reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Applies a GroupReduce transformation on a non-grouped DataSet.
The transformation calls a RichGroupReduceFunction once with the full 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
Applies a GroupReduce transformation on a grouped DataSet.
The transformation calls a RichGroupReduceFunction for each group of the DataSet.
ReduceOperator<IN> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "reduce" function on a data set, and the result data set produced by the function.
ReduceOperator(DataSet<IN>, ReduceFunction<IN>, String) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
This is the case for a reduce-all case (in contrast to the reduce-per-group case).
ReduceOperator(Grouping<IN>, ReduceFunction<IN>, String) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
 
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.WrappingReduceFunction - Class in org.apache.flink.api.java.record.operators
 
registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Registers an Aggregator for the iteration together with a ConvergenceCriterion.
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Registers an Aggregator for the iteration.
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Registers an Aggregator for the iteration.
registerCachedFile(String, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFilesWithPlan(Plan) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers all files that were registered at this execution environment's cache registry of the given plan's cache registry.
registerGenericAvro(ExecutionConfig) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
Register these serializers for using Avro's GenericData.Record and classes implementing SpecificRecordBase
registerJavaUtils(ExecutionConfig) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
Register less frequently used serializers
registerJodaTime(ExecutionConfig) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
Currently, the following classes of JodaTime are supported: - DateTime - Interval The following chronologies are supported: (see JodaDateTimeSerializer) org.joda.time.chrono.ISOChronology org.joda.time.chrono.CopticChronology org.joda.time.chrono.EthiopicChronology org.joda.time.chrono.GregorianChronology org.joda.time.chrono.JulianChronology org.joda.time.chrono.IslamicChronology org.joda.time.chrono.BuddhistChronology org.joda.time.chrono.GJChronology
registerSpecificAvro(ExecutionConfig, Class<? extends SpecificRecordBase>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
registerType(Class<?>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers the given type with the serialization stack.
registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers the given type with a Kryo Serializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer
RemoteEnvironment - Class in org.apache.flink.api.java
An ExecutionEnvironment that sends programs to a cluster for execution.
RemoteEnvironment(String, int, String...) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteEnvironment(String, int, Configuration, String[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given host name and port.
remove() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
remove() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
removeNullElementsFromList(List<R>) - Static method in class org.apache.flink.api.java.operators.Keys.ExpressionKeys
 
removeUngroupedInputs(TaggedValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
removeUngroupedInputsFromContainer(TaggedValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
requestIFEQLoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
requestIFNELoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
require(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
Require makes sure that at least required number of bytes are kept in the buffer.
ReservoirSamplerWithoutReplacement<T> - Class in org.apache.flink.api.java.sampling
A simple in memory implementation of Reservoir Sampling without replacement, and with only one pass through the input iteration whose size is unpredictable.
ReservoirSamplerWithoutReplacement(int, Random) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
Create a new sampler with reservoir size and a supplied random number generator.
ReservoirSamplerWithoutReplacement(int) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
Create a new sampler with reservoir size and a default random number generator.
ReservoirSamplerWithoutReplacement(int, long) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
Create a new sampler with reservoir size and the seed for random number generator.
ReservoirSamplerWithReplacement<T> - Class in org.apache.flink.api.java.sampling
A simple in memory implementation of Reservoir Sampling with replacement and with only one pass through the input iteration whose size is unpredictable.
ReservoirSamplerWithReplacement(int) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
Create a sampler with fixed sample size and default random number generator.
ReservoirSamplerWithReplacement(int, long) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
Create a sampler with fixed sample size and random number generator seed.
ReservoirSamplerWithReplacement(int, Random) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
Create a sampler with fixed sample size and random number generator.
resetContextEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Un-sets the context environment factory.
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.
returnOperation(AbstractInsnNode, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
returns(String) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(TypeInformation<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(Class<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(String) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(TypeInformation<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(Class<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds a type information hint about the return type of this operator.
rightOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Right Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of the right DataSet (i.e.
rightOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Initiates a Right Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of the right DataSet (i.e.
RNG - Static variable in class org.apache.flink.api.java.Utils
 
runOperation(CustomUnaryOperation<T, X>) - Method in class org.apache.flink.api.java.DataSet
Runs a CustomUnaryOperation on the data set.
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,T2> - Class in org.apache.flink.api.java.typeutils.runtime
 
RuntimePairComparatorFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
RuntimeSerializerFactory<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
RuntimeSerializerFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
RuntimeSerializerFactory(TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 

S

sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.BernoulliSampler
Sample the input elements, for each input element, take a Bernoulli trail for sampling.
sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
Combine the first phase and second phase in sequence, implemented for test purpose only.
sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.PoissonSampler
Sample the input elements, for each input element, generate its count following a poisson distribution.
sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.RandomSampler
Randomly sample the elements from input in sequence, and return the result iterator.
sample(DataSet<T>, boolean, double) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Generate a sample of DataSet by the probability fraction of each element.
sample(DataSet<T>, boolean, double, long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Generate a sample of DataSet by the probability fraction of each element.
SampleInCoordinator<T> - Class in org.apache.flink.api.java.functions
SampleInCoordinator wraps the sample logic of the coordinator side (the second phase of distributed sample algorithm).
SampleInCoordinator(boolean, int, long) - Constructor for class org.apache.flink.api.java.functions.SampleInCoordinator
Create a function instance of SampleInCoordinator.
sampleInCoordinator(Iterator<IntermediateSampleData<T>>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
Sample algorithm for the second phase.
SampleInPartition<T> - Class in org.apache.flink.api.java.functions
SampleInPartition wraps the sample logic on the partition side (the first phase of distributed sample algorithm).
SampleInPartition(boolean, int, long) - Constructor for class org.apache.flink.api.java.functions.SampleInPartition
Create a function instance of SampleInPartition.
sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
Sample algorithm for the first phase.
sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
 
sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
 
SampleWithFraction<T> - Class in org.apache.flink.api.java.functions
A map partition function wrapper for sampling algorithms with fraction, the sample algorithm takes the partition iterator as input.
SampleWithFraction(boolean, double, long) - Constructor for class org.apache.flink.api.java.functions.SampleWithFraction
Create a function instance of SampleWithFraction.
sampleWithSize(DataSet<T>, boolean, int) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Generate a sample of DataSet which contains fixed size elements.
sampleWithSize(DataSet<T>, boolean, int, long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Generate a sample of DataSet which contains fixed size elements.
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
Deprecated.
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
Deprecated.
Sets the order of the elements within a group for the second input.
SELECT_ALL_CHAR - Static variable in class org.apache.flink.api.java.operators.Keys.ExpressionKeys
 
SELECT_ALL_CHAR_SCALA - Static variable in class org.apache.flink.api.java.operators.Keys.ExpressionKeys
 
SelectByMaxFunction<T extends Tuple> - Class in org.apache.flink.api.java.functions
 
SelectByMaxFunction(TupleTypeInfo<T>, int...) - Constructor for class org.apache.flink.api.java.functions.SelectByMaxFunction
Constructor which is overwriting the default constructor.
SelectByMinFunction<T extends Tuple> - Class in org.apache.flink.api.java.functions
 
SelectByMinFunction(TupleTypeInfo<T>, int...) - Constructor for class org.apache.flink.api.java.functions.SelectByMinFunction
Constructor which is overwriting the default constructor.
SelectorFunctionKeys(KeySelector<T, K>, TypeInformation<T>, TypeInformation<K>) - Constructor for class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
 
SemanticPropUtil - Class in org.apache.flink.api.java.functions
Utility class that contains helper methods to work with SemanticProperties.
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
 
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(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
serialize(Tuple0, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
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.
Serializers - Class in org.apache.flink.api.java.typeutils.runtime.kryo
Class containing utilities for the serializers of the Flink Runtime.
Serializers() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
serializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
serializers to deserialize the first n fields for comparison
Serializers.AvroSchemaSerializer - Class in org.apache.flink.api.java.typeutils.runtime.kryo
Slow serialization approach for Avro schemas.
Serializers.SpecificInstanceCollectionSerializer<T extends Collection> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
Special serializer for Java collections enforcing certain instance types.
Serializers.SpecificInstanceCollectionSerializerForArrayList - Class in org.apache.flink.api.java.typeutils.runtime.kryo
 
sessionTimeout - Variable in class org.apache.flink.api.java.ExecutionEnvironment
The session timeout in seconds
set(Iterator<Tuple3<K1, K2, T>>) - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
set(Collector<Tuple3<K1, K2, IN>>) - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
set(Iterator<Tuple2<K, T>>) - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
set(Collector<Tuple2<K, IN>>) - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
setAllowNullValues(boolean) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Configures the format to either allow null values (writing an empty field), or to throw an exception when encountering a null field.
setAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
setAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
setBroadcastVariable(String, Operator<Record>) - Method in class org.apache.flink.api.java.record.operators.CoGroupOperator.Builder
Deprecated.
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
Deprecated.
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
Deprecated.
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
Deprecated.
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.MapPartitionOperator.Builder
Deprecated.
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
Deprecated.
Binds multiple broadcast variables.
setBroadcastVariables(Map<String, Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.CrossOperator.Builder
Deprecated.
Binds multiple broadcast variables.
setBroadcastVariables(Map<String, Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.JoinOperator.Builder
Deprecated.
Binds multiple broadcast variables.
setBroadcastVariables(Map<String, Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.MapOperator.Builder
Deprecated.
Binds multiple broadcast variables.
setBroadcastVariables(Map<String, Operator<Record>>) - Method in class org.apache.flink.api.java.record.operators.MapPartitionOperator.Builder
Deprecated.
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
Sets the default parallelism that will be used for the local execution environment created by ExecutionEnvironment.createLocalEnvironment().
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.Tuple0
 
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.CommonCsvInputFormat
 
setFields(boolean[], Class<?>[]) - Method in class org.apache.flink.api.java.io.CommonCsvInputFormat
 
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.CommonCsvInputFormat
 
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<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
The purpose of this method is solely to check whether the data type to be processed is in fact a tuple type.
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
 
setInputType(TypeInformation<?>, ExecutionConfig) - 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
Deprecated.
 
setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Sets the number of times that failed tasks are re-executed.
setOrderOfPOJOFields(String[]) - Method in class org.apache.flink.api.java.io.CommonCsvInputFormat
 
setOut(DataOutput) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
setParallelism(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Sets the parallelism for operations executed through this environment.
setParallelism(int) - Method in class org.apache.flink.api.java.operators.DataSink
Sets the parallelism for this data sink.
setParallelism(int) - Method in class org.apache.flink.api.java.operators.Operator
Sets the parallelism for this operator.
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(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
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).
setSerializer(TypeSerializer<T>) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
 
setSessionTimeout(long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Sets the session timeout to hold the intermediate results of a job.
setSkipInvalidLines(boolean) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
setSolutionSetUnManaged(boolean) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or unmanaged memory (objects on heap).
setState(int) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
setStatus(String) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
setTag(TaggedValue.Tag) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
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_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
ShortSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
 
ShortValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortValueSumAgg
 
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.
SIZE_MISMATCH_MESSAGE - Static variable in exception org.apache.flink.api.java.operators.Keys.IncompatibleKeysException
 
skip(long) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
skip(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
skipArray() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
skipBytes() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
skipBytesToRead(int) - Method in class org.apache.flink.api.java.typeutils.runtime.ByteArrayInputView
 
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
 
SolutionSetPlaceHolder(DeltaIterationBase<Record, ?>) - Constructor for class org.apache.flink.api.java.record.operators.DeltaIteration.SolutionSetPlaceHolder
Deprecated.
 
SortedGrouping<T> - Class in org.apache.flink.api.java.operators
SortedGrouping is an intermediate step for a transformation on a grouped and sorted DataSet.
The following transformation can be applied on sorted groups: SortedGrouping.reduceGroup(org.apache.flink.api.common.functions.GroupReduceFunction),
SortedGrouping(DataSet<T>, Keys<T>, int, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
 
SortedGrouping(DataSet<T>, Keys<T>, String, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
 
SortedGrouping(DataSet<T>, Keys<T>, Keys.SelectorFunctionKeys<T, K>, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
 
sortFirstGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sorts Tuple elements within a group in the first input on the specified field in the specified Order.
Note: Only groups of Tuple elements and Pojos can be sorted.
Groups can be sorted by multiple fields by chaining CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.sortFirstGroup(int, Order) calls.
sortFirstGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sorts Pojo or Tuple elements within a group in the first input on the specified field in the specified Order.
Groups can be sorted by multiple fields by chaining CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.sortFirstGroup(String, Order) calls.
sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Sorts Tuple elements within a group on the specified field in the specified Order.
Note: Only groups of Tuple or Pojo elements can be sorted.
Groups can be sorted by multiple fields by chaining SortedGrouping.sortGroup(int, Order) calls.
sortGroup(String, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Sorts Tuple or POJO elements within a group on the specified field in the specified Order.
Note: Only groups of Tuple or Pojo elements can be sorted.
Groups can be sorted by multiple fields by chaining SortedGrouping.sortGroup(String, Order) calls.
sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Sorts Tuple elements within a group on the specified field in the specified Order.
Note: Only groups of Tuple elements and Pojos can be sorted.
Groups can be sorted by multiple fields by chaining UnsortedGrouping.sortGroup(int, Order) calls.
sortGroup(String, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Sorts Pojos within a group on the specified field in the specified Order.
Note: Only groups of Tuple elements and Pojos can be sorted.
Groups can be sorted by multiple fields by chaining UnsortedGrouping.sortGroup(String, Order) calls.
sortGroup(KeySelector<T, K>, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Sorts elements within a group on a key extracted by the specified KeySelector in the specified Order.
Chaining UnsortedGrouping.sortGroup(KeySelector, Order) calls is not supported.
sortLocalOutput(int, Order) - Method in class org.apache.flink.api.java.operators.DataSink
Sorts each local partition of a Tuple data set on the specified field in the specified Order before it is emitted by the output format.
Note: Only tuple data sets can be sorted using integer field indices.
The tuple data set can be sorted on multiple fields in different orders by chaining DataSink.sortLocalOutput(int, Order) calls.
sortLocalOutput(String, Order) - Method in class org.apache.flink.api.java.operators.DataSink
Sorts each local partition of a data set on the field(s) specified by the field expression in the specified Order before it is emitted by the output format.
Note: Non-composite types can only be sorted on the full element which is specified by a wildcard expression ("*" or "_").
Data sets of composite types (Tuple or Pojo) can be sorted on multiple fields in different orders by chaining DataSink.sortLocalOutput(String, Order) calls.
sortPartition(int, Order) - Method in class org.apache.flink.api.java.DataSet
Locally sorts the partitions of the DataSet on the specified field in the specified order.
sortPartition(String, Order) - Method in class org.apache.flink.api.java.DataSet
Locally sorts the partitions of the DataSet on the specified field in the specified order.
sortPartition(int, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Appends an additional sort order with the specified field in the specified order to the local partition sorting of the DataSet.
sortPartition(String, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Appends an additional sort order with the specified field in the specified order to the local partition sorting of the DataSet.
SortPartitionOperator<T> - Class in org.apache.flink.api.java.operators
This operator represents a DataSet with locally sorted partitions.
SortPartitionOperator(DataSet<T>, int, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
 
SortPartitionOperator(DataSet<T>, String, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
 
sortSecondGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sorts Tuple elements within a group in the second input on the specified field in the specified Order.
Note: Only groups of Tuple elements and Pojos can be sorted.
Groups can be sorted by multiple fields by chaining CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.sortSecondGroup(int, Order) calls.
sortSecondGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sorts Pojo or Tuple elements within a group in the second input on the specified field in the specified Order.
Groups can be sorted by multiple fields by chaining CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.sortSecondGroup(String, Order) calls.
source() - Static method in class org.apache.flink.api.java.record.operators.OperatorInfoHelper
Deprecated.
 
SourcePartitionerMarker(String) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
 
SpecificInstanceCollectionSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
SpecificInstanceCollectionSerializerForArrayList() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializerForArrayList
 
SplitDataProperties<T> - Class in org.apache.flink.api.java.io
SplitDataProperties define data properties on InputSplit generated by the InputFormat of a DataSource.
SplitDataProperties(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
Creates SplitDataProperties for the given data types.
SplitDataProperties(DataSource<T>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
Creates SplitDataProperties for the given data types.
SplitDataProperties.SourcePartitionerMarker<T> - Class in org.apache.flink.api.java.io
A custom partitioner to mark compatible split partitionings.
splitsGroupedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that the data within an input split is grouped on the fields defined by the field positions.
splitsGroupedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that the data within an input split is grouped on the fields defined by the field expressions.
splitsOrderedBy(int[], Order[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that the data within an input split is sorted on the fields defined by the field positions in the specified orders.
splitsOrderedBy(String, Order[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that the data within an input split is sorted on the fields defined by the field expressions in the specified orders.
splitsPartitionedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that data is partitioned across input splits on the fields defined by field positions.
splitsPartitionedBy(String, int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that data is partitioned using a specific partitioning method across input splits on the fields defined by field positions.
splitsPartitionedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that data is partitioned across input splits on the fields defined by field expressions.
splitsPartitionedBy(String, String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that data is partitioned using an identifiable method across input splits on the fields defined by field expressions.
startItem() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
startNewSession() - Method in class org.apache.flink.api.java.CollectionEnvironment
 
startNewSession() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Starts a new session, discarding the previous data flow and all of its intermediate results.
startNewSession() - Method in class org.apache.flink.api.java.LocalEnvironment
 
startNewSession() - Method in class org.apache.flink.api.java.RemoteEnvironment
 
STRING_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
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.ByteValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.DoubleSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.DoubleValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.FloatSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.FloatValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.IntSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.IntValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.LongSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.LongValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.ShortSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.ShortValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.SumAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
 
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.TupleComparatorBase
 
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.TupleComparatorBase
 
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.

T

tagged(Value) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
TaggedValue - Class in org.apache.flink.api.java.sca
Extension of ASM's BasicValue that allows to assign "tags" to values and add additional information depending on the tag to the Value.
TaggedValue(Type) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue(Type, TaggedValue.Tag) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue(Type, TaggedValue.Input, String, boolean, boolean) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue(Type, Map<String, TaggedValue>) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue(int) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue.Input - Enum in org.apache.flink.api.java.sca
 
TaggedValue.Tag - Enum in org.apache.flink.api.java.sca
 
ternaryOperation(AbstractInsnNode, BasicValue, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
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
 
TextOutputFormat.TextFormatter<IN> - Interface in org.apache.flink.api.java.io
 
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
 
toForwardedFieldsExpression(TaggedValue.Input) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
toMap() - Method in class org.apache.flink.api.java.utils.ParameterTool
 
toString() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction
 
toString() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction
 
toString() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction
 
toString() - Method in class org.apache.flink.api.java.io.CollectionInputFormat
 
toString() - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
toString() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
 
toString() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
toString() - Method in class org.apache.flink.api.java.io.TextInputFormat
 
toString() - Method in class org.apache.flink.api.java.io.TextOutputFormat
 
toString() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
toString() - Method in class org.apache.flink.api.java.LocalEnvironment
 
toString() - Method in class org.apache.flink.api.java.operators.DataSink
 
toString() - Method in class org.apache.flink.api.java.operators.Keys.ExpressionKeys
 
toString() - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingGroupCombineOperator.TupleUnwrappingGroupCombiner
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedGroupCombineOperator.TupleUnwrappingGroupReducer
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer
 
toString() - Method in class org.apache.flink.api.java.record.operators.FileDataSink
Deprecated.
 
toString() - Method in class org.apache.flink.api.java.RemoteEnvironment
 
toString() - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
toString() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
toString() - Method in class org.apache.flink.api.java.tuple.Tuple0
Creates a string representation of the tuple in the form "()"
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.EnumTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.PojoField
 
toString() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
toString() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.RecordTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
toString() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
toString() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CrossOperator
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DataSink
 
translateToDataFlow() - Method in class org.apache.flink.api.java.operators.DataSource
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DistinctOperator
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.FilterOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.FlatMapOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.PartitionOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ProjectOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ReduceOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.SingleInputOperator
Translates this operation to a data flow operator of the common data flow API.
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
 
translateToDataFlow(Operator<IN1>, Operator<IN2>) - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Translates this java API operator into a common API operator with two inputs.
translateToDataFlow(Operator<T>, Operator<T>) - Method in class org.apache.flink.api.java.operators.UnionOperator
Returns the BinaryNodeTranslation of the Union.
translateToPlan(List<DataSink<?>>, String) - Method in class org.apache.flink.api.java.operators.OperatorTranslation
 
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
 
Tuple0 - Class in org.apache.flink.api.java.tuple
A tuple with 0 fields.
Tuple0() - Constructor for class org.apache.flink.api.java.tuple.Tuple0
 
Tuple0Builder - Class in org.apache.flink.api.java.tuple.builder
 
Tuple0Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
Tuple0Serializer - Class in org.apache.flink.api.java.typeutils.runtime
 
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
 
Tuple3UnwrappingIterator<T,K1,K2> - Class in org.apache.flink.api.java.operators.translation
An iterator that reads 3-tuples (groupKey, sortKey, value) and returns only the values (third field).
Tuple3UnwrappingIterator() - Constructor for class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
Tuple3WrappingCollector<IN,K1,K2> - Class in org.apache.flink.api.java.operators.translation
Needed to wrap tuples to Tuple3<groupKey, sortKey, value> for combine method of group reduce with key selector sorting
Tuple3WrappingCollector(Tuple3UnwrappingIterator<IN, K1, K2>) - Constructor for class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
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
 
tupleClass - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
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
 
TupleComparatorBase<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
TupleComparatorBase(int[], TypeComparator<?>[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
TupleComparatorBase(TupleComparatorBase<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
TupleLeftUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
TupleLeftUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleLeftUnwrappingJoiner
 
TupleRightUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
TupleRightUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleRightUnwrappingJoiner
 
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
 
TupleSerializerBase<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
TupleSerializerBase(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
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
A TypeInformation for the tuple types of the Java API.
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
 
TupleTypeInfoBase<T> - Class in org.apache.flink.api.java.typeutils
 
TupleTypeInfoBase(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
TupleUnwrappingIterator<T,K> - Class in org.apache.flink.api.java.operators.translation
An iterator that reads 2-tuples (key value pairs) and returns only the values (second field).
TupleUnwrappingIterator() - Constructor for class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
TupleUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
TupleUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleUnwrappingJoiner
 
TupleWrappingCollector<IN,K> - Class in org.apache.flink.api.java.operators.translation
Needed to wrap tuples to Tuple2<key, value> pairs for combine method of group reduce with key selector function
TupleWrappingCollector(TupleUnwrappingIterator<IN, K>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
TwoInputOperator<IN1,IN2,OUT,O extends TwoInputOperator<IN1,IN2,OUT,O>> - Class in org.apache.flink.api.java.operators
Base class for operations that operates on two input data sets.
TwoInputOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.TwoInputOperator
 
TwoInputUdfOperator<IN1,IN2,OUT,O extends TwoInputUdfOperator<IN1,IN2,OUT,O>> - Class in org.apache.flink.api.java.operators
The TwoInputUdfOperator is the base class of all binary operators that execute user-defined functions (UDFs).
TwoInputUdfOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.TwoInputUdfOperator
Creates a new operators with the two given data sets as inputs.
TwoKeyExtractingMapper<T,K1,K2> - Class in org.apache.flink.api.java.operators.translation
 
TwoKeyExtractingMapper(KeySelector<T, K1>, KeySelector<T, K2>) - Constructor for class org.apache.flink.api.java.operators.translation.TwoKeyExtractingMapper
 
TypeExtractor - Class in org.apache.flink.api.java.typeutils
A utility for reflection analysis on classes, to determine the return type of implementations of transformation functions.
TypeExtractor() - Constructor for class org.apache.flink.api.java.typeutils.TypeExtractor
 
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<?>...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.ProjectOperator
Deprecated.
types - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
TypeSerializerInputFormat<T> - Class in org.apache.flink.api.java.io
Reads elements by deserializing them with a given type serializer.
TypeSerializerInputFormat(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.io.TypeSerializerInputFormat
 
TypeSerializerOutputFormat<T> - Class in org.apache.flink.api.java.io
Stores elements by serializing them with their type serializer.
TypeSerializerOutputFormat() - Constructor for class org.apache.flink.api.java.io.TypeSerializerOutputFormat
 
typeToClass(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 

U

UdfAnalyzer - Class in org.apache.flink.api.java.sca
Implements a Static Code Analyzer (SCA) that uses the ASM framework for interpreting Java bytecode of Flink UDFs.
UdfAnalyzer(Class<?>, Class<?>, String, TypeInformation<?>, TypeInformation<?>, TypeInformation<?>, Keys<?>, Keys<?>, boolean) - Constructor for class org.apache.flink.api.java.sca.UdfAnalyzer
 
UdfAnalyzerUtils - Class in org.apache.flink.api.java.sca
Utility class to work with UdfAnalyzer
UdfOperator<O extends UdfOperator<O>> - Interface in org.apache.flink.api.java.operators
This interface marks operators as operators that execute user-defined functions (UDFs), such as RichMapFunction, RichReduceFunction, or RichCoGroupFunction.
UdfOperatorUtils - Class in org.apache.flink.api.java.operators
Utility class that contains helper methods to work with UDF operators.
udfWithForwardedFieldsAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
udfWithForwardedFieldsFirstAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
udfWithForwardedFieldsFirstAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
udfWithForwardedFieldsSecondAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
udfWithForwardedFieldsSecondAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
unary() - Static method in class org.apache.flink.api.java.record.operators.OperatorInfoHelper
Deprecated.
 
unaryOperation(AbstractInsnNode, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
union(DataSet<T>) - Method in class org.apache.flink.api.java.DataSet
Creates a union of this DataSet with an other DataSet.
UnionOperator<T> - Class in org.apache.flink.api.java.operators
Java API operator for union of two data sets
UnionOperator(DataSet<T>, DataSet<T>, String) - Constructor for class org.apache.flink.api.java.operators.UnionOperator
Create an operator that produces the union of the two given data sets.
UnsortedGrouping<T> - Class in org.apache.flink.api.java.operators
 
UnsortedGrouping(DataSet<T>, Keys<T>) - Constructor for class org.apache.flink.api.java.operators.UnsortedGrouping
 
UnsupportedAggregationTypeException - Exception in org.apache.flink.api.java.aggregation
 
UnsupportedAggregationTypeException(String) - Constructor for exception org.apache.flink.api.java.aggregation.UnsupportedAggregationTypeException
 
Utils - Class in org.apache.flink.api.java
Utility class that contains helper methods to work with Java APIs.
Utils.CollectHelper<T> - Class in org.apache.flink.api.java
 
Utils.CountHelper<T> - Class in org.apache.flink.api.java
 

V

validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.java.operators.Keys.ExpressionKeys
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.java.operators.Keys.SelectorFunctionKeys
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.java.operators.Keys
 
value - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
valueClass - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
valueClass - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
ValueComparator<T extends org.apache.flink.types.Value & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
Comparator for all Value types that extend Key
ValueComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
valueOf(String) - Static method in enum org.apache.flink.api.java.aggregation.Aggregations
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.operators.join.JoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Input
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Tag
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.flink.api.java.aggregation.Aggregations
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.operators.join.JoinType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Input
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Tag
Returns an array containing the constants of this enum type, in the order they are declared.
ValueSerializer<T extends org.apache.flink.types.Value> - Class in org.apache.flink.api.java.typeutils.runtime
Serializer for Value types.
ValueSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
ValueTypeInfo<T extends org.apache.flink.types.Value> - Class in org.apache.flink.api.java.typeutils
Type information for data types that extend the Value interface.
ValueTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.ValueTypeInfo
 

W

waitForProcessToFinish() - Method in class org.apache.flink.api.java.record.io.ExternalProcessInputFormat
 
where(int...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Continues a CoGroup transformation.
where(String...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Continues a CoGroup transformation.
where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Continues a CoGroup transformation and defines a KeySelector function for the first co-grouped DataSet.
The KeySelector function is called for each element of the first DataSet and extracts a single key value on which the DataSet is grouped.
where(int...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Continues a Join transformation.
where(String...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Continues a Join transformation.
where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Continues a Join transformation and defines a KeySelector function for the first join DataSet.
The KeySelector function is called for each element of the first DataSet and extracts a single key value on which the DataSet is joined.
where(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Continues a Join transformation.
where(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Continues a Join transformation.
where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Continues a Join transformation and defines a KeySelector function for the first join DataSet.
The KeySelector function is called for each element of the first DataSet and extracts a single key value on which the DataSet is joined.
with(CoGroupFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Finalizes a CoGroup transformation by applying a RichCoGroupFunction to groups of elements with identical keys.
Each CoGroupFunction call returns an arbitrary number of keys.
with(CrossFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Finalizes a Cross transformation by applying a CrossFunction to each pair of crossed elements.
Each CrossFunction call returns exactly one element.
with(JoinFunction<I1, I2, R>) - Method in interface org.apache.flink.api.java.operators.join.JoinFunctionAssigner
 
with(FlatJoinFunction<I1, I2, R>) - Method in interface org.apache.flink.api.java.operators.join.JoinFunctionAssigner
 
with(FlatJoinFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Finalizes a Join transformation by applying a RichFlatJoinFunction to each pair of joined elements.
Each JoinFunction call returns exactly one element.
with(JoinFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
 
withBroadcastSet(DataSet<?>, String) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
withBroadcastSet(DataSet<?>, String) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
withBroadcastSet(DataSet<?>, String) - Method in interface org.apache.flink.api.java.operators.UdfOperator
Adds a certain data set as a broadcast set to this operator.
withForwardedFields(String...) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Adds semantic information about forwarded fields of the user-defined function.
withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds semantic information about forwarded fields of the first input of the user-defined function.
withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds semantic information about forwarded fields of the second input of the user-defined function.
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.DataSink
Pass a configuration to the OutputFormat
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.DataSource
Pass a configuration to the InputFormat
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
withParameters(Configuration) - Method in interface org.apache.flink.api.java.operators.UdfOperator
Sets the configuration parameters for the UDF.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sets a custom partitioner for the CoGroup operation.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Sets a custom partitioner for the CoGroup operation.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator
Sets a custom partitioner for this join.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Uses a custom partitioner for the grouping.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Uses a custom partitioner for the grouping.
WorksetPlaceHolder(DeltaIterationBase<?, Record>) - Constructor for class org.apache.flink.api.java.record.operators.DeltaIteration.WorksetPlaceHolder
Deprecated.
 
wrappedFunction - Variable in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
WrappingClassCoGroupFunction(Class<? extends CoGroupFunction>) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator.WrappingClassCoGroupFunction
Deprecated.
 
WrappingClassReduceFunction(Class<? extends ReduceFunction>) - Constructor for class org.apache.flink.api.java.record.operators.ReduceOperator.WrappingClassReduceFunction
 
WrappingCoGroupFunction(CoGroupFunction) - Constructor for class org.apache.flink.api.java.record.operators.CoGroupOperator.WrappingCoGroupFunction
Deprecated.
 
WrappingFlatJoinFunction(JoinFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin.WrappingFlatJoinFunction
 
WrappingFunction<T extends org.apache.flink.api.common.functions.Function> - Class in org.apache.flink.api.java.operators.translation
 
WrappingFunction(T) - Constructor for class org.apache.flink.api.java.operators.translation.WrappingFunction
 
WrappingReduceFunction(ReduceFunction) - Constructor for class org.apache.flink.api.java.record.operators.ReduceOperator.WrappingReduceFunction
 
WritableComparator<T extends org.apache.hadoop.io.Writable & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
 
WritableComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
WritableSerializer<T extends org.apache.hadoop.io.Writable> - Class in org.apache.flink.api.java.typeutils.runtime
 
WritableSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
WritableTypeInfo<T extends org.apache.hadoop.io.Writable> - Class in org.apache.flink.api.java.typeutils
Type information for data types that extend Hadoop's Writable interface.
WritableTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
write(FileOutputFormat<T>, String) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet using a FileOutputFormat to a specified location.
write(FileOutputFormat<T>, String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet using a FileOutputFormat to a specified location.
write(ObjectOutputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
 
write(ObjectOutputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
 
write(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
write(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
write(Kryo, Output, Schema) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.AvroSchemaSerializer
 
WRITE_BUFFER_SIZE - Static variable in class org.apache.flink.api.java.record.io.DelimitedOutputFormat
The configuration key for the entry that defines the write-buffer size.
writeArrayEnd() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeArrayStart() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeAsCsv(String) - Method in class org.apache.flink.api.java.DataSet
Writes a Tuple DataSet as a CSV file to the specified location.
Note: Only a Tuple DataSet can written as a CSV file.
For each Tuple field the result of Object.toString() is written.
writeAsCsv(String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Writes a Tuple DataSet as a CSV file to the specified location.
Note: Only a Tuple DataSet can written as a CSV file.
For each Tuple field the result of Object.toString() is written.
writeAsCsv(String, String, String) - Method in class org.apache.flink.api.java.DataSet
Writes a Tuple DataSet as a CSV file to the specified location with the specified field and line delimiters.
Note: Only a Tuple DataSet can written as a CSV file.
For each Tuple field the result of Object.toString() is written.
writeAsCsv(String, String, String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Writes a Tuple DataSet as a CSV file to the specified location with the specified field and line delimiters.
Note: Only a Tuple DataSet can written as a CSV file.
ยง * For each Tuple field the result of Object.toString() is written.
writeAsFormattedText(String, TextOutputFormat.TextFormatter<T>) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet as a text file to the specified location.
For each element of the DataSet the result of TextOutputFormat.TextFormatter.format(Object) is written.
writeAsFormattedText(String, FileSystem.WriteMode, TextOutputFormat.TextFormatter<T>) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet as a text file to the specified location.
For each element of the DataSet the result of TextOutputFormat.TextFormatter.format(Object) is written.
writeAsText(String) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet as a text file to the specified location.
For each element of the DataSet the result of Object.toString() is written.
writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet as a text file to the specified location.
For each element of the DataSet the result of Object.toString() is written.
writeBoolean(boolean) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeBufferSize(int) - Method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat.AbstractConfigBuilder
Sets the size of the write buffer.
writeBytes(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeBytes(ByteBuffer) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeDouble(double) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeEnum(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeFixed(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeFloat(float) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeIndex(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeInt(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeLong(long) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeMapEnd() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeMapStart() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeNull() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeParametersToConfig(Configuration) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
writeParametersToConfig(Configuration) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
writeRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormat
 
writeRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.TextOutputFormat
 
writeRecord(Record) - Method in class org.apache.flink.api.java.record.io.CsvOutputFormat
 
writeRecord(Record) - Method in class org.apache.flink.api.java.record.io.DelimitedOutputFormat
 
writeString(String) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeString(Utf8) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeVarLongCount(DataOutput, long) - Static method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 

Z

zipWithIndex(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Method that assigns a unique Long value to all elements in the input data set.
zipWithUniqueId(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Method that assigns a unique Long value to all elements in the input data set in the following way: a map function is applied to the input data set each map task holds a counter c which is increased for each record c is shifted by n bits where n = log2(number of parallel tasks) to create a unique ID among all tasks, the task id is added to the counter for each record, the resulting counter is collected
A B C D E F G H I J K L M N O P Q R S T U V W Z 
Skip navigation links

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