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 X Y Z 

A

absentKeysOrValues() - Method in class org.apache.flink.util.LinkedOptionalMap
Returns the key names of any keys or values that are absent.
absoluteTimeMillis() - Method in class org.apache.flink.util.clock.Clock
Gets the current absolute time, in milliseconds.
absoluteTimeMillis() - Method in class org.apache.flink.util.clock.ManualClock
 
absoluteTimeMillis() - Method in class org.apache.flink.util.clock.SystemClock
 
absolutizePath(Path) - Static method in class org.apache.flink.util.FileUtils
Absolutize the given path if it is relative.
AbstractCloseableRegistry<C extends Closeable,T> - Class in org.apache.flink.util
This is the abstract base class for registries that allow to register instances of Closeable, which are all closed if this registry is closed.
AbstractCloseableRegistry(Map<Closeable, T>) - Constructor for class org.apache.flink.util.AbstractCloseableRegistry
 
AbstractDeserializationSchema<T> - Class in org.apache.flink.api.common.serialization
The deserialization schema describes how to turn the byte messages delivered by certain data sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by Flink.
AbstractDeserializationSchema() - Constructor for class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Creates a new AbstractDeserializationSchema and tries to infer the type returned by this DeserializationSchema.
AbstractDeserializationSchema(Class<T>) - Constructor for class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Creates an AbstractDeserializationSchema that returns the TypeInformation indicated by the given class.
AbstractDeserializationSchema(TypeHint<T>) - Constructor for class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Creates an AbstractDeserializationSchema that returns the TypeInformation indicated by the given type hint.
AbstractDeserializationSchema(TypeInformation<T>) - Constructor for class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Creates an AbstractDeserializationSchema that returns the given TypeInformation for the produced type.
AbstractID - Class in org.apache.flink.util
A statistically unique identification number.
AbstractID(byte[]) - Constructor for class org.apache.flink.util.AbstractID
Constructs a new ID with a specific bytes value.
AbstractID(long, long) - Constructor for class org.apache.flink.util.AbstractID
Constructs a new abstract ID.
AbstractID(AbstractID) - Constructor for class org.apache.flink.util.AbstractID
Copy constructor: Creates a new abstract ID from the given one.
AbstractID() - Constructor for class org.apache.flink.util.AbstractID
Constructs a new random ID from a uniform distribution.
AbstractRichFunction - Class in org.apache.flink.api.common.functions
An abstract stub implementation for rich user-defined functions.
AbstractRichFunction() - Constructor for class org.apache.flink.api.common.functions.AbstractRichFunction
 
AbstractRuntimeUDFContext - Class in org.apache.flink.api.common.functions.util
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
AbstractRuntimeUDFContext(TaskInfo, UserCodeClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>, Map<String, Future<Path>>, OperatorMetricGroup) - Constructor for class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
AbstractUdfOperator<OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
Abstract superclass for all contracts that represent actual operators.
AbstractUdfOperator(UserCodeWrapper<FT>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.AbstractUdfOperator
Creates a new abstract operator with the given name wrapping the given user function.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.Plan
Traverses the job depth first from all data sinks on towards the sources.
accept(T) - Method in interface org.apache.flink.util.concurrent.FutureConsumerWithException
 
accept(T, U) - Method in interface org.apache.flink.util.function.BiConsumerWithException
Performs this operation on the given arguments.
accept(S, T, U, V) - Method in interface org.apache.flink.util.function.QuadConsumer
Performs this operation on the given arguments.
accept(T) - Method in interface org.apache.flink.util.function.ThrowingConsumer
Performs this operation on the given argument.
accept(S, T, U) - Method in interface org.apache.flink.util.function.TriConsumer
Performs this operation on the given arguments.
accept(S, T, U) - Method in interface org.apache.flink.util.function.TriConsumerWithException
Performs this operation on the given arguments.
accept(String, K, V) - Method in interface org.apache.flink.util.LinkedOptionalMap.ConsumerWithException
 
accept(Visitor<T>) - Method in interface org.apache.flink.util.Visitable
Contains the logic to invoke the visitor and continue the traversal.
acceptFile(FileStatus) - Method in class org.apache.flink.api.common.io.FileInputFormat
A simple hook to filter files and directories from the input.
acceptWithException(T) - Method in interface org.apache.flink.util.concurrent.FutureConsumerWithException
 
ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.apache.flink.configuration.WebOptions
The config parameter defining the Access-Control-Allow-Origin header for all responses from the web-frontend.
accessField(Field, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
This method is handling the IllegalAccess exceptions of Field.get()
Accumulator<V,R extends Serializable> - Interface in org.apache.flink.api.common.accumulators
Accumulators collect distributed statistics or aggregates in a from user functions and operators.
AccumulatorHelper - Class in org.apache.flink.api.common.accumulators
Helper functions for the interaction with Accumulator.
AccumulatorHelper() - Constructor for class org.apache.flink.api.common.accumulators.AccumulatorHelper
 
acquire(int) - Method in interface org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
Acquires permits for the rate limiter.
acquire(int) - Method in class org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
 
acquireResource() - Method in class org.apache.flink.util.ResourceGuard
Acquired access from one new client for the guarded resource.
adapterForIterator(Iterator<T>) - Static method in interface org.apache.flink.util.CloseableIterator
 
adapterForIterator(Iterator<T>, AutoCloseable) - Static method in interface org.apache.flink.util.CloseableIterator
 
add(V) - Method in interface org.apache.flink.api.common.accumulators.Accumulator
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(long) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(int) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
Consider using DoubleCounter.add(double) instead for primitive double values
add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
Consider using DoubleMaximum.add(double) instead for primitive double values
add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
Consider using DoubleMinimum.add(double) instead for primitive double values
add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.Histogram
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntCounter
Consider using IntCounter.add(int) instead for primitive int values
add(int) - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
Consider using IntMaximum.add(int) instead for primitive integer values
add(int) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
Consider using IntMinimum.add(int) instead for primitive integer values
add(int) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
add(T) - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
add(Long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
Consider using LongCounter.add(long) instead for primitive long values
add(long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
add(Long) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
Consider using LongMaximum.add(long) instead for primitive long values
add(long) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
add(Long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
Consider using LongMinimum.add(long) instead for primitive long values
add(long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
add(T) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
add(T, TypeSerializer<T>) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
add(IN, ACC) - Method in interface org.apache.flink.api.common.functions.AggregateFunction
Adds the given input value to the given accumulator, returning the new accumulator value.
add(IN, ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
 
add(IN) - Method in interface org.apache.flink.api.common.state.AppendingState
Updates the operator state accessible by AppendingState.get() by adding the given value to the list of values.
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
 
add(BlockElement) - Method in class org.apache.flink.configuration.description.Description.DescriptionBuilder
Block of description add.
add(MemorySize) - Method in class org.apache.flink.configuration.MemorySize
 
add(int, V) - Method in class org.apache.flink.types.ListValue
 
add(V) - Method in class org.apache.flink.types.ListValue
 
add(Iterator<T>) - Method in class org.apache.flink.util.UnionIterator
 
addAccumulator(String, Accumulator<V, A>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Add this accumulator.
addAccumulator(String, Accumulator<V, A>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
addAll(AggregatorRegistry) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
addAll(List<T>) - Method in interface org.apache.flink.api.common.state.ListState
Updates the operator state accessible by AppendingState.get() by adding the given values to existing list of values.
addAll(Configuration) - Method in class org.apache.flink.configuration.Configuration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.Configuration
Adds all entries from the given configuration into this configuration.
addAll(Configuration) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
addAll(Configuration) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAll(Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
 
addAll(int, Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
 
addAllToProperties(Properties) - Method in class org.apache.flink.configuration.Configuration
Adds all entries in this Configuration to the given Properties.
addAllToProperties(Properties) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
addAllToProperties(Properties) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAvroGenericDataArrayRegistration(LinkedHashMap<String, KryoRegistration>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
Registers a special Serializer for GenericData.Array.
addAvroSerializersIfRequired(ExecutionConfig, Class<?>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
Loads the utility class from flink-avro and adds Avro-specific serializers.
addCloseableInternal(Closeable, T) - Method in class org.apache.flink.util.AbstractCloseableRegistry
Adds a mapping to the registry map, respecting locking.
addComparatorField(int, TypeComparator<?>) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
addDataSink(GenericDataSinkBase<?>) - Method in class org.apache.flink.api.common.Plan
Adds a data sink to the set of sinks in this program.
addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.common.ExecutionConfig
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.common.ExecutionConfig
Adds a new Kryo default serializer to the Runtime.
addElement(T) - Method in interface org.apache.flink.api.common.serialization.BulkWriter
Adds an element to the encoder.
addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
addField(Value) - Method in class org.apache.flink.types.Record
 
addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
addFirstInput(Operator<IN1>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addFirstInputs(List<Operator<IN1>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addForwardedField(int, int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
Adds, to the existing information, a field that is forwarded directly from the source record(s) in the first input to the destination record(s).
addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
Adds, to the existing information, a field that is forwarded directly from the source record(s) to the destination record(s).
addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInput(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInputs(List<? extends Operator<IN>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addList(List<T>) - Method in class org.apache.flink.util.UnionIterator
 
addReader(int) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
addReader(int) - Method in interface org.apache.flink.api.connector.source.SplitEnumerator
Add a new source reader with the given subtask ID.
addReadFields(int, FieldSet) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
Adds, to the existing information, field(s) that are read in the source record(s) from the first input.
addReadFields(FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
Adds, to the existing information, field(s) that are read in the source record(s).
ADDRESS - Static variable in class org.apache.flink.configuration.JobManagerOptions
The config parameter defining the network address to connect to for communication with the job manager.
ADDRESS - Static variable in class org.apache.flink.configuration.RestOptions
The address that should be used by clients to connect to the server.
ADDRESS - Static variable in class org.apache.flink.configuration.WebOptions
Deprecated.
addSecondInput(Operator<IN2>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addSecondInputs(List<Operator<IN2>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addShutdownHook(AutoCloseable, String, Logger) - Static method in class org.apache.flink.util.ShutdownHookUtil
Adds a shutdown hook to the JVM and returns the Thread, which has been registered.
addShutdownHookThread(Thread, String, Logger) - Static method in class org.apache.flink.util.ShutdownHookUtil
Adds a shutdown hook to the JVM.
addSplits(List<SplitT>) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
addSplits(List<SplitT>) - Method in interface org.apache.flink.api.connector.source.SourceReader
Adds a list of splits for this reader to read.
addSplitsBack(List<SplitT>, int) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
addSplitsBack(List<SplitT>, int) - Method in interface org.apache.flink.api.connector.source.SplitEnumerator
Add a split back to the split enumerator.
addUniqueField(FieldSet) - Method in class org.apache.flink.api.common.operators.CompilerHints
Adds a FieldSet to be unique
addUniqueField(int) - Method in class org.apache.flink.api.common.operators.CompilerHints
Adds a field as having only unique values.
addUniqueFields(Set<FieldSet>) - Method in class org.apache.flink.api.common.operators.CompilerHints
Adds multiple FieldSets to be unique
advanceTime(long, TimeUnit) - Method in class org.apache.flink.util.clock.ManualClock
Advances the time by the given duration.
advanceTime(Duration) - Method in class org.apache.flink.util.clock.ManualClock
Advances the time by the given duration.
aggregate(T) - Method in interface org.apache.flink.api.common.aggregators.Aggregator
Aggregates the given element.
aggregate(DoubleValue) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
aggregate(double) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
Adds the given value to the current aggregate.
aggregate(LongValue) - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
 
aggregate(long) - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
Adds the given value to the current aggregate.
aggregate(long) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
aggregate(LongValue) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
AggregateFunction<IN,ACC,OUT> - Interface in org.apache.flink.api.common.functions
The AggregateFunction is a flexible aggregation function, characterized by the following features: The aggregates may use different types for input values, intermediate aggregates, and result type, to support a wide range of aggregation types.
AggregatingState<IN,OUT> - Interface in org.apache.flink.api.common.state
State interface for aggregating state, based on an AggregateFunction.
AggregatingStateDescriptor<IN,ACC,OUT> - Class in org.apache.flink.api.common.state
A StateDescriptor for AggregatingState.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, Class<ACC>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new state descriptor with the given name, function, and type.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeInformation<ACC>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new ReducingStateDescriptor with the given name and default value.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeSerializer<ACC>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new ValueStateDescriptor with the given name and default value.
Aggregator<T extends Value> - Interface in org.apache.flink.api.common.aggregators
Aggregators are a means of aggregating values across parallel instances of a function.
AggregatorRegistry - Class in org.apache.flink.api.common.aggregators
A registry for iteration Aggregators.
AggregatorRegistry() - Constructor for class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
AggregatorWithName<T extends Value> - Class in org.apache.flink.api.common.aggregators
Simple utility class holding an Aggregator with the name it is registered under.
AggregatorWithName(String, Aggregator<T>) - Constructor for class org.apache.flink.api.common.aggregators.AggregatorWithName
Creates a new instance for the given aggregator and name.
AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use ClientOptions#CLIENT_TIMEOUT instead.
AKKA_DISPATCHER_THROUGHPUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_FRAMESIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_JVM_EXIT_ON_FATAL_ERROR - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_LOOKUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_STARTUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_TCP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
AKKA_TRANSPORT_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use AkkaOptions#TRANSPORT_HEARTBEAT_INTERVAL instead.
AKKA_TRANSPORT_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use AkkaOptions#TRANSPORT_HEARTBEAT_PAUSE instead.
AKKA_TRANSPORT_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use AkkaOptions#TRANSPORT_THRESHOLD instead.
AKKA_WATCH_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
This option is no longer used and has no effect on Flink.
AKKA_WATCH_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
This option is no longer used and has no effect on Flink.
AKKA_WATCH_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
This option is no longer used and has no effect on Flink.
AkkaOptions - Class in org.apache.flink.configuration
Akka configuration options.
AkkaOptions() - Constructor for class org.apache.flink.configuration.AkkaOptions
 
AlgorithmOptions - Class in org.apache.flink.configuration
Configuration parameters for join/sort algorithms.
AlgorithmOptions() - Constructor for class org.apache.flink.configuration.AlgorithmOptions
 
AllFieldsForwardedProperties() - Constructor for class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
allocateOffHeapUnsafeMemory(int) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
 
allocateOffHeapUnsafeMemory(int, Object, Runnable) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Allocates an off-heap unsafe memory and creates a new memory segment to represent that memory.
allocateUnpooledOffHeapMemory(int) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled off-heap memory and creates a new memory segment that represents that memory.
allocateUnpooledOffHeapMemory(int, Object) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled off-heap memory and creates a new memory segment that represents that memory.
allocateUnpooledSegment(int) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled memory and creates a new memory segment that represents that memory.
allocateUnpooledSegment(int, Object) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled memory and creates a new memory segment that represents that memory.
ALLOWED_FALLBACK_FILESYSTEMS - Static variable in class org.apache.flink.configuration.CoreOptions
 
ALWAYS_PARENT_FIRST_LOADER_PATTERNS - Static variable in class org.apache.flink.configuration.CoreOptions
The namespace patterns for classes that are loaded with a preference from the parent classloader, meaning the application class path, rather than any user code jar file.
ALWAYS_PARENT_FIRST_LOADER_PATTERNS_ADDITIONAL - Static variable in class org.apache.flink.configuration.CoreOptions
 
analyzePojo(Type, List<Type>, TypeInformation<IN1>, TypeInformation<IN2>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
append(char) - Method in class org.apache.flink.types.StringValue
 
append(CharSequence) - Method in class org.apache.flink.types.StringValue
 
append(CharSequence, int, int) - Method in class org.apache.flink.types.StringValue
 
append(StringValue) - Method in class org.apache.flink.types.StringValue
 
append(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
 
AppendingState<IN,OUT> - Interface in org.apache.flink.api.common.state
Base interface for partitioned state that supports adding elements and inspecting the current state.
appendOrdering(Integer, Class<? extends Comparable<?>>, Order) - Method in class org.apache.flink.api.common.operators.Ordering
Extends this ordering by appending an additional order requirement.
apply(T, U) - Method in interface org.apache.flink.util.function.BiFunctionWithException
Apply the given values t and u to obtain the resulting value.
apply(T) - Method in interface org.apache.flink.util.function.FunctionWithException
Calls this function.
apply(long) - Method in interface org.apache.flink.util.function.LongFunctionWithException
Applies this function to the given argument.
apply(S, T, U, V) - Method in interface org.apache.flink.util.function.QuadFunction
Applies this function to the given arguments.
apply(S, T, U) - Method in interface org.apache.flink.util.function.TriFunction
Applies this function to the given arguments.
apply(S, T, U) - Method in interface org.apache.flink.util.function.TriFunctionWithException
Applies this function to the given arguments.
applyRegistrations(Kryo, Collection<KryoRegistration>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
Apply a list of KryoRegistration to a Kryo instance.
applyToAllWhileSuppressingExceptions(Iterable<T>, ThrowingConsumer<T, ? extends Exception>) - Static method in class org.apache.flink.util.LambdaUtil
This method supplies all elements from the input to the consumer.
archive() - Method in interface org.apache.flink.api.common.Archiveable
 
archive() - Method in class org.apache.flink.api.common.ExecutionConfig
 
ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.WebOptions
The config parameter defining the number of archived jobs for the JobManager.
ARCHIVE_DIR - Static variable in class org.apache.flink.configuration.JobManagerOptions
The location where the JobManager stores the archives of completed jobs.
Archiveable<T extends Serializable> - Interface in org.apache.flink.api.common
 
ArchivedExecutionConfig - Class in org.apache.flink.api.common
Serializable class which is created when archiving the job.
ArchivedExecutionConfig(ExecutionConfig) - Constructor for class org.apache.flink.api.common.ArchivedExecutionConfig
 
ArchivedExecutionConfig(String, String, int, int, boolean, Map<String, String>) - Constructor for class org.apache.flink.api.common.ArchivedExecutionConfig
 
areCompatible(Keys<?>) - Method in class org.apache.flink.api.common.operators.Keys
Check if two sets of keys are compatible to each other (matching types, key counts)
arity - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
arrayAwareToString(Object) - Static method in class org.apache.flink.util.StringUtils
Converts the given object into a string representation by calling Object.toString() and formatting (possibly nested) arrays and null.
ArrayUtils - Class in org.apache.flink.util
Utility class for Java arrays.
ArrayUtils() - Constructor for class org.apache.flink.util.ArrayUtils
 
asArray(Class<U>) - Static method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Generic utility function that wraps a single class object into an array of that class type.
asCallable(RunnableWithException, T) - Static method in class org.apache.flink.util.function.FunctionUtils
Converts RunnableWithException into a Callable that will return the result.
ascending - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
ascendingComparison - Variable in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
ascendingComparison - Variable in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
ascendingComparison - Variable in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
AscendingTimestampsWatermarks<T> - Class in org.apache.flink.api.common.eventtime
A watermark generator that assumes monotonically ascending timestamps within the stream split and periodically generates watermarks based on that assumption.
AscendingTimestampsWatermarks() - Constructor for class org.apache.flink.api.common.eventtime.AscendingTimestampsWatermarks
Creates a new watermark generator with for ascending timestamps.
asClassLoader() - Method in class org.apache.flink.util.SimpleUserCodeClassLoader
 
asClassLoader() - Method in interface org.apache.flink.util.UserCodeClassLoader
Obtains the actual class loader.
ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
ASK_TIMEOUT_DURATION - Static variable in class org.apache.flink.configuration.AkkaOptions
Timeout for akka ask calls.
asList() - Method in class org.apache.flink.configuration.ConfigOptions.TypedConfigOptionBuilder
Defines that the option's type should be a list of previously defined atomic type.
assembleDynamicConfigsStr(Map<String, String>) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Creates a dynamic parameter list String of the passed configuration map.
assertNoException(CompletableFuture<?>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Asserts that the given CompletableFuture is not completed exceptionally.
assertThrowable(Throwable, Class<T>) - Static method in class org.apache.flink.util.ExceptionUtils
The same as ExceptionUtils.findThrowable(Throwable, Class), but rethrows original exception if the expected exception was not found.
assertThrowable(T, Predicate<Throwable>) - Static method in class org.apache.flink.util.ExceptionUtils
The same as ExceptionUtils.findThrowable(Throwable, Predicate), but rethrows original exception if the expected exception was not found.
assertThrowableWithMessage(Throwable, String) - Static method in class org.apache.flink.util.ExceptionUtils
The same as ExceptionUtils.findThrowableWithMessage(Throwable, String), but rethrows original exception if the expected exception was not found.
assignment() - Method in class org.apache.flink.api.connector.source.SplitsAssignment
 
assignSplit(SplitT, int) - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
Assigns a single split.
assignSplits(SplitsAssignment<SplitT>) - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
Assign the splits.
ASYNC_SNAPSHOTS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
Deprecated.
Checkpoints are aways asynchronous.
AtomicType<T> - Interface in org.apache.flink.api.common.typeinfo
An atomic type is a type that is treated as one indivisible unit and where the entire type acts as a key.
ATTACHED - Static variable in class org.apache.flink.configuration.DeploymentOptions
 
AUTO_GENERATE_UIDS - Static variable in class org.apache.flink.configuration.PipelineOptions
 
AUTO_TYPE_REGISTRATION - Static variable in class org.apache.flink.configuration.PipelineOptions
 
AUTO_WATERMARK_INTERVAL - Static variable in class org.apache.flink.configuration.PipelineOptions
 
AutoCloseableAsync - Interface in org.apache.flink.util
Closeable interface which allows to close a resource in a non blocking fashion.
available() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
available() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
available() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
available() - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
AverageAccumulator - Class in org.apache.flink.api.common.accumulators
An accumulator that computes the average value.
AverageAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.AverageAccumulator
 
AVG_RECORD_BYTES_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Constant indicating that average record width is unknown.
avgBytesPerRecord - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
AvroUtils - Class in org.apache.flink.api.java.typeutils
Utility methods for dealing with Avro types.
AvroUtils() - Constructor for class org.apache.flink.api.java.typeutils.AvroUtils
 
AWAIT_LEADER_TIMEOUT - Static variable in class org.apache.flink.configuration.RestOptions
The time in ms that the client waits for the leader address, e.g., Dispatcher or WebMonitorEndpoint.

B

BACKPRESSURE_CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.WebOptions
Deprecated.
- no longer used.
BACKPRESSURE_DELAY - Static variable in class org.apache.flink.configuration.WebOptions
Deprecated.
- no longer used.
BACKPRESSURE_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.WebOptions
Deprecated.
- no longer used.
BACKPRESSURE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.WebOptions
Deprecated.
- no longer used.
BackwardsCompatibleSerializerSnapshot<T> - Class in org.apache.flink.api.common.typeutils
A utility TypeSerializerConfigSnapshot that is used for backwards compatibility purposes.
BackwardsCompatibleSerializerSnapshot(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
BaseStatistics - Interface in org.apache.flink.api.common.io.statistics
Interface describing the basic statistics that can be obtained from the input.
BasicArrayTypeInfo<T,C> - Class in org.apache.flink.api.common.typeinfo
Type information for arrays boxed primitive types.
BasicTypeComparator<T extends Comparable<T>> - Class in org.apache.flink.api.common.typeutils.base
 
BasicTypeComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
BasicTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for primitive types (int, long, double, byte, ...), String, Date, Void, BigInteger, and BigDecimal.
BasicTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BATCH_SHUFFLE_MODE - Static variable in class org.apache.flink.configuration.ExecutionOptions
 
BatchShuffleMode - Enum in org.apache.flink.api.common
Defines how data is exchanged between tasks in batch ExecutionOptions.RUNTIME_MODE if the shuffling behavior has not been set explicitly for an individual exchange.
BiConsumerWithException<T,U,E extends Throwable> - Interface in org.apache.flink.util.function
A checked extension of the BiConsumer interface.
BiFunctionWithException<T,U,R,E extends Throwable> - Interface in org.apache.flink.util.function
BiFunction interface which can throw exceptions.
BIG_DEC - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for BigDecimal.
BIG_DEC_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BIG_INT - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for BigInteger.
BIG_INT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BigDecComparator - Class in org.apache.flink.api.common.typeutils.base
Comparator for comparing BigDecimal values.
BigDecComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
BigDecParser - Class in org.apache.flink.types.parser
Parses a text field into a BigDecimal.
BigDecParser() - Constructor for class org.apache.flink.types.parser.BigDecParser
 
BigDecSerializer - Class in org.apache.flink.api.common.typeutils.base
Serializer for serializing/deserializing BigDecimal values including null values.
BigDecSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
BigDecSerializer.BigDecSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
BigDecSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.BigDecSerializer.BigDecSerializerSnapshot
 
BigIntComparator - Class in org.apache.flink.api.common.typeutils.base
Comparator for comparing BigInteger values.
BigIntComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
BigIntParser - Class in org.apache.flink.types.parser
Parses a text field into a BigInteger.
BigIntParser() - Constructor for class org.apache.flink.types.parser.BigIntParser
 
BigIntSerializer - Class in org.apache.flink.api.common.typeutils.base
Serializer for serializing/deserializing BigInteger values including null values.
BigIntSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
BigIntSerializer.BigIntSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
BigIntSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.BigIntSerializer.BigIntSerializerSnapshot
 
BinaryInputFormat<T> - Class in org.apache.flink.api.common.io
Base class for all input formats that use blocks of fixed size.
BinaryInputFormat() - Constructor for class org.apache.flink.api.common.io.BinaryInputFormat
 
BinaryInputFormat.BlockBasedInput - Class in org.apache.flink.api.common.io
Reads the content of a block of data.
BinaryOperatorInformation<IN1,IN2,OUT> - Class in org.apache.flink.api.common.operators
A class for holding information about a single input operator, such as input/output TypeInformation.
BinaryOperatorInformation(TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.BinaryOperatorInformation
 
BinaryOutputFormat<T> - Class in org.apache.flink.api.common.io
 
BinaryOutputFormat() - Constructor for class org.apache.flink.api.common.io.BinaryOutputFormat
 
BinaryOutputFormat.BlockBasedOutput - Class in org.apache.flink.api.common.io
Writes a block info at the end of the blocks.
Current implementation uses only int and not long.
BIND_ADDRESS - Static variable in class org.apache.flink.configuration.RestOptions
The address that the server binds itself to.
BIND_HOST - Static variable in class org.apache.flink.configuration.JobManagerOptions
The local address of the network interface that the job manager binds to.
BIND_HOST - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The local address of the network interface that the task manager binds to.
BIND_PORT - Static variable in class org.apache.flink.configuration.RestOptions
The port range that the server could bind itself to.
bitMix(int) - Static method in class org.apache.flink.util.MathUtils
Bit-mixing for pseudo-randomization of integers (e.g., to guard against bad hash functions).
BLOB_FETCH_BACKLOG_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_FETCH_CONCURRENT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_FETCH_RETRIES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_SERVER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_SERVICE_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
BLOB_STORAGE_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
blobKey - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
BlobServerOptions - Class in org.apache.flink.configuration
Configuration options for the BlobServer and BlobCache.
BlobServerOptions() - Constructor for class org.apache.flink.configuration.BlobServerOptions
 
BLOCK_SIZE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.BinaryInputFormat
The config parameter which defines the fixed length of a record.
BLOCK_SIZE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.BinaryOutputFormat
The config parameter which defines the fixed length of a record.
BlockBasedInput(FSDataInputStream, int) - Constructor for class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
BlockBasedInput(FSDataInputStream, int, long) - Constructor for class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
BlockBasedOutput(OutputStream, int) - Constructor for class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
BlockElement - Interface in org.apache.flink.configuration.description
Part of description that represents a block e.g.
BlockInfo - Class in org.apache.flink.api.common.io
A block of 24 bytes written at the end of a block in a binary file, and containing i) the number of records in the block, ii) the accumulated number of records, and iii) the offset of the first record in the block.
BlockInfo() - Constructor for class org.apache.flink.api.common.io.BlockInfo
 
BLOCKING_SHUFFLE_COMPRESSION_ENABLED - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Boolean flag indicating whether the shuffle data will be compressed for blocking shuffle mode.
BlockLocation - Interface in org.apache.flink.core.fs
A BlockLocation lists hosts, offset and length of block.
BOOLEAN - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive boolean and Boolean.
BOOLEAN_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
BOOLEAN_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
BOOLEAN_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BOOLEAN_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
BooleanComparator - Class in org.apache.flink.api.common.typeutils.base
 
BooleanComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
BooleanParser - Class in org.apache.flink.types.parser
 
BooleanParser() - Constructor for class org.apache.flink.types.parser.BooleanParser
 
BooleanPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
BooleanPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
BooleanPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for boolean arrays.
BooleanPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
BooleanPrimitiveArraySerializer.BooleanPrimitiveArraySerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base.array
Serializer configuration snapshot for compatibility and format evolution.
BooleanPrimitiveArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer.BooleanPrimitiveArraySerializerSnapshot
 
BooleanSerializer - Class in org.apache.flink.api.common.typeutils.base
Type serializer for Boolean.
BooleanSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
BooleanSerializer.BooleanSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
BooleanSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanSerializer.BooleanSerializerSnapshot
 
booleanType() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Boolean type.
BooleanValue - Class in org.apache.flink.types
Boxed serializable and comparable boolean type, representing the primitive type boolean.
BooleanValue() - Constructor for class org.apache.flink.types.BooleanValue
 
BooleanValue(boolean) - Constructor for class org.apache.flink.types.BooleanValue
 
BooleanValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for BooleanValue based on CopyableValueComparator.
BooleanValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
BooleanValueParser - Class in org.apache.flink.types.parser
 
BooleanValueParser() - Constructor for class org.apache.flink.types.parser.BooleanValueParser
 
BooleanValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
BooleanValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
BooleanValueSerializer.BooleanValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
BooleanValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer.BooleanValueSerializerSnapshot
 
Boundedness - Enum in org.apache.flink.api.connector.source
The boundedness of a stream.
BoundedOutOfOrdernessWatermarks<T> - Class in org.apache.flink.api.common.eventtime
A WatermarkGenerator for situations where records are out of order, but you can place an upper bound on how far the events are out of order.
BoundedOutOfOrdernessWatermarks(Duration) - Constructor for class org.apache.flink.api.common.eventtime.BoundedOutOfOrdernessWatermarks
Creates a new watermark generator with the given out-of-orderness bound.
broadcastInputs - Variable in class org.apache.flink.api.common.operators.AbstractUdfOperator
The extra inputs which parameterize the user function.
BroadcastState<K,V> - Interface in org.apache.flink.api.common.state
A type of state that can be created to store the state of a BroadcastStream.
BroadcastVariableInitializer<T,O> - Interface in org.apache.flink.api.common.functions
A broadcast variable initializer can be used to transform a broadcast variable into another format during initialization.
buffer - Variable in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
BUFFER_DEBLOAT_ENABLED - Static variable in class org.apache.flink.configuration.TaskManagerOptions
 
BUFFER_DEBLOAT_PERIOD - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The period between recalculation the relevant size of the buffer.
BUFFER_DEBLOAT_SAMPLES - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The number of samples requires for the buffer size adjustment.
BUFFER_DEBLOAT_TARGET - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The total time for which automated adjusted buffers should be fully consumed.
BUFFER_DEBLOAT_THRESHOLD_PERCENTAGES - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Difference between the new and the old buffer size for applying the new value(in percent).
BUFFER_TIMEOUT - Static variable in class org.apache.flink.configuration.ExecutionOptions
 
bufferTimeout - Variable in class org.apache.flink.api.dag.Transformation
 
build() - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
 
build() - Method in class org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Build the SlotSharingGroup.
build() - Method in class org.apache.flink.api.common.state.StateTtlConfig.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
 
build() - Method in class org.apache.flink.configuration.description.Description.DescriptionBuilder
Creates description representation.
build() - Method in class org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
Builder(Time) - Constructor for class org.apache.flink.api.common.state.StateTtlConfig.Builder
 
builder() - Static method in class org.apache.flink.configuration.description.Description
 
Builder() - Constructor for class org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
BulkIterationBase<T> - Class in org.apache.flink.api.common.operators.base
 
BulkIterationBase(UnaryOperatorInformation<T, T>) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase
 
BulkIterationBase(UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase
 
BulkIterationBase.PartialSolutionPlaceHolder<OT> - Class in org.apache.flink.api.common.operators.base
Specialized operator to use as a recognizable place-holder for the input to the step function when composing the nested data flow.
BulkIterationBase.TerminationCriterionAggregationConvergence - Class in org.apache.flink.api.common.operators.base
Convergence for the termination criterion is reached if no tuple is output at current iteration for the termination criterion branch
BulkIterationBase.TerminationCriterionAggregator - Class in org.apache.flink.api.common.operators.base
Aggregator that basically only adds 1 for every output tuple of the termination criterion branch
BulkIterationBase.TerminationCriterionMapper<X> - Class in org.apache.flink.api.common.operators.base
Special Mapper that is added before a termination criterion and is only a container for an special aggregator
BulkWriter<T> - Interface in org.apache.flink.api.common.serialization
An encoder that encodes data in a bulk fashion, encoding many records together at a time.
BulkWriter.Factory<T> - Interface in org.apache.flink.api.common.serialization
A factory that creates a BulkWriter.
BYTE - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive byte and Byte.
BYTE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
BYTE_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
BYTE_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BYTE_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
ByteArrayInputStreamWithPos - Class in org.apache.flink.core.memory
Un-synchronized stream similar to Java's ByteArrayInputStream that also exposes the current position.
ByteArrayInputStreamWithPos() - Constructor for class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayInputStreamWithPos(byte[]) - Constructor for class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayInputStreamWithPos(byte[], int, int) - Constructor for class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayOutputStreamWithPos - Class in org.apache.flink.core.memory
Un-synchronized stream similar to Java's ByteArrayOutputStream that also exposes the current position.
ByteArrayOutputStreamWithPos() - Constructor for class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
ByteArrayOutputStreamWithPos(int) - Constructor for class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
ByteComparator - Class in org.apache.flink.api.common.typeutils.base
 
ByteComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ByteComparator
 
ByteParser - Class in org.apache.flink.types.parser
 
ByteParser() - Constructor for class org.apache.flink.types.parser.ByteParser
 
BytePrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
BytePrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
BytePrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for byte arrays.
BytePrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
BytePrimitiveArraySerializer.BytePrimitiveArraySerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base.array
Serializer configuration snapshot for compatibility and format evolution.
BytePrimitiveArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer.BytePrimitiveArraySerializerSnapshot
 
ByteSerializer - Class in org.apache.flink.api.common.typeutils.base
Type serializer for Byte.
ByteSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
ByteSerializer.ByteSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
ByteSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.ByteSerializer.ByteSerializerSnapshot
 
byteToHexString(byte[], int, int) - Static method in class org.apache.flink.util.StringUtils
Given an array of bytes it will convert the bytes to a hex string representation of the bytes.
byteToHexString(byte[]) - Static method in class org.apache.flink.util.StringUtils
Given an array of bytes it will convert the bytes to a hex string representation of the bytes.
ByteValue - Class in org.apache.flink.types
Boxed serializable and comparable byte type, representing the primitive type byte (signed 8 bit integer).
ByteValue() - Constructor for class org.apache.flink.types.ByteValue
Initializes the encapsulated byte with 0.
ByteValue(byte) - Constructor for class org.apache.flink.types.ByteValue
Initializes the encapsulated byte with the provided value.
ByteValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for ByteValue based on CopyableValueComparator.
ByteValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
ByteValueParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a ByteValue.
ByteValueParser() - Constructor for class org.apache.flink.types.parser.ByteValueParser
 
ByteValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
ByteValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
ByteValueSerializer.ByteValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
ByteValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.ByteValueSerializer.ByteValueSerializerSnapshot
 
Bzip2InputStreamFactory - Class in org.apache.flink.api.common.io.compression
Factory for Bzip2 decompressors.
Bzip2InputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 

C

CACHED_FILES - Static variable in class org.apache.flink.configuration.PipelineOptions
 
cacheFile - Variable in class org.apache.flink.api.common.Plan
Hash map for files in the distributed cache: registered name to cache entry.
callAsync(Callable<T>, BiConsumer<T, Throwable>) - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
Invoke the callable and handover the return value to the handler which will be executed by the source coordinator.
callAsync(Callable<T>, BiConsumer<T, Throwable>, long, long) - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
Invoke the given callable periodically and handover the return value to the handler which will be executed by the source coordinator.
canBePrefixMap(ConfigOption<?>) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Maps can be represented in two ways.
cancel() - Method in interface org.apache.flink.core.execution.JobClient
Cancels the associated job.
cancel(boolean) - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
 
CANCEL_ENABLE - Static variable in class org.apache.flink.configuration.WebOptions
Config parameter indicating whether jobs can be cancel from the web-frontend.
canEqual(Object) - Method in class org.apache.flink.api.common.ExecutionConfig
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Returns true if the given object can be equaled with this object.
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
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.ListTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
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
 
canReadInt() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
canReadLong() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
CAPTURE_ASK_CALLSTACK - Static variable in class org.apache.flink.configuration.AkkaOptions
Flag whether to capture call stacks for RPC ask calls.
CHAR - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive char and Character.
CHAR_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
CHAR_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
CHAR_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
CHAR_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
charAt(int) - Method in class org.apache.flink.types.StringValue
 
CharComparator - Class in org.apache.flink.api.common.typeutils.base
 
CharComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.CharComparator
 
CharPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
CharPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
CharPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for char arrays.
CharPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
CharPrimitiveArraySerializer.CharPrimitiveArraySerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base.array
Serializer configuration snapshot for compatibility and format evolution.
CharPrimitiveArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer.CharPrimitiveArraySerializerSnapshot
 
CharSerializer - Class in org.apache.flink.api.common.typeutils.base
Type serializer for Character.
CharSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.CharSerializer
 
CharSerializer.CharSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
CharSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.CharSerializer.CharSerializerSnapshot
 
CharValue - Class in org.apache.flink.types
Boxed serializable and comparable character type, representing the primitive type char.
CharValue() - Constructor for class org.apache.flink.types.CharValue
Initializes the encapsulated char with 0.
CharValue(char) - Constructor for class org.apache.flink.types.CharValue
Initializes the encapsulated char with the provided value.
CharValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for CharValue based on CopyableValueComparator.
CharValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
CharValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
CharValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
CharValueSerializer.CharValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
CharValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.CharValueSerializer.CharValueSerializerSnapshot
 
CHECK_LEAKED_CLASSLOADER - Static variable in class org.apache.flink.configuration.CoreOptions
 
CHECK_MULTIPLE_FREE_PROPERTY - Static variable in class org.apache.flink.core.memory.MemorySegment
System property for activating multiple free segment check, for testing purpose.
checkAndCoSort(int[], Class<?>[]) - Static method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
checkAndExtractLambda(Function) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks if the given function has been implemented using a Java 8 lambda.
checkArgument(boolean) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkArgument(boolean, Object) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkArgument(boolean, String, Object...) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkCompletedNormally(CompletableFuture<?>) - Static method in class org.apache.flink.util.Preconditions
Ensures that future has completed normally.
checked(Supplier<R>) - Static method in interface org.apache.flink.util.function.CheckedSupplier
 
checkedDownCast(long) - Static method in class org.apache.flink.util.MathUtils
Casts the given value to a 32 bit integer, if it can be safely done.
CheckedSupplier<R> - Interface in org.apache.flink.util.function
Similar to Supplier but can throw Exception.
checkElementIndex(int, int) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given index is valid for an array, list or string of the given size.
checkElementIndex(int, int, String) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given index is valid for an array, list or string of the given size.
checkExit(int) - Method in class org.apache.flink.core.security.FlinkSecurityManager
 
checkForInstantiation(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Performs a standard check whether the class can be instantiated by Class#newInstance().
checkForInstantiationError(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
 
checkForMonotonousOrder(int[], Class<?>[]) - Static method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
checkIfNullSupported(TypeSerializer<T>) - Static method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
This method checks if serializer supports null value.
checkInterrupted(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether the given exception is a InterruptedException and sets the interrupted flag accordingly.
checkJarFile(URL) - Static method in class org.apache.flink.util.JarUtils
 
checkNotNull(T) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given object reference is not null.
checkNotNull(T, String) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given object reference is not null.
checkNotNull(T, String, Object...) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given object reference is not null.
checkPermission(Permission) - Method in class org.apache.flink.core.security.FlinkSecurityManager
 
checkPermission(Permission, Object) - Method in class org.apache.flink.core.security.FlinkSecurityManager
 
CHECKPOINT_STORAGE - Static variable in class org.apache.flink.configuration.CheckpointingOptions
The checkpoint storage used to checkpoint state for recovery.
CheckpointableInputFormat<S extends InputSplit,T extends Serializable> - Interface in org.apache.flink.api.common.io
An interface that describes InputFormats that allow checkpointing/restoring their state.
CheckpointingOptions - Class in org.apache.flink.configuration
A collection of all configuration options that relate to checkpoints and savepoints.
CheckpointingOptions() - Constructor for class org.apache.flink.configuration.CheckpointingOptions
 
CheckpointListener - Interface in org.apache.flink.api.common.state
This interface is typically only needed for transactional interaction with the "outside world", like committing external side effects on checkpoints.
CHECKPOINTS_DIRECTORY - Static variable in class org.apache.flink.configuration.CheckpointingOptions
The default directory used for storing the data files and meta data of checkpoints in a Flink supported filesystem.
CHECKPOINTS_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
CHECKPOINTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.WebOptions
Config parameter defining the number of checkpoints to remember for recent history.
checkState(boolean) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkState(boolean, Object) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkState(boolean, String, Object...) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkStateAndGet(CompletableFuture<T>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Perform check state that future has completed normally and return the result.
ChildFirstClassLoader - Class in org.apache.flink.util
A variant of the URLClassLoader that first loads from the URLs and only after that from the parent.
ChildFirstClassLoader(URL[], ClassLoader, String[], Consumer<Throwable>) - Constructor for class org.apache.flink.util.ChildFirstClassLoader
 
CLASS_FILE_EXTENSION - Static variable in class org.apache.flink.util.FileUtils
 
classLoader - Variable in class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
CLASSLOADER_RESOLVE_ORDER - Static variable in class org.apache.flink.configuration.CoreOptions
Defines the class resolution strategy when loading classes from user code, meaning whether to first check the user code jar ("child-first") or the application classpath ("parent-first")
ClassLoaderObjectInputStream(InputStream, ClassLoader) - Constructor for class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
CLASSPATHS - Static variable in class org.apache.flink.configuration.PipelineOptions
A list of URLs that are added to the classpath of each user code classloader of the program.
clean(Object, ExecutionConfig.ClosureCleanerLevel, boolean) - Static method in class org.apache.flink.api.java.ClosureCleaner
Tries to clean the closure of the given object, if the object is a non-static inner class.
cleanDirectory(File) - Static method in class org.apache.flink.util.FileUtils
Removes all files contained within a directory, without removing the directory itself.
cleanup(Logger, AutoCloseable...) - Static method in class org.apache.flink.util.IOUtils
Close the AutoCloseable objects and ignore any Exception or null pointers.
CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.BlobServerOptions
Cleanup interval of the blob caches at the task managers (in seconds).
cleanupFullSnapshot() - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
Cleanup expired state in full snapshot on checkpoint.
cleanupIncrementally(int, boolean) - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
Cleanup expired state incrementally cleanup local state.
cleanupInRocksdbCompactFilter(long) - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
Cleanup expired state while Rocksdb compaction is running.
cleanupRecoverableState(RecoverableWriter.ResumeRecoverable) - Method in class org.apache.flink.core.fs.local.LocalRecoverableWriter
 
cleanupRecoverableState(RecoverableWriter.ResumeRecoverable) - Method in interface org.apache.flink.core.fs.RecoverableWriter
Frees up any resources that were previously occupied in order to be able to recover from a (potential) failure.
CleanupWhenUnsuccessful - Interface in org.apache.flink.api.common.io
OutputFormats may implement this interface to run a cleanup hook when the execution is not successful.
clear() - Method in interface org.apache.flink.api.common.state.State
Removes the value mapped under the current key.
clear() - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
clear() - Method in class org.apache.flink.types.ListValue
 
clear() - Method in class org.apache.flink.types.MapValue
 
clear() - Method in class org.apache.flink.types.Record
Clears the record.
clear() - Method in class org.apache.flink.types.Row
Clears all fields of this row.
clear() - Method in class org.apache.flink.util.UnionIterator
 
clearAllBroadcastVariables() - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
clearBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
clearFirstInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Clears this operator's first input.
clearInputs() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Removes all inputs.
clearSecondInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Clears this operator's second input.
clearUniqueFields() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
CLIENT_CONNECT_TIMEOUT_SECONDS - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
CLIENT_MAX_CONTENT_LENGTH - Static variable in class org.apache.flink.configuration.RestOptions
The maximum content length that the client will handle.
CLIENT_NETWORK_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Number of network (event loop) threads for the KvState client (0 => Use number of available cores).
CLIENT_SOCKET_WORKER_POOL_SIZE_FACTOR - Static variable in class org.apache.flink.configuration.AkkaOptions
 
CLIENT_SOCKET_WORKER_POOL_SIZE_MAX - Static variable in class org.apache.flink.configuration.AkkaOptions
 
CLIENT_SOCKET_WORKER_POOL_SIZE_MIN - Static variable in class org.apache.flink.configuration.AkkaOptions
 
CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
Deprecated.
Use the ClientOptions.CLIENT_TIMEOUT instead.
Clock - Class in org.apache.flink.util.clock
A clock that gives access to time.
Clock() - Constructor for class org.apache.flink.util.clock.Clock
 
clone() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
Duplicates the accumulator.
clone() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
clone() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
clone() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
clone() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
clone() - Method in class org.apache.flink.api.common.accumulators.Histogram
 
clone() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
clone() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
clone() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
clone() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
clone() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
clone() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
clone() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
clone() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
clone() - Method in class org.apache.flink.api.common.operators.Ordering
 
clone() - Method in class org.apache.flink.api.common.operators.util.FieldSet
Since instances of FieldSet are strictly immutable, this method does not actually clone, but it only returns the original instance.
clone() - Method in class org.apache.flink.configuration.Configuration
 
clone() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
clone(T) - Static method in class org.apache.flink.util.InstantiationUtil
Clones the given serializable object using Java serialization.
clone(T, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
Clones the given serializable object using Java serialization, using the given classloader to resolve the cloned classes.
close() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
close() - Method in interface org.apache.flink.api.common.functions.RichFunction
Tear-down method for the user code.
close() - Method in class org.apache.flink.api.common.functions.util.CopyingListCollector
 
close() - Method in class org.apache.flink.api.common.functions.util.ListCollector
 
close() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
close() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
close() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Closes the input by releasing all buffers and closing the file input stream.
close() - Method in class org.apache.flink.api.common.io.FileInputFormat
Closes the file input stream of the input format.
close() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
close() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
close() - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
close() - Method in interface org.apache.flink.api.common.io.InputFormat
Method that marks the end of the life-cycle of an input split.
close() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
close() - Method in interface org.apache.flink.api.common.io.OutputFormat
Method that marks the end of the life-cycle of parallel output instance.
close() - Method in interface org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
 
close() - Method in class org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
 
close() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
close() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
close() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
close() - Method in interface org.apache.flink.api.connector.source.SplitEnumerator
Called to close the enumerator, in case it holds on to any resources, like threads or network connections.
close() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
close() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
close() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
close() - Method in class org.apache.flink.core.fs.FSDataOutputStream
Closes the output stream.
close() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
close() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
close() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
close() - Method in class org.apache.flink.core.fs.RecoverableFsDataOutputStream
Closes this stream.
close() - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
close() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
close() - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
close() - Method in class org.apache.flink.core.plugin.PluginLoader
 
close() - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
close() - Method in interface org.apache.flink.util.AutoCloseableAsync
 
close() - Method in class org.apache.flink.util.CloseableIterable.Empty
 
close() - Method in class org.apache.flink.util.CloseableIterator.IteratorAdapter
 
close() - Method in interface org.apache.flink.util.Collector
Closes the collector.
close() - Method in class org.apache.flink.util.ResourceGuard
Closed the resource guard.
close() - Method in class org.apache.flink.util.ResourceGuard.Lease
 
close() - Method in class org.apache.flink.util.TemporaryClassLoaderContext
 
CloseableIterable<T> - Interface in org.apache.flink.util
This interface represents an iterable that is also closeable.
CloseableIterable.Empty<T> - Class in org.apache.flink.util
Empty iterator.
CloseableIterator<T> - Interface in org.apache.flink.util
This interface represents an Iterator that is also AutoCloseable.
CloseableIterator.IteratorAdapter<E> - Class in org.apache.flink.util
Adapter from Iterator to CloseableIterator.
CloseableRegistry - Class in org.apache.flink.core.fs
This class allows to register instances of Closeable, which are all closed if this registry is closed.
CloseableRegistry() - Constructor for class org.apache.flink.core.fs.CloseableRegistry
 
closeableToRef - Variable in class org.apache.flink.util.AbstractCloseableRegistry
Map from tracked Closeables to some associated meta data.
closeAll(AutoCloseable...) - Static method in class org.apache.flink.util.IOUtils
 
closeAll(Iterable<? extends AutoCloseable>) - Static method in class org.apache.flink.util.IOUtils
Closes all AutoCloseable objects in the parameter, suppressing exceptions.
closeAllQuietly(AutoCloseable...) - Static method in class org.apache.flink.util.IOUtils
Closes all elements in the iterable with closeQuietly().
closeAllQuietly(Iterable<? extends AutoCloseable>) - Static method in class org.apache.flink.util.IOUtils
Closes all elements in the iterable with closeQuietly().
closeAsync() - Method in interface org.apache.flink.util.AutoCloseableAsync
Trigger the closing of the resource and return the corresponding close future.
closed - Variable in class org.apache.flink.core.fs.RefCountedFile
 
closeForCommit() - Method in class org.apache.flink.core.fs.RecoverableFsDataOutputStream
Closes the stream, ensuring persistence of all data (similar to FSDataOutputStream.sync()).
closeFunction(Function) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
closeInputFormat() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
closeInputFormat() - Method in class org.apache.flink.api.common.io.RichInputFormat
Closes this InputFormat instance.
closeInterruptibly() - Method in class org.apache.flink.util.ResourceGuard
 
closeQuietly(AutoCloseable) - Static method in class org.apache.flink.util.IOUtils
Closes the given AutoCloseable.
closeSafetyNetAndGuardedResourcesForThread() - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
Closes the safety net for a thread.
closeSocket(Socket) - Static method in class org.apache.flink.util.IOUtils
Closes the socket ignoring IOException.
closeStream(Closeable) - Static method in class org.apache.flink.util.IOUtils
Closes the stream ignoring IOException.
closeUninterruptibly() - Method in class org.apache.flink.util.ResourceGuard
If the current thread is interrupted while waiting for the close method to complete, then it will continue to wait.
ClosingFSDataInputStream - Class in org.apache.flink.core.fs
This class is a WrappingProxy for FSDataInputStream that is used to implement a safety net against unclosed streams.
ClosingFSDataOutputStream - Class in org.apache.flink.core.fs
This class is a WrappingProxy for FSDataOutputStream that is used to implement a safety net against unclosed streams.
ClosingFSDataOutputStream(FSDataOutputStream, SafetyNetCloseableRegistry) - Constructor for class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
CLOSURE_CLEANER_LEVEL - Static variable in class org.apache.flink.configuration.PipelineOptions
 
ClosureCleaner - Class in org.apache.flink.api.java
The closure cleaner is a utility that tries to truncate the closure (enclosing instance) of non-static inner classes (created for inline transformation functions).
ClosureCleaner() - Constructor for class org.apache.flink.api.java.ClosureCleaner
 
CLUSTER_IO_EXECUTOR_POOL_SIZE - Static variable in class org.apache.flink.configuration.ClusterOptions
 
CLUSTER_SERVICES_SHUTDOWN_TIMEOUT - Static variable in class org.apache.flink.configuration.ClusterOptions
 
ClusterOptions - Class in org.apache.flink.configuration
Options which control the cluster behaviour.
ClusterOptions() - Constructor for class org.apache.flink.configuration.ClusterOptions
 
ClusterOptions.UncaughtExceptionHandleMode - Enum in org.apache.flink.configuration
 
ClusterOptions.UserSystemExitMode - Enum in org.apache.flink.configuration
The mode of how to handle user code attempting to exit JVM.
code(String) - Static method in class org.apache.flink.configuration.description.TextElement
Creates a block of text formatted as code.
CodeAnalysisMode - Enum in org.apache.flink.api.common
Deprecated.
The code analysis code has been removed and this enum has no effect. NOTE It can not be removed from the codebase for now, because it had been serialized as part of the ExecutionConfig which in turn had been serialized as part of the PojoSerializer.

This class can be removed when we drop support for pre 1.8 serializer snapshots that contained java serialized serializers (TypeSerializerConfigSnapshot).

coGroup(Iterable<IN1>, Iterable<IN2>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.CoGroupFunction
This method must be implemented to provide a user implementation of a coGroup.
coGroup(Iterable<IN1>, Iterable<IN2>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichCoGroupFunction
 
CoGroupFunction<IN1,IN2,O> - Interface in org.apache.flink.api.common.functions
The interface for CoGroup functions.
CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
CoGroupOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
CoGroupOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
CoGroupOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
CoGroupRawOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
CoGroupRawOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
CoGroupRawOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
CoGroupRawOperatorBase.SimpleListIterable<IN> - Class in org.apache.flink.api.common.operators.base
 
CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator<IN> - Class in org.apache.flink.api.common.operators.base
 
collect(T) - Method in class org.apache.flink.api.common.functions.util.CopyingListCollector
 
collect(T) - Method in class org.apache.flink.api.common.functions.util.ListCollector
 
collect(T) - Method in interface org.apache.flink.api.connector.source.ReaderOutput
Emit a record without a timestamp.
collect(T, long) - Method in interface org.apache.flink.api.connector.source.ReaderOutput
Emit a record with a timestamp.
collect(T) - Method in interface org.apache.flink.api.connector.source.SourceOutput
Emit a record without a timestamp.
collect(T, long) - Method in interface org.apache.flink.api.connector.source.SourceOutput
Emit a record with a timestamp.
collect(T) - Method in interface org.apache.flink.util.Collector
Emits a record.
collection - Variable in class org.apache.flink.api.common.operators.util.FieldSet
 
CollectionExecutor - Class in org.apache.flink.api.common.operators
Execution utility for serial, local, collection-based executions of Flink programs.
CollectionExecutor(ExecutionConfig) - Constructor for class org.apache.flink.api.common.operators.CollectionExecutor
 
CollectionSerializerConfigSnapshot<C extends Collection<T>,T> - Class in org.apache.flink.api.common.typeutils.base
Deprecated.
this snapshot class should no longer be used by any serializers as their snapshot.
CollectionSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
CollectionSerializerConfigSnapshot(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
Deprecated.
 
CollectionUtil - Class in org.apache.flink.util
Simple utility to work with Java collections.
Collector<T> - Interface in org.apache.flink.util
Collects a record and forwards it.
combine(Iterable<IN>) - Method in interface org.apache.flink.api.common.functions.CombineFunction
The combine method, called (potentially multiple timed) with subgroups of elements.
combine(Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.api.common.functions.GroupCombineFunction
The combine method, called (potentially multiple timed) with subgroups of elements.
combine(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichGroupCombineFunction
 
combine(List<CommT>) - Method in interface org.apache.flink.api.connector.sink.GlobalCommitter
Compute an aggregated committable from a list of committables.
combineAll(Collection<? extends CompletableFuture<? extends T>>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Creates a future that is complete once multiple other futures completed.
CombineFunction<IN,OUT> - Interface in org.apache.flink.api.common.functions
Generic interface used for combine functions ("combiners").
commentCount - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
commentPrefix - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
commit(List<CommT>) - Method in interface org.apache.flink.api.connector.sink.Committer
Commit the given list of CommT.
commit(List<GlobalCommT>) - Method in interface org.apache.flink.api.connector.sink.GlobalCommitter
Commit the given list of GlobalCommT.
commit() - Method in interface org.apache.flink.core.fs.RecoverableFsDataOutputStream.Committer
Commits the file, making it visible.
commitAfterRecovery() - Method in interface org.apache.flink.core.fs.RecoverableFsDataOutputStream.Committer
Commits the file, making it visible.
Committer<CommT> - Interface in org.apache.flink.api.connector.sink
The Committer is responsible for committing the data staged by the sink.
CommonRangeBoundaries<T> - Class in org.apache.flink.api.common.distributions
 
CommonRangeBoundaries(TypeComparator<T>, Object[][]) - Constructor for class org.apache.flink.api.common.distributions.CommonRangeBoundaries
 
comparator - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
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(boolean[], boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
compare(byte[], byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
compare(char[], char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
compare(double[], double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
compare(float[], float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
compare(int[], int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
compare(long[], long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
compare(short[], short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
compare(T, T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
compare(BooleanValue, BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
compare(ByteValue, ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
compare(CharValue, CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
compare(DoubleValue, DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
compare(FloatValue, FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
compare(IntValue, IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
compare(LocalDate, LocalDate) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
compare(LocalDateTime, LocalDateTime) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
compare(LongValue, LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
compare(NullValue, NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
compare(ShortValue, ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
compare(StringValue, StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
compare(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Compares two records in object form.
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.NullAwareComparator
 
compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compare(Row, Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
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(MemorySegment, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Compares two memory segment regions.
compare(MemorySegment, int, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Compares two memory segment regions with different length.
compareAccumulatorTypes(Object, Class<? extends Accumulator>, Class<? extends Accumulator>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
Compare both classes and throw UnsupportedOperationException if they differ.
compareAgainstReference(Comparable[]) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
 
compareRows(List<Row>, List<Row>) - Static method in class org.apache.flink.types.RowUtils
Compares two Lists of Row for deep equality.
compareRows(List<Row>, List<Row>, boolean) - Static method in class org.apache.flink.types.RowUtils
Compares two Lists of Row for deep equality.
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.InstantComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Compares two records in serialized form.
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.NullAwareComparator
 
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.RowComparator
 
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
 
compareSerializedDate(DataInputView, DataInputView, boolean) - Static method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
compareSerializedLocalDate(DataInputView, DataInputView, boolean) - Static method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
compareSerializedLocalTime(DataInputView, DataInputView, boolean) - Static method in class org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
compareTo(Resource) - Method in class org.apache.flink.api.common.resources.Resource
 
compareTo(MemorySize) - Method in class org.apache.flink.configuration.MemorySize
 
compareTo(BlockLocation) - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
 
compareTo(Object) - Method in class org.apache.flink.core.fs.Path
 
compareTo(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
 
compareTo(ByteValue) - Method in class org.apache.flink.types.ByteValue
 
compareTo(CharValue) - Method in class org.apache.flink.types.CharValue
 
compareTo(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
 
compareTo(FloatValue) - Method in class org.apache.flink.types.FloatValue
 
compareTo(IntValue) - Method in class org.apache.flink.types.IntValue
 
compareTo(LongValue) - Method in class org.apache.flink.types.LongValue
 
compareTo(NullValue) - Method in class org.apache.flink.types.NullValue
 
compareTo(ShortValue) - Method in class org.apache.flink.types.ShortValue
 
compareTo(StringValue) - Method in class org.apache.flink.types.StringValue
 
compareTo(AbstractID) - Method in class org.apache.flink.util.AbstractID
 
compareTo(Delayed) - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
compareToReference(TypeComparator<BooleanValue>) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
compareToReference(TypeComparator<ByteValue>) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
compareToReference(TypeComparator<CharValue>) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
compareToReference(TypeComparator<DoubleValue>) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
compareToReference(TypeComparator<FloatValue>) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
compareToReference(TypeComparator<IntValue>) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
compareToReference(TypeComparator<LocalDate>) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
compareToReference(TypeComparator<LocalDateTime>) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
compareToReference(TypeComparator<LongValue>) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
compareToReference(TypeComparator<NullValue>) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
compareToReference(TypeComparator<ShortValue>) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
compareToReference(TypeComparator<StringValue>) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
 
compareToReference(T) - Method in class org.apache.flink.api.common.typeutils.SameTypePairComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
This method compares the element that has been set as reference in this type accessor, to the element set as reference in the given type accessor.
compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
 
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.NullAwareComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compareToReference(TypeComparator<Row>) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
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
 
compatibleAfterMigration() - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns a result that indicates that the new serializer can be used after migrating the written bytes, i.e.
compatibleAsIs() - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns a result that indicates that the new serializer is compatible and no migration is required.
compatibleWithReconfiguredSerializer(TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns a result that indicates a reconfigured version of the new serializer is compatible, and should be used instead of the original new serializer.
CompilerHints - Class in org.apache.flink.api.common.operators
A class encapsulating compiler hints describing the behavior of the user function.
CompilerHints() - Constructor for class org.apache.flink.api.common.operators.CompilerHints
 
compilerHints - Variable in class org.apache.flink.api.common.operators.Operator
 
complementBlockInfo(BlockInfo) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
completeAll(Collection<? extends CompletableFuture<?>>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Creates a FutureUtils.ConjunctFuture which is only completed after all given futures have completed.
completeDelayed(CompletableFuture<T>, T, Duration) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Asynchronously completes the future after a certain delay.
completedExceptionally(Throwable) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Returns an exceptionally completed CompletableFuture.
completedVoidFuture() - Static method in class org.apache.flink.util.concurrent.FutureUtils
Returns a completed future of type Void.
completeFromCallable(CompletableFuture<T>, Callable<T>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Fakes asynchronous execution by immediately executing the operation and completing the supplied future either normally or exceptionally.
ComponentClassLoader - Class in org.apache.flink.core.classloading
A URLClassLoader that restricts which classes can be loaded to those contained within the given classpath, except classes from a given set of packages that are either loaded owner or component-first.
ComponentClassLoader(URL[], ClassLoader, String[], String[]) - Constructor for class org.apache.flink.core.classloading.ComponentClassLoader
 
composeAfterwards(CompletableFuture<?>, Supplier<CompletableFuture<?>>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Run the given asynchronous action after the completion of the given future.
CompositeSerializer<T> - Class in org.apache.flink.api.common.typeutils
Base class for composite serializers.
CompositeSerializer(boolean, TypeSerializer<?>...) - Constructor for class org.apache.flink.api.common.typeutils.CompositeSerializer
Can be used for user facing constructor.
CompositeSerializer(CompositeSerializer.PrecomputedParameters, TypeSerializer<?>...) - Constructor for class org.apache.flink.api.common.typeutils.CompositeSerializer
Can be used in createSerializerInstance for internal operations.
CompositeSerializer.ConfigSnapshot - Class in org.apache.flink.api.common.typeutils
Deprecated.
this snapshot class is no longer in use by any serializers, and is only kept around for backwards compatibility. All subclass serializers should have their own serializer snapshot classes.
CompositeSerializer.PrecomputedParameters - Class in org.apache.flink.api.common.typeutils
This class holds composite serializer parameters which can be precomputed in advanced for better performance.
CompositeType<T> - Class in org.apache.flink.api.common.typeutils
Base type information class for Tuple and Pojo types
CompositeType(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeType
 
CompositeType.FlatFieldDescriptor - Class in org.apache.flink.api.common.typeutils
 
CompositeType.InvalidFieldReferenceException - Exception in org.apache.flink.api.common.typeutils
 
CompositeType.TypeComparatorBuilder<T> - Interface in org.apache.flink.api.common.typeutils
 
CompositeTypeComparator<T> - Class in org.apache.flink.api.common.typeutils
 
CompositeTypeComparator() - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeComparator
 
CompositeTypeSerializerConfigSnapshot<T> - Class in org.apache.flink.api.common.typeutils
A TypeSerializerConfigSnapshot for serializers that has multiple nested serializers.
CompositeTypeSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
CompositeTypeSerializerConfigSnapshot(TypeSerializer<?>...) - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
CompositeTypeSerializerSnapshot<T,S extends TypeSerializer<T>> - Class in org.apache.flink.api.common.typeutils
A CompositeTypeSerializerSnapshot is a convenient serializer snapshot class that can be used by simple serializers which 1) delegates its serialization to multiple nested serializers, and 2) may contain some extra static information that needs to be persisted as part of its snapshot.
CompositeTypeSerializerSnapshot(Class<? extends TypeSerializer>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Constructor to be used for read instantiation.
CompositeTypeSerializerSnapshot(S) - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Constructor to be used for writing the snapshot.
CompositeTypeSerializerSnapshot.OuterSchemaCompatibility - Enum in org.apache.flink.api.common.typeutils
Indicates schema compatibility of the serializer configuration persisted as the outer snapshot.
CompositeTypeSerializerUtil - Class in org.apache.flink.api.common.typeutils
CompositeTypeSerializerUtil() - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil
 
CompositeTypeSerializerUtil.IntermediateCompatibilityResult<T> - Class in org.apache.flink.api.common.typeutils
 
compressDirectory(Path, Path) - Static method in class org.apache.flink.util.FileUtils
 
CompressedSerializedValue<T> - Class in org.apache.flink.util
An extension of SerializedValue that compresses the value after the serialization.
computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys
 
computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
concat(String[], String[]) - Static method in class org.apache.flink.util.ArrayUtils
 
concatenate(Record) - Method in class org.apache.flink.types.Record
 
concatenateWithAnd(String, String) - Static method in class org.apache.flink.util.StringUtils
If both string arguments are non-null, this method concatenates them with ' and '.
CONF_DIR - Static variable in class org.apache.flink.configuration.DeploymentOptionsInternal
 
confData - Variable in class org.apache.flink.configuration.Configuration
Stores the concrete key/value pairs of this configuration object.
ConfigConstants - Class in org.apache.flink.configuration
This class contains all constants for the configuration.
ConfigOption<T> - Class in org.apache.flink.configuration
A ConfigOption describes a configuration parameter.
ConfigOptions - Class in org.apache.flink.configuration
ConfigOptions are used to build a ConfigOption.
ConfigOptions.ListConfigOptionBuilder<E> - Class in org.apache.flink.configuration
Builder for ConfigOption of list of type E.
ConfigOptions.OptionBuilder - Class in org.apache.flink.configuration
The option builder is used to create a ConfigOption.
ConfigOptions.TypedConfigOptionBuilder<T> - Class in org.apache.flink.configuration
Builder for ConfigOption with a defined atomic type.
ConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.CompositeSerializer.ConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
Configuration - Class in org.apache.flink.configuration
Lightweight configuration object which stores key/value pairs.
Configuration() - Constructor for class org.apache.flink.configuration.Configuration
Creates a new empty configuration.
Configuration(Configuration) - Constructor for class org.apache.flink.configuration.Configuration
Creates a new configuration with the copy of the given configuration.
ConfigurationException - Exception in org.apache.flink.util
Exception which occurs when creating a configuration object fails.
ConfigurationException(String) - Constructor for exception org.apache.flink.util.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.util.ConfigurationException
 
ConfigurationException(Throwable) - Constructor for exception org.apache.flink.util.ConfigurationException
 
ConfigurationUtils - Class in org.apache.flink.configuration
Utility class for Configuration related helper functions.
configure(ReadableConfig, ClassLoader) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets all relevant options contained in the ReadableConfig such as e.g.
configure(Configuration) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Configures this input format by reading the path to the file from the configuration and the string that defines the record delimiter.
configure(Configuration) - Method in class org.apache.flink.api.common.io.FileInputFormat
Configures the file input format by reading the file path from the configuration.
configure(Configuration) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
configure(Configuration) - Method in interface org.apache.flink.api.common.io.InputFormat
Configures this input format.
configure(Configuration) - Method in interface org.apache.flink.api.common.io.OutputFormat
Configures this output format.
configure(Configuration) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
configure(Configuration) - Method in class org.apache.flink.core.fs.ConnectionLimitingFactory
 
configure(Configuration) - Method in class org.apache.flink.core.fs.PluginFileSystemFactory
 
configure(Configuration) - Method in interface org.apache.flink.core.plugin.Plugin
Optional method for plugins to pick up settings from the configuration.
ConfigUtils - Class in org.apache.flink.configuration
General utilities for parsing values to configuration options.
ConjunctFuture() - Constructor for class org.apache.flink.util.concurrent.FutureUtils.ConjunctFuture
 
CONNECT_BACKLOG - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
CONNECT_TIMEOUT - Static variable in class org.apache.flink.configuration.BlobServerOptions
The connection timeout in milliseconds for the blob client.
CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.RestOptions
The maximum time in ms for the client to establish a TCP connection.
ConnectionLimitingFactory - Class in org.apache.flink.core.fs
A wrapping factory that adds a LimitedConnectionsFileSystem to a file system.
ConnectionLimitingSettings(int, int, int, long, long) - Constructor for class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
Creates a new ConnectionLimitingSettings with the given parameters.
constructIntermediateCompatibilityResult(TypeSerializer<?>[], TypeSerializerSnapshot<?>[]) - Static method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil
Constructs an CompositeTypeSerializerUtil.IntermediateCompatibilityResult with the given array of nested serializers and their corresponding serializer snapshots.
CONTAINERIZED_HEAP_CUTOFF_MIN - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
CONTAINERIZED_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
CONTAINERIZED_MASTER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
CONTAINERIZED_MASTER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
Prefix for passing custom environment variables to Flink's master process.
CONTAINERIZED_TASK_MANAGER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
CONTAINERIZED_TASK_MANAGER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
Similar to the CONTAINERIZED_MASTER_ENV_PREFIX, this configuration prefix allows setting custom environment variables for the workers (TaskManagers).
containingIteration - Variable in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
contains(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
contains(UK) - Method in interface org.apache.flink.api.common.state.MapState
Returns whether there exists the given mapping.
contains(K) - Method in interface org.apache.flink.api.common.state.ReadOnlyBroadcastState
Returns whether there exists the given mapping.
contains(ConfigOption<?>) - Method in class org.apache.flink.configuration.Configuration
Checks whether there is an entry for the given config option.
contains(ConfigOption<?>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
contains(Object) - Method in class org.apache.flink.types.ListValue
 
containsAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
 
containsKey(String) - Method in class org.apache.flink.configuration.Configuration
Checks whether there is an entry with the specified key.
containsKey(String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
containsKey(Object) - Method in class org.apache.flink.types.MapValue
 
containsValue(Object) - Method in class org.apache.flink.types.MapValue
 
ConvergenceCriterion<T extends Value> - Interface in org.apache.flink.api.common.aggregators
Used to check for convergence.
convertBoxedJavaType(Object) - Static method in class org.apache.flink.types.JavaToValueConverter
 
convertValue(Object, Class<?>) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Tries to convert the raw value into the provided type.
convertValueType(Value) - Static method in class org.apache.flink.types.JavaToValueConverter
 
copy(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
 
copy(boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
copy(boolean[], boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
copy(byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
copy(byte[], byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
copy(char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
copy(char[], char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
copy(double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
copy(double[], double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
copy(float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
copy(float[], float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
copy(int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
copy(int[], int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
copy(long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
copy(long[], long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
copy(short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
copy(short[], short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
copy(String[]) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
copy(String[], String[]) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
copy(BigDecimal) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
copy(BigDecimal, BigDecimal) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
copy(BigInteger) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copy(BigInteger, BigInteger) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copy(Boolean) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
copy(Boolean, Boolean) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
copy(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
copy(BooleanValue, BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
copy(Byte) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
copy(Byte, Byte) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
copy(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
copy(ByteValue, ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
copy(Character) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
copy(Character, Character) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
copy(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
copy(CharValue, CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
copy(Date) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
copy(Date, Date) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
copy(Double) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
copy(Double, Double) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
copy(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
copy(DoubleValue, DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
copy(T) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
copy(T, T) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
copy(Float) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
copy(Float, Float) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
copy(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
copy(FloatValue, FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
copy(C[]) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
copy(C[], C[]) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
copy(Instant) - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
copy(Instant, Instant) - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
copy(Integer) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
copy(Integer, Integer) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
copy(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
copy(IntValue, IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
copy(List<T>) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
copy(List<T>, List<T>) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
copy(LocalDate) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
copy(LocalDate, LocalDate) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
copy(LocalDateTime) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
copy(LocalDateTime, LocalDateTime) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
copy(LocalTime) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
copy(LocalTime, LocalTime) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
copy(Long) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
copy(Long, Long) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
copy(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
copy(LongValue, LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
copy(Map<K, V>) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
copy(Map<K, V>, Map<K, V>) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
copy(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
copy(NullValue, NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
copy(Short) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
copy(Short, Short) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
copy(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
copy(ShortValue, ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
copy(Date) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
copy(Date, Date) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
copy(Time) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
copy(Time, Time) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
copy(Timestamp) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
copy(Timestamp, Timestamp) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
copy(String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
copy(String, String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
copy(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
copy(StringValue, StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
copy(Void) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
copy(Void, Void) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
copy(T) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
copy(T, T) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
copy(T) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
copy(T, T) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
copy(T) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Creates a deep copy of the given element in a new element.
copy(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Creates a copy from the given element.
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Copies exactly one record from the source input view to the target output view.
copy(T) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
copy(T, T) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
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.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(Either<L, R>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
copy(Either<L, R>, Either<L, R>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
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, Kryo, TypeSerializer<T>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
Tries to copy the given record from using the provided Kryo instance.
copy(T, T, Kryo, TypeSerializer<T>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
Tries to copy the given record from using the provided Kryo instance.
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
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(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
copy(Row, Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
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.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
copy(T, T) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
copy() - Method in class org.apache.flink.types.BooleanValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.BooleanValue
 
copy() - Method in class org.apache.flink.types.ByteValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ByteValue
 
copy() - Method in class org.apache.flink.types.CharValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.CharValue
 
copy() - Method in interface org.apache.flink.types.CopyableValue
Performs a deep copy of this object into a new instance.
copy(DataInputView, DataOutputView) - Method in interface org.apache.flink.types.CopyableValue
Copies the next serialized instance from source to target.
copy() - Method in class org.apache.flink.types.DoubleValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.DoubleValue
 
copy() - Method in class org.apache.flink.types.FloatValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.FloatValue
 
copy() - Method in class org.apache.flink.types.IntValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.IntValue
 
copy() - Method in class org.apache.flink.types.LongValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.LongValue
 
copy() - Method in class org.apache.flink.types.NullValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.NullValue
 
copy() - Method in class org.apache.flink.types.Record
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.Record
 
copy(Row) - Static method in class org.apache.flink.types.Row
Creates a new row which is copied from another row (including its RowKind).
copy() - Method in class org.apache.flink.types.ShortValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ShortValue
 
copy() - Method in class org.apache.flink.types.StringValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.StringValue
 
copy(Path, Path, boolean) - Static method in class org.apache.flink.util.FileUtils
Copies all files from source to target and sets executable flag.
CopyableValue<T> - Interface in org.apache.flink.types
Interface to be implemented by basic types that support to be copied efficiently.
CopyableValueComparator<T extends CopyableValue<T> & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
Comparator for all Value types that extend Key
CopyableValueComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
CopyableValueSerializer<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
 
CopyableValueSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
CopyableValueSerializer.CopyableValueSerializerConfigSnapshot<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
Deprecated.
CopyableValueSerializer.CopyableValueSerializerSnapshot<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
TypeSerializerSnapshot for the CopyableValueSerializer.
CopyableValueSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
CopyableValueSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
Deprecated.
 
CopyableValueSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerSnapshot
Used for reflective instantiation.
copyBigInteger(DataInputView, DataOutputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.flink.util.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream) - Static method in class org.apache.flink.util.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream, boolean) - Static method in class org.apache.flink.util.IOUtils
Copies from one stream to another.
copyFrom(CompilerHints) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
copyFrom(Record, int[], int[]) - Method in class org.apache.flink.types.Record
Bin-copies fields from a source record to this record.
copyFromUnsafe(int, Object, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk copy method.
CopyingIterator<E> - Class in org.apache.flink.api.common.functions.util
Wraps an iterator to return deep copies of the original iterator's elements.
CopyingIterator(Iterator<E>, TypeSerializer<E>) - Constructor for class org.apache.flink.api.common.functions.util.CopyingIterator
 
CopyingListCollector<T> - Class in org.apache.flink.api.common.functions.util
A Collector that collects deep copies of its elements in a list.
CopyingListCollector(List<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.functions.util.CopyingListCollector
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.BooleanValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.ByteValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.CharValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.IntValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.LongValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in interface org.apache.flink.types.NormalizableKey
Writes a normalized key for the given record into the target byte array, starting at the specified position an writing exactly the given number of bytes.
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.NullValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.ShortValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.StringValue
 
copyString(DataInput, DataOutput) - Static method in class org.apache.flink.types.StringValue
 
copyTo(int, MemorySegment, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk copy method.
copyTo(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
 
copyTo(ByteValue) - Method in class org.apache.flink.types.ByteValue
 
copyTo(CharValue) - Method in class org.apache.flink.types.CharValue
 
copyTo(T) - Method in interface org.apache.flink.types.CopyableValue
Performs a deep copy of this object into the target instance.
copyTo(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
 
copyTo(FloatValue) - Method in class org.apache.flink.types.FloatValue
 
copyTo(IntValue) - Method in class org.apache.flink.types.IntValue
 
copyTo(LongValue) - Method in class org.apache.flink.types.LongValue
 
copyTo(NullValue) - Method in class org.apache.flink.types.NullValue
 
copyTo(Record) - Method in class org.apache.flink.types.Record
 
copyTo(ShortValue) - Method in class org.apache.flink.types.ShortValue
 
copyTo(StringValue) - Method in class org.apache.flink.types.StringValue
 
copyToUnsafe(int, Object, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk copy method.
CoreOptions - Class in org.apache.flink.configuration
The set of configuration options for core parameters.
CoreOptions() - Constructor for class org.apache.flink.configuration.CoreOptions
 
count - Variable in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
CPU_CORES - Static variable in class org.apache.flink.configuration.TaskManagerOptions
This config option describes number of cpu cores of task executors.
CPUResource - Class in org.apache.flink.api.common.resources
Represents CPU resource.
CPUResource(double) - Constructor for class org.apache.flink.api.common.resources.CPUResource
 
create(InputStream) - Method in class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 
create(InputStream) - Method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
create(InputStream) - Method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 
create(InputStream) - Method in interface org.apache.flink.api.common.io.compression.InflaterInputStreamFactory
Creates a InflaterInputStream that wraps the given input stream.
create(InputStream) - Method in class org.apache.flink.api.common.io.compression.XZInputStreamFactory
 
create(InputStream) - Method in class org.apache.flink.api.common.io.compression.ZStandardInputStreamFactory
 
create(BigDecimal) - Method in class org.apache.flink.api.common.resources.CPUResource
 
create(BigDecimal) - Method in class org.apache.flink.api.common.resources.ExternalResource
 
create(BigDecimal) - Method in class org.apache.flink.api.common.resources.Resource
Create a new instance of the sub resource.
create(FSDataOutputStream) - Method in interface org.apache.flink.api.common.serialization.BulkWriter.Factory
Creates a writer that writes to the given stream.
create(Kryo, Input, Class<Collection>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
create(URI) - Method in class org.apache.flink.core.fs.ConnectionLimitingFactory
 
create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.FileSystem
Deprecated.
Deprecated because not well supported across types of file systems. Control the behavior of specific file systems via configurations instead.
create(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
Deprecated.
create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.FileSystem
Opens an FSDataOutputStream to a new file at the given path.
create(URI) - Method in interface org.apache.flink.core.fs.FileSystemFactory
Creates a new file system for the given file system URI.
create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Deprecated.
create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
create(URI) - Method in class org.apache.flink.core.fs.local.LocalFileSystemFactory
 
create(URI) - Method in class org.apache.flink.core.fs.PluginFileSystemFactory
 
create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
create(PluginDescriptor, ClassLoader, String[]) - Static method in class org.apache.flink.core.plugin.PluginLoader
 
create(ClassLoader) - Static method in class org.apache.flink.util.SimpleUserCodeClassLoader
 
createAccumulator() - Method in interface org.apache.flink.api.common.functions.AggregateFunction
Creates a new accumulator, starting a new aggregate.
createAccumulator() - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
 
createAvroSerializer(Class<T>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
Creates an AvroSerializer if flink-avro is present, otherwise throws an exception.
createAvroTypeInfo(Class<T>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
Creates an AvroTypeInfo if flink-avro is present, otherwise throws an exception.
createBlockInfo() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
createBlockInfo() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
createCommitter() - Method in interface org.apache.flink.api.connector.sink.Sink
Creates a Committer which is part of a 2-phase-commit protocol.
createComparator(boolean, ExecutionConfig) - Method in interface org.apache.flink.api.common.typeinfo.AtomicType
Creates a comparator for this type.
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Generic implementation of the comparator creation.
createComparator() - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
 
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(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
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
 
createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
 
createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
 
createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
createConfiguration(Properties) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Creates a new Configuration from the given Properties.
createCopy(Kryo, Collection) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
createCopy() - Method in class org.apache.flink.types.Record
Creates an exact copy of this record.
createCopyWritable(T) - Static method in class org.apache.flink.util.InstantiationUtil
Clones the given writable using the serialization.
createDefaultFilter() - Static method in class org.apache.flink.api.common.io.FilePathFilter
Returns the default filter, which excludes the following files: Files starting with "_" Files starting with "." Files containing the string "_COPYING_"
createEntropyAware(FileSystem, Path, FileSystem.WriteMode) - Static method in class org.apache.flink.core.fs.EntropyInjector
Handles entropy injection across regular and entropy-aware file systems.
createEnumerator(SplitEnumeratorContext<NumberSequenceSource.NumberSequenceSplit>) - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
createEnumerator(SplitEnumeratorContext<SplitT>) - Method in interface org.apache.flink.api.connector.source.Source
Creates a new SplitEnumerator for this source, starting a new input.
createExternalResourceDriver(Configuration) - Method in interface org.apache.flink.api.common.externalresource.ExternalResourceDriverFactory
Construct the ExternalResourceDriver from configuration.
createFrom(CheckedSupplier<T>) - Static method in class org.apache.flink.util.OptionalFailure
 
createGlobalCommitter() - Method in interface org.apache.flink.api.connector.sink.Sink
Creates a GlobalCommitter which is part of a 2-phase-commit protocol.
createHadoopWritableTypeInfo(Class<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
createInputSplits(int) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
createInputSplits(int) - Method in class org.apache.flink.api.common.io.FileInputFormat
Computes the input splits for the file.
createInputSplits(int) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
createInputSplits(int) - Method in interface org.apache.flink.api.common.io.InputFormat
 
createInputSplits(int) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
createInputSplits(int) - Method in interface org.apache.flink.core.io.InputSplitSource
Computes the input splits.
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
createInstance(Object...) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
Create new instance from its fields.
createInstance() - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Creates a new instance of the data type.
createInstance() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
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.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
createLegacySerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
Deprecated.
createNewOrderingUpToIndex(int) - Method in class org.apache.flink.api.common.operators.Ordering
Creates a new ordering the represents an ordering on a prefix of the fields.
createOrReuseInstance(Object[], T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createOrReuseInstance(Object[], T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Creates an instance of the outer serializer with a given array of its nested serializers.
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
createOutputForSplit(String) - Method in interface org.apache.flink.api.connector.source.ReaderOutput
Creates a SourceOutput for a specific Source Split.
createPluginClassLoader(PluginDescriptor, ClassLoader, String[]) - Static method in class org.apache.flink.core.plugin.PluginLoader
 
createPluginManagerFromRootFolder(Configuration) - Static method in class org.apache.flink.core.plugin.PluginUtils
 
createPojoSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
createProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
 
createReader(SourceReaderContext) - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
createReader(SourceReaderContext) - Method in interface org.apache.flink.api.connector.source.Source
Creates a new reader to read data from the splits it gets assigned.
createRecoverableWriter() - Method in class org.apache.flink.core.fs.FileSystem
Creates a new RecoverableWriter.
createRecoverableWriter() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
createRecoverableWriter() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
createRowWithNamedPositions(RowKind, Object[], LinkedHashMap<String, Integer>) - Static method in class org.apache.flink.types.RowUtils
Internal utility for creating a row in static named-position field mode.
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Creates a serializer for the type.
createSerializer(Class<T>) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
Create a serializer that is able to serialize the generic type typeClass.
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
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.ListTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
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.RowTypeInfo
 
createSerializer(Class<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerSnapshot
 
createSerializer(Class<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerSnapshot
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
createSerializerInstance(CompositeSerializer.PrecomputedParameters, TypeSerializer<?>...) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
Factory for concrete serializer.
createSocket(int) - Method in interface org.apache.flink.util.NetUtils.SocketFactory
 
createSocketFromPorts(Iterator<Integer>, NetUtils.SocketFactory) - Static method in class org.apache.flink.util.NetUtils
Tries to allocate a socket from the given sets of ports.
createStatistics(List<FileStatus>, FileInputFormat.FileBaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
Fill in the statistics.
createTimestampAssigner(TimestampAssignerSupplier.Context) - Method in interface org.apache.flink.api.common.eventtime.TimestampAssignerSupplier
Instantiates a TimestampAssigner.
createTimestampAssigner(TimestampAssignerSupplier.Context) - Method in class org.apache.flink.api.common.eventtime.TimestampAssignerSupplier.SupplierFromSerializableTimestampAssigner
 
createTimestampAssigner(TimestampAssignerSupplier.Context) - Method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
Instantiates a TimestampAssigner for assigning timestamps according to this strategy.
createTypeComparator(ExecutionConfig) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.api.common.typeinfo.TypeInfoFactory
Creates type information for the type the factory is targeted for.
createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfoFactory
 
createTypeInfo(Class<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
createTypeInfo(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
createTypeInfo(Object, Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Creates a TypeInformation from the given parameters.
createTypeInfo(Class<?>, Class<?>, int, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
createUnionCascade(List<? extends Operator<T>>) - Static method in class org.apache.flink.api.common.operators.Operator
Takes a list of operators and creates a cascade of unions of this inputs, if needed.
createUnionCascade(Operator<T>...) - Static method in class org.apache.flink.api.common.operators.Operator
Takes a list of operators and creates a cascade of unions of this inputs, if needed.
createUnionCascade(Operator<T>, Operator<T>...) - Static method in class org.apache.flink.api.common.operators.Operator
Takes a single Operator and a list of operators and creates a cascade of unions of this inputs, if needed.
createValue() - Method in class org.apache.flink.types.parser.BigDecParser
 
createValue() - Method in class org.apache.flink.types.parser.BigIntParser
 
createValue() - Method in class org.apache.flink.types.parser.BooleanParser
 
createValue() - Method in class org.apache.flink.types.parser.BooleanValueParser
 
createValue() - Method in class org.apache.flink.types.parser.ByteParser
 
createValue() - Method in class org.apache.flink.types.parser.ByteValueParser
 
createValue() - Method in class org.apache.flink.types.parser.DoubleParser
 
createValue() - Method in class org.apache.flink.types.parser.DoubleValueParser
 
createValue() - Method in class org.apache.flink.types.parser.FieldParser
Returns an instance of the parsed value type.
createValue() - Method in class org.apache.flink.types.parser.FloatParser
 
createValue() - Method in class org.apache.flink.types.parser.FloatValueParser
 
createValue() - Method in class org.apache.flink.types.parser.IntParser
 
createValue() - Method in class org.apache.flink.types.parser.IntValueParser
 
createValue() - Method in class org.apache.flink.types.parser.LongParser
 
createValue() - Method in class org.apache.flink.types.parser.LongValueParser
 
createValue() - Method in class org.apache.flink.types.parser.ShortParser
 
createValue() - Method in class org.apache.flink.types.parser.ShortValueParser
 
createValue() - Method in class org.apache.flink.types.parser.SqlDateParser
 
createValue() - Method in class org.apache.flink.types.parser.SqlTimeParser
 
createValue() - Method in class org.apache.flink.types.parser.SqlTimestampParser
 
createValue() - Method in class org.apache.flink.types.parser.StringParser
 
createValue() - Method in class org.apache.flink.types.parser.StringValueParser
 
createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - Method in interface org.apache.flink.api.common.eventtime.WatermarkGeneratorSupplier
Instantiates a WatermarkGenerator.
createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - Method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
Instantiates a WatermarkGenerator that generates watermarks according to this strategy.
createWriter(Sink.InitContext, List<WriterStateT>) - Method in interface org.apache.flink.api.connector.sink.Sink
Create a SinkWriter.
cross(IN1, IN2) - Method in interface org.apache.flink.api.common.functions.CrossFunction
Cross UDF method.
cross(IN1, IN2) - Method in class org.apache.flink.api.common.functions.RichCrossFunction
 
CrossFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
Interface for Cross functions.
CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
CrossOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
CrossOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
CrossOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
CrossOperatorBase.CrossHint - Enum in org.apache.flink.api.common.operators.base
The cross hint tells the system which sizes to expect from the data sets
CrossOperatorBase.CrossWithLarge - Interface in org.apache.flink.api.common.operators.base
Marker interface to declare the second input as the larger one.
CrossOperatorBase.CrossWithSmall - Interface in org.apache.flink.api.common.operators.base
Marker interface to declare the second input as the smaller one.
CUR_DIR - Static variable in class org.apache.flink.core.fs.Path
Character denoting the current directory.
currBuffer - Variable in class org.apache.flink.api.common.io.DelimitedInputFormat
 
currentParallelism() - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
Get the current parallelism of this Source.
currentSplit - Variable in class org.apache.flink.api.common.io.FileInputFormat
The current split that this parallel instance must consume.
currentWatermark() - Method in interface org.apache.flink.api.connector.sink.SinkWriter.Context
Returns the current event-time watermark.
currLen - Variable in class org.apache.flink.api.common.io.DelimitedInputFormat
 
currOffset - Variable in class org.apache.flink.api.common.io.DelimitedInputFormat
 

D

DATA_BIND_PORT - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
The local network port that the task manager listen at for data exchange.
DATA_PORT - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
The default network port the task manager expects to receive transfer envelopes on.
DATA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Config parameter to override SSL support for taskmanager's data transport.
DataDistribution - Interface in org.apache.flink.api.common.distributions
 
DataInputDeserializer - Class in org.apache.flink.core.memory
A simple and efficient deserializer for the DataInput interface.
DataInputDeserializer() - Constructor for class org.apache.flink.core.memory.DataInputDeserializer
 
DataInputDeserializer(byte[]) - Constructor for class org.apache.flink.core.memory.DataInputDeserializer
 
DataInputDeserializer(byte[], int, int) - Constructor for class org.apache.flink.core.memory.DataInputDeserializer
 
DataInputDeserializer(ByteBuffer) - Constructor for class org.apache.flink.core.memory.DataInputDeserializer
 
DataInputView - Interface in org.apache.flink.core.memory
This interface defines a view over some memory that can be used to sequentially read the contents of the memory.
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
 
DataInputViewStreamWrapper - Class in org.apache.flink.core.memory
Utility class that turns an InputStream into a DataInputView.
DataInputViewStreamWrapper(InputStream) - Constructor for class org.apache.flink.core.memory.DataInputViewStreamWrapper
 
DataOutputSerializer - Class in org.apache.flink.core.memory
A simple and efficient serializer for the DataOutput interface.
DataOutputSerializer(int) - Constructor for class org.apache.flink.core.memory.DataOutputSerializer
 
DataOutputView - Interface in org.apache.flink.core.memory
This interface defines a view over some memory that can be used to sequentially write contents to the memory.
DataOutputViewStream - Class in org.apache.flink.api.java.typeutils.runtime
 
DataOutputViewStream(DataOutputView) - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
DataOutputViewStreamWrapper - Class in org.apache.flink.core.memory
Utility class that turns an OutputStream into a DataOutputView.
DataOutputViewStreamWrapper(OutputStream) - Constructor for class org.apache.flink.core.memory.DataOutputViewStreamWrapper
 
DATE - Static variable in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
DATE_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
DateComparator - Class in org.apache.flink.api.common.typeutils.base
 
DateComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.DateComparator
 
dateComparator - Variable in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
DateSerializer - Class in org.apache.flink.api.common.typeutils.base
 
DateSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.DateSerializer
 
DateSerializer.DateSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
DateSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.DateSerializer.DateSerializerSnapshot
 
days(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of days.
Deadline - Class in org.apache.flink.api.common.time
This class stores a deadline, as obtained via Deadline.now() or from Deadline.plus(Duration).
DEBUG_MEMORY_LOG - Static variable in class org.apache.flink.configuration.TaskManagerOptions
 
DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - Static variable in class org.apache.flink.configuration.TaskManagerOptions
 
declareManagedMemoryUseCaseAtOperatorScope(ManagedMemoryUseCase, int) - Method in class org.apache.flink.api.dag.Transformation
Declares that this transformation contains certain operator scope managed memory use case.
declareManagedMemoryUseCaseAtSlotScope(ManagedMemoryUseCase) - Method in class org.apache.flink.api.dag.Transformation
Declares that this transformation contains certain slot scope managed memory use case.
decodeListFromConfig(ReadableConfig, ConfigOption<List<IN>>, FunctionWithException<IN, OUT, E>) - Static method in class org.apache.flink.configuration.ConfigUtils
Gets a List of values of type IN from a ReadableConfig and transforms it to a List of type OUT based on the provided mapper function.
decompressAndDeserializeObject(byte[], ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
 
decorateIfLimited(FileSystemFactory, String, Configuration) - Static method in class org.apache.flink.core.fs.ConnectionLimitingFactory
Decorates the given factory for a ConnectionLimitingFactory, if the given configuration configured connection limiting for the given file system scheme.
decorateInputStream(FSDataInputStream, FileInputSplit) - Method in class org.apache.flink.api.common.io.FileInputFormat
This method allows to wrap/decorate the raw FSDataInputStream for a certain file split, e.g., for decoding.
DEFAULT - Static variable in class org.apache.flink.api.common.operators.ResourceSpec
The default ResourceSpec used for operators and transformation functions.
DEFAULT_AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_AKKA_CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use ClientOptions#CLIENT_TIMEOUT instead.
DEFAULT_AKKA_DISPATCHER_THROUGHPUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_AKKA_FRAMESIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_AKKA_LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_AKKA_LOOKUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_AKKA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_AKKA_TRANSPORT_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use AkkaOptions#TRANSPORT_HEARTBEAT_INTERVAL instead.
DEFAULT_AKKA_TRANSPORT_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use AkkaOptions#TRANSPORT_HEARTBEAT_PAUSE instead.
DEFAULT_AKKA_TRANSPORT_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use AkkaOptions#TRANSPORT_THRESHOLD instead.
DEFAULT_AKKA_WATCH_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
This default value is no longer used and has no effect on Flink.
DEFAULT_BLOB_FETCH_BACKLOG - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_BLOB_FETCH_CONCURRENT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_BLOB_FETCH_RETRIES - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_BLOB_SERVER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_BLOB_SERVICE_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_CHARSET - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_DELIMITED_FORMAT_MAX_LINE_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_DELIMITED_FORMAT_MAX_SAMPLE_LEN - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_DELIMITED_FORMAT_MIN_LINE_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_EXECUTION_RETRIES - Static variable in class org.apache.flink.configuration.ConfigConstants
The default number of execution retries.
DEFAULT_FILESYSTEM_ALWAYS_CREATE_DIRECTORY - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_FILESYSTEM_OVERWRITE - Static variable in class org.apache.flink.configuration.ConfigConstants
The default behavior with respect to overwriting existing files (= not overwrite).
DEFAULT_FILESYSTEM_SCHEME - Static variable in class org.apache.flink.configuration.ConfigConstants
The default filesystem to be used, if no other scheme is specified in the user-provided URI (= local filesystem).
DEFAULT_FILESYSTEM_SCHEME - Static variable in class org.apache.flink.configuration.CoreOptions
The default filesystem scheme, used for paths that do not declare a scheme explicitly.
DEFAULT_FLINK_PLUGINS_DIRS - Static variable in class org.apache.flink.configuration.ConfigConstants
The default Flink plugins directory if none has been specified via ConfigConstants.ENV_FLINK_PLUGINS_DIR.
DEFAULT_FLINK_USR_LIB_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The user lib directory name.
DEFAULT_FS_STREAM_OPENING_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
The default timeout for filesystem stream opening: infinite (means max long milliseconds).
DEFAULT_HA_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
No longer used.
DEFAULT_HA_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of HighAvailabilityOptions.HA_MODE
DEFAULT_HA_ZOOKEEPER_CLIENT_ACL - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_JOB_MANAGER_IPC_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_JOB_MANAGER_WEB_ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_CLEAN_UP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_JOB_MANAGER_WEB_CHECKPOINTS_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Config key has been deprecated. Therefore, no default value required.
DEFAULT_JOB_MANAGER_WEB_CHECKPOINTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_JOB_MANAGER_WEB_FRONTEND_ADDRESS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
use WebOptions.ADDRESS instead
DEFAULT_JOB_MANAGER_WEB_FRONTEND_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
use WebOptions.PORT instead
DEFAULT_JOB_MANAGER_WEB_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_JOB_MANAGER_WEB_SUBMIT_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_LIBRARY_CACHE_MANAGER_CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_LOCAL_NUMBER_JOB_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_LOCAL_NUMBER_RESOURCE_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_LOCAL_NUMBER_TASK_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_MEMORY_MANAGER_MEMORY_FRACTION - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
DEFAULT_MESOS_ARTIFACT_SERVER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
DEFAULT_MESOS_ARTIFACT_SERVER_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
DEFAULT_MESOS_FAILOVER_TIMEOUT_SECS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_NAME - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_ROLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_USER - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
DEFAULT_METRICS_LATENCY_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_PARALLELISM - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_PARALLELISM - Static variable in class org.apache.flink.configuration.CoreOptions
 
DEFAULT_PARALLELISM_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_RECOVERY_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_RECOVERY_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of ConfigConstants.DEFAULT_HA_MODE
DEFAULT_RESOURCE_MANAGER_IPC_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_RUNTIME_HASH_JOIN_BLOOM_FILTERS - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_SECURITY_SSL_ALGORITHMS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_SECURITY_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_SECURITY_SSL_PROTOCOL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_SECURITY_SSL_VERIFY_HOSTNAME - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_SORT_SPILLING_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_SORT_SPILLING_THRESHOLD_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_SPILLING_MAX_FAN - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_SPILLING_MAX_FAN_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_STATE_BACKEND - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_TASK_CANCELLATION_INTERVAL_MILLIS - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_DATA_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_DATA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_DEBUG_MEMORY_USAGE_START_LOG_THREAD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_TASK_MANAGER_INITIAL_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_IPC_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_TASK_MANAGER_MAX_REGISTRATION_DURATION - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_MAX_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_MEMORY_PRE_ALLOCATE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
DEFAULT_TASK_MANAGER_MEMORY_SEGMENT_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TaskManagerOptions.MEMORY_SEGMENT_SIZE provides the default value now
DEFAULT_TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore
DEFAULT_TASK_MANAGER_NETWORK_NUM_BUFFERS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_TASK_MANAGER_REFUSED_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_TMP_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
CoreOptions.TMP_DIRS provides the default value now
DEFAULT_USE_LARGE_RECORD_HANDLER - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_YARN_APPLICATION_MASTER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
DEFAULT_YARN_CONTAINER_START_COMMAND_TEMPLATE - Static variable in class org.apache.flink.configuration.ConfigConstants
Start command template for Flink on YARN containers.
DEFAULT_YARN_HEAP_CUTOFF - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
DEFAULT_YARN_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
DEFAULT_YARN_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of YarnConfigOptions#APPLICATION_MASTER_PORT.
DEFAULT_YARN_MIN_HEAP_CUTOFF - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
DEFAULT_ZOOKEEPER_CHECKPOINT_COUNTER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
no longer used.
DEFAULT_ZOOKEEPER_CHECKPOINTS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
no longer used.
DEFAULT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_CLIENT_PORT.
DEFAULT_ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_INIT_LIMIT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_INIT_LIMIT.
DEFAULT_ZOOKEEPER_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_LATCH_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
no longer used.
DEFAULT_ZOOKEEPER_LEADER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
no longer used.
DEFAULT_ZOOKEEPER_LEADER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_LEADER_PORT.
DEFAULT_ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_MESOS_WORKERS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
DEFAULT_ZOOKEEPER_NAMESPACE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_ZOOKEEPER_PEER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_PEER_PORT.
DEFAULT_ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_SASL_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_ZOOKEEPER_SYNC_LIMIT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of FlinkZookeeperQuorumPeer#DEFAULT_ZOOKEEPER_SYNC_LIMIT.
DefaultExecutorServiceLoader - Class in org.apache.flink.core.execution
The default implementation of the PipelineExecutorServiceLoader.
DefaultExecutorServiceLoader() - Constructor for class org.apache.flink.core.execution.DefaultExecutorServiceLoader
 
DefaultInputSplitAssigner - Class in org.apache.flink.api.common.io
This is the default implementation of the InputSplitAssigner interface.
DefaultInputSplitAssigner(InputSplit[]) - Constructor for class org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
DefaultInputSplitAssigner(Collection<? extends InputSplit>) - Constructor for class org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
defaultParallelism - Variable in class org.apache.flink.api.common.Plan
The default parallelism to use for nodes that have no explicitly specified parallelism.
DefaultPluginManager - Class in org.apache.flink.core.plugin
Default implementation of PluginManager.
DefaultPluginManager(Collection<PluginDescriptor>, String[]) - Constructor for class org.apache.flink.core.plugin.DefaultPluginManager
 
DefaultPluginManager(Collection<PluginDescriptor>, ClassLoader, String[]) - Constructor for class org.apache.flink.core.plugin.DefaultPluginManager
 
defaultValue - Variable in class org.apache.flink.api.common.state.StateDescriptor
The default value returned by the state when no other value is bound to a key.
defaultValue() - Method in class org.apache.flink.configuration.ConfigOption
Returns the default value, or null, if there is no default value.
defaultValue(T) - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Deprecated.
define the type explicitly first with one of the intType(), stringType(), etc.
defaultValue(T) - Method in class org.apache.flink.configuration.ConfigOptions.TypedConfigOptionBuilder
Creates a ConfigOption with the given default value.
defaultValues(E...) - Method in class org.apache.flink.configuration.ConfigOptions.ListConfigOptionBuilder
Creates a ConfigOption with the given default value.
DeflateInflaterInputStreamFactory - Class in org.apache.flink.api.common.io.compression
Factory for input streams that decompress the "deflate" compression format.
DeflateInflaterInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
delegateCompatibilityCheckToNewSnapshot(TypeSerializer<T>, CompositeTypeSerializerSnapshot<T, ? extends TypeSerializer>, TypeSerializerSnapshot<?>...) - Static method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil
Delegates compatibility checks to a CompositeTypeSerializerSnapshot instance.
DelegatingConfiguration - Class in org.apache.flink.configuration
A configuration that manages a subset of keys with a common prefix from a given configuration.
DelegatingConfiguration() - Constructor for class org.apache.flink.configuration.DelegatingConfiguration
Default constructor for serialization.
DelegatingConfiguration(Configuration, String) - Constructor for class org.apache.flink.configuration.DelegatingConfiguration
Creates a new delegating configuration which stores its key/value pairs in the given configuration using the specifies key prefix.
delete(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
Delete a file.
delete(Path, boolean) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
delete(Path, boolean) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
delete(Path, boolean) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
deleteDirectory(File) - Static method in class org.apache.flink.util.FileUtils
Deletes the given directory recursively.
deleteDirectoryQuietly(File) - Static method in class org.apache.flink.util.FileUtils
Deletes the given directory recursively, not reporting any I/O exceptions that occur.
deleteFileOrDirectory(File) - Static method in class org.apache.flink.util.FileUtils
Removes the given file or directory recursively.
deleteFileQuietly(Path) - Static method in class org.apache.flink.util.IOUtils
Deletes the given file.
deletePathIfEmpty(FileSystem, Path) - Static method in class org.apache.flink.util.FileUtils
Deletes the path if it is empty.
DELIMITED_FORMAT_MAX_LINE_SAMPLES - Static variable in class org.apache.flink.configuration.OptimizerOptions
The maximum number of line samples taken by the compiler for delimited inputs.
DELIMITED_FORMAT_MAX_LINE_SAMPLES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
DELIMITED_FORMAT_MAX_SAMPLE_LEN - Static variable in class org.apache.flink.configuration.OptimizerOptions
The maximal length of a line sample that the compiler takes for delimited inputs.
DELIMITED_FORMAT_MAX_SAMPLE_LENGTH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
DELIMITED_FORMAT_MIN_LINE_SAMPLES - Static variable in class org.apache.flink.configuration.OptimizerOptions
The minimum number of line samples taken by the compiler for delimited inputs.
DELIMITED_FORMAT_MIN_LINE_SAMPLES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
DelimitedInputFormat<OT> - Class in org.apache.flink.api.common.io
Base implementation for input formats that split the input at a delimiter into records.
DelimitedInputFormat() - Constructor for class org.apache.flink.api.common.io.DelimitedInputFormat
 
DelimitedInputFormat(Path, Configuration) - Constructor for class org.apache.flink.api.common.io.DelimitedInputFormat
 
delimiterNext(byte[], int, byte[]) - Static method in class org.apache.flink.types.parser.FieldParser
Checks if the delimiter starts at the given start position of the byte array.
DeltaIterationBase<ST,WT> - Class in org.apache.flink.api.common.operators.base
A DeltaIteration is similar to a BulkIterationBase, but maintains state across the individual iteration steps.
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int[]) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int, String) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase.SolutionSetPlaceHolder<ST> - Class in org.apache.flink.api.common.operators.base
Specialized operator to use as a recognizable place-holder for the solution set input to the step function.
DeltaIterationBase.WorksetPlaceHolder<WT> - Class in org.apache.flink.api.common.operators.base
Specialized operator to use as a recognizable place-holder for the working set input to the step function.
DeploymentOptions - Class in org.apache.flink.configuration
The configuration options relevant for all Executors.
DeploymentOptions() - Constructor for class org.apache.flink.configuration.DeploymentOptions
 
DeploymentOptionsInternal - Class in org.apache.flink.configuration
Internal options used during deployment.
DeploymentOptionsInternal() - Constructor for class org.apache.flink.configuration.DeploymentOptionsInternal
 
deprecatedKeys() - Method in class org.apache.flink.configuration.ConfigOption
Deprecated.
depth() - Method in class org.apache.flink.core.fs.Path
Returns the number of elements in this path.
DescribedEnum - Interface in org.apache.flink.configuration
Describe enum constants used in ConfigOptions.
description() - Method in class org.apache.flink.configuration.ConfigOption
Returns the description of this option.
Description - Class in org.apache.flink.configuration.description
Description for ConfigOption.
Description.DescriptionBuilder - Class in org.apache.flink.configuration.description
Builder for Description.
DescriptionBuilder() - Constructor for class org.apache.flink.configuration.description.Description.DescriptionBuilder
 
deserializationAdapter(RuntimeContext) - Static method in class org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
deserializationAdapter(RuntimeContext, Function<MetricGroup, MetricGroup>) - Static method in class org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
DeserializationException - Exception in org.apache.flink.types
An exception specifying that the deserialization caused an error.
DeserializationException() - Constructor for exception org.apache.flink.types.DeserializationException
Constructs an DeserializationException with null as its error detail message.
DeserializationException(String, Throwable) - Constructor for exception org.apache.flink.types.DeserializationException
Constructs an DeserializationException with the specified detail message and cause.
DeserializationException(String) - Constructor for exception org.apache.flink.types.DeserializationException
Constructs an DeserializationException with the specified detail message.
DeserializationException(Throwable) - Constructor for exception org.apache.flink.types.DeserializationException
Constructs an DeserializationException with the specified cause.
DeserializationSchema<T> - Interface in org.apache.flink.api.common.serialization
The deserialization schema describes how to turn the byte messages delivered by certain data sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by Flink.
DeserializationSchema.InitializationContext - Interface in org.apache.flink.api.common.serialization
A contextual information provided for DeserializationSchema.open(InitializationContext) method.
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.io.SerializedInputFormat
 
deserialize(byte[]) - Method in class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
De-serializes the byte message.
deserialize(byte[]) - Method in interface org.apache.flink.api.common.serialization.DeserializationSchema
Deserializes the byte message.
deserialize(byte[], Collector<T>) - Method in interface org.apache.flink.api.common.serialization.DeserializationSchema
Deserializes the byte message.
deserialize(byte[]) - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
 
deserialize(byte[]) - Method in class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
deserialize(boolean[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
deserialize(byte[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
deserialize(char[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
deserialize(double[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
deserialize(float[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
deserialize(int[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
deserialize(long[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
deserialize(short[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
deserialize(String[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
deserialize(BigDecimal, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
deserialize(BigInteger, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
deserialize(Boolean, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
deserialize(BooleanValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
deserialize(Byte, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
deserialize(ByteValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
deserialize(Character, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
deserialize(CharValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
deserialize(Date, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
deserialize(Double, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
deserialize(DoubleValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
deserialize(Float, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
deserialize(FloatValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
deserialize(C[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
deserialize(Instant, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
deserialize(Integer, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
deserialize(IntValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
deserialize(List<T>, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
deserialize(LocalDate, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
deserialize(LocalDateTime, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
deserialize(LocalTime, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
deserialize(Long, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
deserialize(LongValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
deserialize(Map<K, V>, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
deserialize(NullValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
deserialize(Short, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
deserialize(ShortValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
deserialize(Date, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
deserialize(Time, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
deserialize(Timestamp, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
deserialize(String, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
deserialize(StringValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
deserialize(Void, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
De-serializes a record from the given source input view.
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
De-serializes a record from the given source input view into the given reuse record instance if mutable.
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
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.EitherSerializer
 
deserialize(Either<L, R>, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
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.NullableSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
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.RowSerializer
 
deserialize(Row, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
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(int, byte[]) - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
De-serializes the given data (bytes) which was serialized with the scheme of the indicated version.
deserialize(DataInputView) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
deserialize(T, DataInputView) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
deserialize(DataInputView) - Method in class org.apache.flink.types.Record
 
deserializeAccumulators(Map<String, SerializedValue<OptionalFailure<Object>>>, ClassLoader) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
Takes the serialized accumulator results and tries to deserialize them using the provided class loader.
deserializeAndUnwrapAccumulators(Map<String, SerializedValue<OptionalFailure<Object>>>, ClassLoader) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
Takes the serialized accumulator results and tries to deserialize them using the provided class loader, and then try to unwrap the value unchecked.
deserializedFields1 - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
deserializedFields2 - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
deserializeError(ClassLoader) - Method in exception org.apache.flink.util.SerializedThrowable
 
deserializeField(ObjectInputStream) - Static method in class org.apache.flink.api.java.typeutils.runtime.FieldSerializer
 
deserializeFromByteArray(TypeSerializer<T>, byte[]) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeFromByteArray(TypeSerializer<T>, T, byte[]) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeList(ArrayList<byte[]>, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
deserializeObject(byte[], ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeObject(InputStream, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeObject(byte[], ClassLoader, boolean) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeObject(InputStream, ClassLoader, boolean) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeValue(ClassLoader) - Method in class org.apache.flink.util.CompressedSerializedValue
Decompress and deserialize the data to get the original object.
deserializeValue(ClassLoader) - Method in class org.apache.flink.util.SerializedValue
 
DETACHED_MESSAGE - Static variable in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
DetachedJobExecutionResult - Class in org.apache.flink.core.execution
The JobExecutionResult returned by a context environment when executing a job in detached mode.
DetachedJobExecutionResult(JobID) - Constructor for class org.apache.flink.core.execution.DetachedJobExecutionResult
 
directExecutor() - Static method in class org.apache.flink.util.concurrent.Executors
Return a direct executor.
DirectoryBasedPluginFinder - Class in org.apache.flink.core.plugin
This class is used to create a collection of PluginDescriptor based on directory structure for a given plugin root folder.
DirectoryBasedPluginFinder(Path) - Constructor for class org.apache.flink.core.plugin.DirectoryBasedPluginFinder
 
disableAutoGeneratedUIDs() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables auto-generated UIDs.
disableAutoTypeRegistration() - Method in class org.apache.flink.api.common.ExecutionConfig
Control whether Flink is automatically registering all types in the user programs with Kryo.
disableCleanupInBackground() - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
Disable default cleanup of expired state in background (enabled by default).
disableClosureCleaner() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables the ClosureCleaner.
DISABLED - Static variable in class org.apache.flink.api.common.state.StateTtlConfig
 
disableForceAvro() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables the Apache Avro serializer as the forced serializer for POJOs.
disableForceKryo() - Method in class org.apache.flink.api.common.ExecutionConfig
Disable use of Kryo serializer for all POJOs.
disableGenericTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables the use of generic types (types that would be serialized via Kryo).
disableObjectReuse() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables reusing objects that Flink internally uses for deserialization and passing data to user-code functions.
DISPATCHER_THROUGHPUT - Static variable in class org.apache.flink.configuration.AkkaOptions
Maximum number of messages until another actor is executed by the same thread.
Disposable - Interface in org.apache.flink.util
Interface for classes that can be disposed, i.e.
dispose() - Method in interface org.apache.flink.util.Disposable
Disposes the object and releases all resources.
DistributedCache - Class in org.apache.flink.api.common.cache
DistributedCache provides static methods to write the registered cache files into job configuration or decode them from job configuration.
DistributedCache(Map<String, Future<Path>>) - Constructor for class org.apache.flink.api.common.cache.DistributedCache
 
DistributedCache.DistributedCacheEntry - Class in org.apache.flink.api.common.cache
Meta info about an entry in DistributedCache.
DistributedCacheEntry(String, Boolean) - Constructor for class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
Client-side constructor used by the API for initial registration.
DistributedCacheEntry(String, boolean, boolean) - Constructor for class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
Client-side constructor used during job-submission for zipped directory.
DistributedCacheEntry(String, Boolean, byte[], boolean) - Constructor for class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
Server-side constructor used during job-submission for zipped directories.
DistributedCacheEntry(String, Boolean, byte[]) - Constructor for class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
Server-side constructor used during job-submission for files.
divide(BigDecimal) - Method in class org.apache.flink.api.common.resources.Resource
 
divide(int) - Method in class org.apache.flink.api.common.resources.Resource
 
divide(long) - Method in class org.apache.flink.configuration.MemorySize
 
divideRoundUp(int, int) - Static method in class org.apache.flink.util.MathUtils
Divide and rounding up to integer.
doForward(T, Throwable, CompletableFuture<T>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Completes the given future with either the given value or throwable, depending on which parameter is not null.
doRegister(Closeable, Map<Closeable, Object>) - Method in class org.apache.flink.core.fs.CloseableRegistry
 
doRegister(WrappingProxyCloseable<? extends Closeable>, Map<Closeable, SafetyNetCloseableRegistry.PhantomDelegatingCloseableRef>) - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
doRegister(C, Map<Closeable, T>) - Method in class org.apache.flink.util.AbstractCloseableRegistry
Does the actual registration of the closeable with the registry map.
DOUBLE - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive double and Double.
DOUBLE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
DOUBLE_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
DOUBLE_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
DOUBLE_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
DoubleComparator - Class in org.apache.flink.api.common.typeutils.base
 
DoubleComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
DoubleCounter - Class in org.apache.flink.api.common.accumulators
An accumulator that sums up double values.
DoubleCounter() - Constructor for class org.apache.flink.api.common.accumulators.DoubleCounter
 
DoubleCounter(double) - Constructor for class org.apache.flink.api.common.accumulators.DoubleCounter
 
DoubleMaximum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the maximum double value.
DoubleMaximum() - Constructor for class org.apache.flink.api.common.accumulators.DoubleMaximum
 
DoubleMaximum(double) - Constructor for class org.apache.flink.api.common.accumulators.DoubleMaximum
 
DoubleMinimum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the minimum double value.
DoubleMinimum() - Constructor for class org.apache.flink.api.common.accumulators.DoubleMinimum
 
DoubleMinimum(double) - Constructor for class org.apache.flink.api.common.accumulators.DoubleMinimum
 
DoubleParser - Class in org.apache.flink.types.parser
Parses a text field into a Double.
DoubleParser() - Constructor for class org.apache.flink.types.parser.DoubleParser
 
DoublePrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
DoublePrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
DoublePrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for double arrays.
DoublePrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
DoublePrimitiveArraySerializer.DoublePrimitiveArraySerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base.array
Serializer configuration snapshot for compatibility and format evolution.
DoublePrimitiveArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer.DoublePrimitiveArraySerializerSnapshot
 
DoubleSerializer - Class in org.apache.flink.api.common.typeutils.base
Type serializer for Double.
DoubleSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
DoubleSerializer.DoubleSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
DoubleSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleSerializer.DoubleSerializerSnapshot
 
DoubleSumAggregator - Class in org.apache.flink.api.common.aggregators
An Aggregator that sums up DoubleValue values.
DoubleSumAggregator() - Constructor for class org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
doubleType() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Double type.
DoubleValue - Class in org.apache.flink.types
Boxed serializable and comparable double precision floating point type, representing the primitive type double.
DoubleValue() - Constructor for class org.apache.flink.types.DoubleValue
Initializes the encapsulated double with 0.0.
DoubleValue(double) - Constructor for class org.apache.flink.types.DoubleValue
Initializes the encapsulated double with the provided value.
DoubleValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for DoubleValue based on CopyableValueComparator.
DoubleValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
DoubleValueParser - Class in org.apache.flink.types.parser
Parses a text field into a DoubleValue.
DoubleValueParser() - Constructor for class org.apache.flink.types.parser.DoubleValueParser
 
DoubleValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
DoubleValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
DoubleValueSerializer.DoubleValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
DoubleValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer.DoubleValueSerializerSnapshot
 
DoubleZeroConvergence - Class in org.apache.flink.api.common.aggregators
A ConvergenceCriterion over an Aggregator that defines convergence as reached once the aggregator holds the value zero.
DoubleZeroConvergence() - Constructor for class org.apache.flink.api.common.aggregators.DoubleZeroConvergence
 
doUnRegister(Closeable, Map<Closeable, Object>) - Method in class org.apache.flink.core.fs.CloseableRegistry
 
doUnRegister(WrappingProxyCloseable<? extends Closeable>, Map<Closeable, SafetyNetCloseableRegistry.PhantomDelegatingCloseableRef>) - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
doUnRegister(C, Map<Closeable, T>) - Method in class org.apache.flink.util.AbstractCloseableRegistry
Does the actual un-registration of the closeable from the registry map.
DualInputOperator<IN1,IN2,OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
Abstract operator superclass for all operators that have two inputs, like "Join", "CoGroup", or "Cross".
DualInputOperator(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.DualInputOperator
Creates a new abstract dual-input Pact with the given name wrapping the given user function.
DualInputOperator(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.DualInputOperator
Creates a new abstract dual-input operator with the given name wrapping the given user function.
DualInputSemanticProperties - Class in org.apache.flink.api.common.operators
Container for the semantic properties associated to a dual input operator.
DualInputSemanticProperties() - Constructor for class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
DummyAvroKryoSerializerClass() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroKryoSerializerClass
 
DummyAvroRegisteredClass() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroRegisteredClass
 
DummyKryoSerializerClass() - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
 
DummyRegisteredClass() - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyRegisteredClass
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.InstantComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Creates a copy of this class.
duplicate() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Creates a deep copy of this serializer if it is necessary, i.e.
duplicate() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
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.EitherSerializer
 
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.NullableSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
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.RowComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
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.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
durationType() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Duration type.
DynamicCodeLoadingException - Exception in org.apache.flink.util
An exception that is thrown if the dynamic instantiation of code fails.
DynamicCodeLoadingException(Throwable) - Constructor for exception org.apache.flink.util.DynamicCodeLoadingException
Creates a new exception with the given cause.
DynamicCodeLoadingException(String, Throwable) - Constructor for exception org.apache.flink.util.DynamicCodeLoadingException
Creates a new exception with the given message and cause.

E

EAGER_FUNCTION_MESSAGE - Static variable in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
EITHER(TypeInformation<L>, TypeInformation<R>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Flink's Either type.
Either<L,R> - Class in org.apache.flink.types
This type represents a value of one two possible types, Left or Right (a disjoint union), inspired by Scala's Either type.
Either() - Constructor for class org.apache.flink.types.Either
 
Either.Left<L,R> - Class in org.apache.flink.types
A left value of Either
Either.Right<L,R> - Class in org.apache.flink.types
A right value of Either
EitherSerializer<L,R> - Class in org.apache.flink.api.java.typeutils.runtime
A TypeSerializer for the Either type of the Java class.
EitherSerializer(TypeSerializer<L>, TypeSerializer<R>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
EitherSerializerConfigSnapshot<L,R> - Class in org.apache.flink.api.java.typeutils.runtime
Deprecated.
EitherSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
EitherSerializerSnapshot<L,R> - Class in org.apache.flink.api.java.typeutils.runtime
Deprecated.
this snapshot class is no longer used by any serializers. Instead, JavaEitherSerializerSnapshot is used.
EitherSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
Deprecated.
Constructor for read instantiation.
EitherSerializerSnapshot(TypeSerializer<L>, TypeSerializer<R>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
Deprecated.
Constructor to create the snapshot for writing.
EitherTypeInfo<L,R> - Class in org.apache.flink.api.java.typeutils
A TypeInformation for the Either type of the Java API.
EitherTypeInfo(TypeInformation<L>, TypeInformation<R>) - Constructor for class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
EitherTypeInfoFactory<L,R> - Class in org.apache.flink.api.java.typeutils
 
EitherTypeInfoFactory() - Constructor for class org.apache.flink.api.java.typeutils.EitherTypeInfoFactory
 
emitWatermark(Watermark) - Method in interface org.apache.flink.api.common.eventtime.WatermarkOutput
Emits the given watermark.
emitWatermark(Watermark) - Method in interface org.apache.flink.api.connector.source.ReaderOutput
Emits the given watermark.
empty() - Static method in class org.apache.flink.types.SerializableOptional
 
empty() - Static method in interface org.apache.flink.util.CloseableIterable
Returns an empty iterator.
empty() - Static method in interface org.apache.flink.util.CloseableIterator
 
EMPTY_ARGS - Static variable in interface org.apache.flink.api.common.operators.MailboxExecutor
A constant for empty args to save on object allocation.
EMPTY_INSTANCE - Static variable in interface org.apache.flink.util.CloseableIterator
 
EMPTY_LIST - Static variable in class org.apache.flink.api.common.operators.util.FieldList
 
EMPTY_SET - Static variable in class org.apache.flink.api.common.operators.util.FieldSet
 
EMPTY_STRING_ARRAY - Static variable in class org.apache.flink.util.StringUtils
An empty string array.
emptyClassArray() - Static method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Generic utility function that returns an empty class array.
EmptySemanticProperties() - Constructor for class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
ENABLE_FINE_GRAINED_RESOURCE_MANAGEMENT - Static variable in class org.apache.flink.configuration.ClusterOptions
 
ENABLE_FLAMEGRAPH - Static variable in class org.apache.flink.configuration.RestOptions
Enables the experimental flame graph feature.
ENABLE_QUERYABLE_STATE_PROXY_SERVER - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Option whether the queryable state proxy and server should be enabled where possible and configurable.
ENABLE_STATE_CHANGE_LOG - Static variable in class org.apache.flink.configuration.CheckpointingOptions
Whether to enable state change log.
enableAutoGeneratedUIDs() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables the Flink runtime to auto-generate UID's for operators.
enableClosureCleaner() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables the ClosureCleaner.
enableForceAvro() - Method in class org.apache.flink.api.common.ExecutionConfig
Forces Flink to use the Apache Avro serializer for POJOs.
enableForceKryo() - Method in class org.apache.flink.api.common.ExecutionConfig
Force TypeExtractor to use Kryo serializer for POJOS even though we could analyze as POJO.
enableGenericTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables the use generic types which are serialized via Kryo.
enableObjectReuse() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables reusing objects that Flink internally uses for deserialization and passing data to user-code functions.
enableQuotedStringParsing(char) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
enableQuotedStringParsing(byte) - Method in class org.apache.flink.types.parser.StringParser
 
enableQuotedStringParsing(byte) - Method in class org.apache.flink.types.parser.StringValueParser
 
enableTimeToLive(StateTtlConfig) - Method in class org.apache.flink.api.common.state.StateDescriptor
Configures optional activation of state time-to-live (TTL).
encode(IN, OutputStream) - Method in interface org.apache.flink.api.common.serialization.Encoder
Writes one element to the bucket file.
encode(IN, OutputStream) - Method in class org.apache.flink.api.common.serialization.SimpleStringEncoder
 
encodeArrayToConfig(WritableConfig, ConfigOption<List<OUT>>, IN[], Function<IN, OUT>) - Static method in class org.apache.flink.configuration.ConfigUtils
Puts an array of values of type IN in a WritableConfig as a ConfigOption of type List of type OUT.
encodeCollectionToConfig(WritableConfig, ConfigOption<List<OUT>>, Collection<IN>, Function<IN, OUT>) - Static method in class org.apache.flink.configuration.ConfigUtils
Puts a Collection of values of type IN in a WritableConfig as a ConfigOption of type List of type OUT.
Encoder<IN> - Interface in org.apache.flink.api.common.serialization
A Encoder is used by the streaming file sink to perform the actual writing of the incoming elements to the files in a bucket.
endOfInput() - Method in interface org.apache.flink.api.connector.sink.GlobalCommitter
Signals that there is no committable any more.
endsWithDelimiter(byte[], int, byte[]) - Static method in class org.apache.flink.types.parser.FieldParser
Checks if the given bytes ends with the delimiter at the given end position.
ensureSerializable(Object) - Static method in class org.apache.flink.api.java.ClosureCleaner
 
entries() - Method in interface org.apache.flink.api.common.state.BroadcastState
Returns all the mappings in the state.
entries() - Method in interface org.apache.flink.api.common.state.MapState
Returns all the mappings in the state.
EntropyInjectingFileSystem - Interface in org.apache.flink.core.fs
An interface to be implemented by a FileSystem that is aware of entropy injection.
EntropyInjector - Class in org.apache.flink.core.fs
This class offers utilities for entropy injection for FileSystems that implement EntropyInjectingFileSystem.
entrySet() - Method in class org.apache.flink.types.MapValue
 
ENUM(Class<E>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Java enumerations.
EnumComparator<T extends Enum<T>> - Class in org.apache.flink.api.common.typeutils.base
 
EnumComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.EnumComparator
 
ENUMERATE_NESTED_FILES_FLAG - Static variable in class org.apache.flink.api.common.io.FileInputFormat
The config parameter which defines whether input directories are recursively traversed.
enumerateNestedFiles - Variable in class org.apache.flink.api.common.io.FileInputFormat
The flag to specify whether recursive traversal of the input directory structure is enabled.
EnumSerializer<T extends Enum<T>> - Class in org.apache.flink.api.common.typeutils.base
TypeSerializer for Java enums.
EnumSerializer(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
EnumSerializer.EnumSerializerConfigSnapshot<T extends Enum<T>> - Class in org.apache.flink.api.common.typeutils.base
Deprecated.
EnumSerializer.EnumSerializerSnapshot<T extends Enum<T>> - Class in org.apache.flink.api.common.typeutils.base
EnumSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
EnumSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
enumType(Class<T>) - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Enum type.
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
 
ENV_FLINK_BIN_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the bin directory.
ENV_FLINK_CONF_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the configuration directory.
ENV_FLINK_HOME_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the Flink installation root directory.
ENV_FLINK_LIB_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the lib folder.
ENV_FLINK_OPT_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the opt directory.
ENV_FLINK_PLUGINS_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the plugins folder.
eof() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
equals(Object) - Method in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
equals(Object) - Method in class org.apache.flink.api.common.eventtime.Watermark
 
equals(Object) - Method in class org.apache.flink.api.common.ExecutionConfig
 
equals(Object) - Method in class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
 
equals(Object) - Method in class org.apache.flink.api.common.operators.Ordering
 
equals(Object) - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
equals(Object) - Method in class org.apache.flink.api.common.operators.SlotSharingGroup
 
equals(Object) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
equals(Object) - Method in class org.apache.flink.api.common.operators.util.TypeComparable
 
equals(Object) - Method in class org.apache.flink.api.common.resources.Resource
 
equals(Object) - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
equals(Object) - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
equals(Object) - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
equals(Object) - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
equals(Object) - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
equals(Object) - Method in class org.apache.flink.api.common.state.StateDescriptor
 
equals(Object) - Method in class org.apache.flink.api.common.time.Time
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.TypeHint
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
Deprecated.
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
Deprecated.
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
equals(Object) - Method in class org.apache.flink.api.connector.source.ReaderInfo
 
equals(Object) - Method in class org.apache.flink.api.dag.Transformation
 
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.EitherTypeInfo
 
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.ListTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
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.RowTypeInfo
The equals method does only check for field types.
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.EitherSerializer
 
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.KryoRegistration
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
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.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
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.TupleSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
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.configuration.ConfigOption
 
equals(Object) - Method in class org.apache.flink.configuration.Configuration
 
equals(Object) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
equals(Object) - Method in class org.apache.flink.configuration.FallbackKey
 
equals(Object) - Method in class org.apache.flink.configuration.MemorySize
 
equals(Object) - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
equals(Object) - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
equals(Object) - Method in class org.apache.flink.core.fs.FileInputSplit
 
equals(Object) - Method in class org.apache.flink.core.fs.Path
 
equals(Object) - Method in class org.apache.flink.core.io.GenericInputSplit
 
equals(Object) - Method in class org.apache.flink.core.io.LocatableInputSplit
 
equals(Object) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
equals(Object) - Method in class org.apache.flink.types.BooleanValue
 
equals(Object) - Method in class org.apache.flink.types.ByteValue
 
equals(Object) - Method in class org.apache.flink.types.CharValue
 
equals(Object) - Method in class org.apache.flink.types.DoubleValue
 
equals(Object) - Method in class org.apache.flink.types.Either.Left
 
equals(Object) - Method in class org.apache.flink.types.Either.Right
 
equals(Object) - Method in class org.apache.flink.types.FloatValue
 
equals(Object) - Method in class org.apache.flink.types.IntValue
 
equals(Object) - Method in interface org.apache.flink.types.Key
Deprecated.
Compares the object on equality with another object.
equals(Object) - Method in class org.apache.flink.types.ListValue
 
equals(Object) - Method in class org.apache.flink.types.LongValue
 
equals(Object) - Method in class org.apache.flink.types.MapValue
 
equals(Object) - Method in class org.apache.flink.types.NullValue
 
equals(Object) - Method in class org.apache.flink.types.Row
 
equals(Object) - Method in class org.apache.flink.types.ShortValue
 
equals(Object) - Method in class org.apache.flink.types.StringValue
 
equals(Object) - Method in class org.apache.flink.util.AbstractID
 
equals(Object) - Method in class org.apache.flink.util.OptionalFailure
 
equals(Object) - Method in class org.apache.flink.util.OutputTag
 
equals(Object) - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
equals(Object) - Method in class org.apache.flink.util.SerializedValue
 
equals(Object) - Method in class org.apache.flink.util.StringBasedID
 
equalsFields(int[], Value[], Value[]) - Method in class org.apache.flink.types.Record
Checks the values of this record and a given list of values at specified positions for equality.
equalTo(MemorySegment, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Equals two memory segment regions.
equalToReference(T) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
equalToReference(T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
equalToReference(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
equalToReference(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
equalToReference(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
equalToReference(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
equalToReference(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
equalToReference(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
equalToReference(LocalDate) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
equalToReference(LocalDateTime) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
equalToReference(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
equalToReference(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
equalToReference(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
equalToReference(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
equalToReference(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
 
equalToReference(T) - Method in class org.apache.flink.api.common.typeutils.SameTypePairComparator
 
equalToReference(T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Checks, whether the given element is equal to the element that has been set as the comparison reference in this comparator instance.
equalToReference(T2) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
Checks, whether the given candidate instance is equal to the reference instance, with respect to this comparator's equality definition.
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.NullAwareComparator
 
equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
equalToReference(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
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
 
ERROR_REGISTRATION_DELAY - Static variable in class org.apache.flink.configuration.ClusterOptions
 
EVENLY_SPREAD_OUT_SLOTS_STRATEGY - Static variable in class org.apache.flink.configuration.ClusterOptions
 
ExceptionUtils - Class in org.apache.flink.util
A collection of utility functions for dealing with exceptions and exception workflows.
executablesEquals(Method) - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
executablesEquals(Constructor<?>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
execute(Plan) - Method in class org.apache.flink.api.common.operators.CollectionExecutor
 
execute(ThrowingRunnable<? extends Exception>, String) - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
Executes the given command at some time in the future in the mailbox thread.
execute(ThrowingRunnable<? extends Exception>, String, Object...) - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
Executes the given command at some time in the future in the mailbox thread.
execute(Pipeline, Configuration, ClassLoader) - Method in interface org.apache.flink.core.execution.PipelineExecutor
Executes a Pipeline based on the provided configuration and returns a JobClient which allows to interact with the job being executed, e.g.
execute(Runnable) - Method in class org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
executeOnCollections(List<ST>, List<WT>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.FilterOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.MapOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
 
executeOnCollections(RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
executeOnCollections(List<T>, List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.Union
 
EXECUTION_FAILOVER_STRATEGY - Static variable in class org.apache.flink.configuration.JobManagerOptions
This option specifies the failover strategy, i.e.
EXECUTION_RETRIES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
The configuration value will be replaced by ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS and the corresponding FixedDelayRestartStrategy.
EXECUTION_RETRY_DELAY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
The configuration value will be replaced by ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_DELAY and the corresponding FixedDelayRestartStrategy.
ExecutionConfig - Class in org.apache.flink.api.common
A config to define the behavior of the program execution.
ExecutionConfig() - Constructor for class org.apache.flink.api.common.ExecutionConfig
 
executionConfig - Variable in class org.apache.flink.api.common.Plan
Config object for runtime execution parameters.
ExecutionConfig.ClosureCleanerLevel - Enum in org.apache.flink.api.common
Configuration settings for the closure cleaner.
ExecutionConfig.GlobalJobParameters - Class in org.apache.flink.api.common
Abstract class for a custom user configuration object registered at the execution config.
ExecutionConfig.SerializableSerializer<T extends com.esotericsoftware.kryo.Serializer<?> & Serializable> - Class in org.apache.flink.api.common
 
ExecutionMode - Enum in org.apache.flink.api.common
The execution mode specifies how a batch program is executed in terms of data exchange: pipelining or batched.
ExecutionOptions - Class in org.apache.flink.configuration
ConfigOptions specific for a single execution of a user program.
ExecutionOptions() - Constructor for class org.apache.flink.configuration.ExecutionOptions
 
Executors - Class in org.apache.flink.util.concurrent
Collection of Executor and ExecutorService implementations.
Executors() - Constructor for class org.apache.flink.util.concurrent.Executors
 
ExecutorThreadFactory - Class in org.apache.flink.util.concurrent
A thread factory intended for use by critical thread pools.
ExecutorThreadFactory() - Constructor for class org.apache.flink.util.concurrent.ExecutorThreadFactory
Creates a new thread factory using the default thread pool name ('flink-executor-pool') and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String) - Constructor for class org.apache.flink.util.concurrent.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.flink.util.concurrent.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the given uncaught exception handler.
ExecutorThreadFactory.Builder - Class in org.apache.flink.util.concurrent
ExecutorUtils - Class in org.apache.flink.util
Utilities for Executors.
ExecutorUtils() - Constructor for class org.apache.flink.util.ExecutorUtils
 
exists(Path) - Method in class org.apache.flink.core.fs.FileSystem
Check if exists.
exists(Path) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
exists(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
exists(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
EXIT_CODE - Static variable in class org.apache.flink.util.FatalExitExceptionHandler
 
EXIT_ON_FATAL_AKKA_ERROR - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Deprecated.
expandDirectory(Path, Path) - Static method in class org.apache.flink.util.FileUtils
 
ExponentialBackoffRetryStrategy - Class in org.apache.flink.util.concurrent
An implementation of RetryStrategy that retries that has an exponential backoff with a cap.
ExponentialBackoffRetryStrategy(int, Duration, Duration) - Constructor for class org.apache.flink.util.concurrent.ExponentialBackoffRetryStrategy
 
exponentialDelayRestart(Time, Time, double, Time, double) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a ExponentialDelayRestartStrategyConfiguration.
ExponentialDelayRestartStrategyConfiguration(Time, Time, double, Time, double) - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
ExpressionKeys(TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
ExpressionKeys that is defined by the full data type.
ExpressionKeys(int, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create int-based (non-nested) field position keys on a tuple type.
ExpressionKeys(int[], TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create int-based (non-nested) field position keys on a tuple type.
ExpressionKeys(int[], TypeInformation<T>, boolean) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create int-based (non-nested) field position keys on a tuple type.
ExpressionKeys(String, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create String-based (nested) field expression keys on a composite type.
ExpressionKeys(String[], TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create String-based (nested) field expression keys on a composite type.
EXTERNAL_RESOURCE_AMOUNT - Static variable in class org.apache.flink.configuration.ExternalResourceOptions
The amount for the external resource specified by >resource_name< per TaskExecutor.
EXTERNAL_RESOURCE_AMOUNT_SUFFIX - Static variable in class org.apache.flink.configuration.ExternalResourceOptions
The amount of the external resource per task executor.
EXTERNAL_RESOURCE_DRIVER_FACTORY_CLASS - Static variable in class org.apache.flink.configuration.ExternalResourceOptions
Defines the factory class name for the external resource identified by >resource_name<.
EXTERNAL_RESOURCE_DRIVER_FACTORY_SUFFIX - Static variable in class org.apache.flink.configuration.ExternalResourceOptions
The driver factory class of the external resource to use.
EXTERNAL_RESOURCE_DRIVER_PARAM - Static variable in class org.apache.flink.configuration.ExternalResourceOptions
The naming pattern of custom config options for the external resource specified by >resource_name<.
EXTERNAL_RESOURCE_DRIVER_PARAM_SUFFIX - Static variable in class org.apache.flink.configuration.ExternalResourceOptions
The suffix of custom config options' prefix for the external resource.
EXTERNAL_RESOURCE_LIST - Static variable in class org.apache.flink.configuration.ExternalResourceOptions
List of the resource_name of all external resources with delimiter ";", e.g.
ExternallyInducedSourceReader<T,SplitT extends SourceSplit> - Interface in org.apache.flink.api.connector.source
Sources that implement this interface do not trigger checkpoints when receiving a trigger message from the checkpoint coordinator, but when their input data/events indicate that a checkpoint should be triggered.
ExternalResource - Class in org.apache.flink.api.common.resources
An external resource.
ExternalResource(String, double) - Constructor for class org.apache.flink.api.common.resources.ExternalResource
 
ExternalResourceDriver - Interface in org.apache.flink.api.common.externalresource
Driver which takes the responsibility to manage and provide the information of external resource.
ExternalResourceDriverFactory - Interface in org.apache.flink.api.common.externalresource
ExternalResourceInfo - Interface in org.apache.flink.api.common.externalresource
Contains the information of an external resource.
ExternalResourceOptions - Class in org.apache.flink.configuration
Configuration options for external resources and external resource drivers.
ExternalResourceOptions() - Constructor for class org.apache.flink.configuration.ExternalResourceOptions
 
extractFileExtension(String) - Static method in class org.apache.flink.api.common.io.FileInputFormat
Returns the extension of a file name (!= a path).
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Extracts the key fields from a record.
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.NullAwareComparator
 
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.RowComparator
 
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
 
extractResourceSpec(SlotSharingGroup) - Static method in class org.apache.flink.api.common.operators.util.SlotSharingGroupUtils
 
extractTimestamp(T, long) - Method in class org.apache.flink.api.common.eventtime.IngestionTimeAssigner
 
extractTimestamp(E, long) - Method in class org.apache.flink.api.common.eventtime.RecordTimestampAssigner
 
extractTimestamp(T, long) - Method in interface org.apache.flink.api.common.eventtime.TimestampAssigner
Assigns a timestamp to an element, in milliseconds since the Epoch.
extractTypeArgument(Type, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
This method extracts the n-th type argument from the given type.
extractTypeFromLambda(Class<?>, TypeExtractionUtils.LambdaExecutable, int[], int, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Extracts type from given index from lambda.

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.
FAIL_ON_USER_CLASS_LOADING_METASPACE_OOM - Static variable in class org.apache.flink.configuration.CoreOptions
 
failureRateRestart(int, Time, Time) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a FailureRateRestartStrategyConfiguration.
FailureRateRestartStrategyConfiguration(int, Time, Time) - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
FailureTolerantObjectInputStream(InputStream, ClassLoader) - Constructor for class org.apache.flink.util.InstantiationUtil.FailureTolerantObjectInputStream
 
FallbackKey - Class in org.apache.flink.configuration
A key with FallbackKeys will fall back to the FallbackKeys if it itself is not configured.
fallbackKeys() - Method in class org.apache.flink.configuration.ConfigOption
Gets the fallback keys, in the order to be checked.
fallBackRestart() - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
 
FallbackRestartStrategyConfiguration() - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
FALSE - Static variable in class org.apache.flink.types.BooleanValue
 
FatalExitExceptionHandler - Class in org.apache.flink.util
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
FatalExitExceptionHandler() - Constructor for class org.apache.flink.util.FatalExitExceptionHandler
 
FETCH_BACKLOG - Static variable in class org.apache.flink.configuration.BlobServerOptions
The config parameter defining the backlog of BLOB fetches on the JobManager.
FETCH_CONCURRENT - Static variable in class org.apache.flink.configuration.BlobServerOptions
The config parameter defining the maximum number of concurrent BLOB fetches that the JobManager serves.
FETCH_RETRIES - Static variable in class org.apache.flink.configuration.BlobServerOptions
The config parameter defining number of retires for failed BLOB fetches.
fieldIncluded - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
FieldList - Class in org.apache.flink.api.common.operators.util
Immutable ordered list of fields IDs.
FieldList() - Constructor for class org.apache.flink.api.common.operators.util.FieldList
 
FieldList(int) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
 
FieldList(Integer) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
 
FieldList(int...) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
 
fieldNames - Variable in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
fieldNames - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
FieldParser<T> - Class in org.apache.flink.types.parser
A FieldParser is used parse a field from a sequence of bytes.
FieldParser() - Constructor for class org.apache.flink.types.parser.FieldParser
 
FieldParser.ParseErrorState - Enum in org.apache.flink.types.parser
An enumeration of different types of errors that may occur.
FieldSerializer - Class in org.apache.flink.api.java.typeutils.runtime
This class is for the serialization of java.lang.reflect.Field, which doesn't implement Serializable, therefore readObject/writeObject need to be implemented in classes where there is a field of type java.lang.reflect.Field.
FieldSerializer() - Constructor for class org.apache.flink.api.java.typeutils.runtime.FieldSerializer
 
fieldSerializers - Variable in class org.apache.flink.api.common.typeutils.CompositeSerializer
Serializers for fields which constitute T.
fieldSerializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
FieldSet - Class in org.apache.flink.api.common.operators.util
Immutable unordered collection of fields IDs.
FieldSet() - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
Creates a new empty set of fields.
FieldSet(Integer) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
Creates a set with one field.
FieldSet(int...) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
Creates a set with the given fields.
FieldSet(int[], boolean) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
Creates a set with the given fields.
FieldSet(Collection<Integer>) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
 
FILE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.FileOutputFormat
The key under which the name of the target path is stored in the configuration.
FileBaseStatistics(long, long, float) - Constructor for class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Creates a new statistics object.
FileInputFormat<OT> - Class in org.apache.flink.api.common.io
The base class for RichInputFormats that read from files.
FileInputFormat() - Constructor for class org.apache.flink.api.common.io.FileInputFormat
 
FileInputFormat(Path) - Constructor for class org.apache.flink.api.common.io.FileInputFormat
 
FileInputFormat.FileBaseStatistics - Class in org.apache.flink.api.common.io
Encapsulation of the basic statistics the optimizer obtains about a file.
FileInputFormat.InputSplitOpenThread - Class in org.apache.flink.api.common.io
Obtains a DataInputStream in an thread that is not interrupted.
FileInputSplit - Class in org.apache.flink.core.fs
A file input split provides information on a particular part of a file, possibly hosted on a distributed file system and replicated among several hosts.
FileInputSplit(int, Path, long, long, String[]) - Constructor for class org.apache.flink.core.fs.FileInputSplit
Constructs a split with host information.
fileModTime - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
FileOutputFormat<IT> - Class in org.apache.flink.api.common.io
The abstract base class for all Rich output formats that are file based.
FileOutputFormat() - Constructor for class org.apache.flink.api.common.io.FileOutputFormat
 
FileOutputFormat(Path) - Constructor for class org.apache.flink.api.common.io.FileOutputFormat
 
FileOutputFormat.OutputDirectoryMode - Enum in org.apache.flink.api.common.io
Behavior for creating output directories.
filePath - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
filePath - Variable in class org.apache.flink.api.common.io.FileInputFormat
FilePathFilter - Class in org.apache.flink.api.common.io
The FilePathFilter.filterPath(Path) method is responsible for deciding if a path is eligible for further processing or not.
FilePathFilter() - Constructor for class org.apache.flink.api.common.io.FilePathFilter
 
FilePathFilter.DefaultFilter - Class in org.apache.flink.api.common.io
The default file path filtering method and is used if no other such function is provided.
fileSize - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
FileStatus - Interface in org.apache.flink.core.fs
Interface that represents the client side information for a file independent of the file system.
FileSystem - Class in org.apache.flink.core.fs
Abstract base class of all file systems used by Flink.
FileSystem() - Constructor for class org.apache.flink.core.fs.FileSystem
 
FileSystem.WriteMode - Enum in org.apache.flink.core.fs
The possible write modes.
FILESYSTEM_DEFAULT_OVERWRITE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
FILESYSTEM_OUTPUT_ALWAYS_CREATE_DIRECTORY - Static variable in class org.apache.flink.configuration.CoreOptions
Specifies whether the file systems should always create a directory for the output, even with a parallelism of one.
FILESYSTEM_OUTPUT_ALWAYS_CREATE_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
FILESYSTEM_SCHEME - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
fileSystemConnectionLimit(String) - Static method in class org.apache.flink.configuration.CoreOptions
The total number of input plus output connections that a file system for the given scheme may open.
fileSystemConnectionLimitIn(String) - Static method in class org.apache.flink.configuration.CoreOptions
The total number of input connections that a file system for the given scheme may open.
fileSystemConnectionLimitOut(String) - Static method in class org.apache.flink.configuration.CoreOptions
The total number of output connections that a file system for the given scheme may open.
fileSystemConnectionLimitStreamInactivityTimeout(String) - Static method in class org.apache.flink.configuration.CoreOptions
If any connection limit is configured, this option can be optionally set to define after which time (in milliseconds) inactive streams are reclaimed.
fileSystemConnectionLimitTimeout(String) - Static method in class org.apache.flink.configuration.CoreOptions
If any connection limit is configured, this option can be optionally set to define after which time (in milliseconds) stream opening fails with a timeout exception, if no stream connection becomes available.
FileSystemFactory - Interface in org.apache.flink.core.fs
A factory to create file systems.
FileSystemKind - Enum in org.apache.flink.core.fs
An enumeration defining the kind and characteristics of a FileSystem.
FileSystemSafetyNet - Class in org.apache.flink.core.fs
The FileSystemSafetyNet can be used to guard a thread against FileSystem stream resource leaks.
FileSystemSafetyNet() - Constructor for class org.apache.flink.core.fs.FileSystemSafetyNet
 
FILESYTEM_DEFAULT_OVERRIDE - Static variable in class org.apache.flink.configuration.CoreOptions
Specifies whether file output writers should overwrite existing files by default.
FileUtils - Class in org.apache.flink.util
This is a utility class to deal files and directories.
filter(T) - Method in interface org.apache.flink.api.common.functions.FilterFunction
The filter function that evaluates the predicate.
filter(T) - Method in class org.apache.flink.api.common.functions.RichFilterFunction
 
FilterFunction<T> - Interface in org.apache.flink.api.common.functions
A filter function is a predicate applied individually to each record.
FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> - Class in org.apache.flink.api.common.operators.base
 
FilterOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
 
FilterOperatorBase(FT, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
 
FilterOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
 
filterPath(Path) - Method in class org.apache.flink.api.common.io.FilePathFilter.DefaultFilter
 
filterPath(Path) - Method in class org.apache.flink.api.common.io.FilePathFilter
Returns true if the filePath given is to be ignored when processing a directory, e.g.
filterPath(Path) - Method in class org.apache.flink.api.common.io.GlobFilePathFilter
 
filterPrefixMapKey(String, String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Filter condition for prefix map keys.
filterRecoveredCommittables(List<GlobalCommT>) - Method in interface org.apache.flink.api.connector.sink.GlobalCommitter
Find out which global committables need to be retried when recovering from the failure.
finalizeGlobal(int) - Method in interface org.apache.flink.api.common.io.FinalizeOnMaster
The method is invoked on the master (JobManager) after all (parallel) instances of an OutputFormat finished.
FinalizeOnMaster - Interface in org.apache.flink.api.common.io
This interface may be implemented by OutputFormats to have the master finalize them globally.
find(CharSequence) - Method in class org.apache.flink.types.StringValue
Finds any occurrence of the str character sequence in this StringValue.
find(CharSequence, int) - Method in class org.apache.flink.types.StringValue
Finds any occurrence of the str character sequence in this StringValue.
findPlugins() - Method in class org.apache.flink.core.plugin.DirectoryBasedPluginFinder
 
findPlugins() - Method in interface org.apache.flink.core.plugin.PluginFinder
Find plugins and return a corresponding collection of PluginDescriptor instances.
findSerializedThrowable(Throwable, Class<T>, ClassLoader) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains a specific type of exception and returns it.
findThrowable(Throwable, Class<T>) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains a specific type of exception and returns it.
findThrowable(Throwable, Predicate<Throwable>) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains an exception matching a predicate and returns it.
findThrowableSerializedAware(Throwable, Class<T>, ClassLoader) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains a specific type of exception and returns it.
findThrowableWithMessage(Throwable, String) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains a specific error message and returns the corresponding throwable.
FINE_GRAINED_SHUFFLE_MODE_ALL_BLOCKING - Static variable in class org.apache.flink.configuration.ClusterOptions
 
finish() - Method in interface org.apache.flink.api.common.serialization.BulkWriter
Finishes the writing.
firstOrSuppressed(T, T) - Static method in class org.apache.flink.util.ExceptionUtils
Adds a new exception as a suppressed exception to a prior exception, or returns the new exception, if no prior exception exists.
fixedDelayRestart(int, long) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a FixedDelayRestartStrategyConfiguration.
fixedDelayRestart(int, Time) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a FixedDelayRestartStrategyConfiguration.
FixedRetryStrategy - Class in org.apache.flink.util.concurrent
An implementation of RetryStrategy that retries at a fixed delay.
FixedRetryStrategy(int, Duration) - Constructor for class org.apache.flink.util.concurrent.FixedRetryStrategy
 
FLAMEGRAPH_CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.RestOptions
"Time after which cached stats are cleaned up if not accessed.
FLAMEGRAPH_DELAY - Static variable in class org.apache.flink.configuration.RestOptions
Delay between individual stack trace samples taken for building a FlameGraph.
FLAMEGRAPH_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.RestOptions
Number of samples to take to build a FlameGraph.
FLAMEGRAPH_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.RestOptions
Time after which available stats are deprecated and need to be refreshed (by resampling).
FLAMEGRAPH_STACK_TRACE_DEPTH - Static variable in class org.apache.flink.configuration.RestOptions
Maximum depth of stack traces used to create FlameGraphs.
FlatFieldDescriptor(int, TypeInformation<?>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
FlatJoinFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
Interface for Join functions.
flatMap(T, Collector<O>) - Method in interface org.apache.flink.api.common.functions.FlatMapFunction
The core method of the FlatMapFunction.
flatMap(IN, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichFlatMapFunction
 
flatMap(X, Collector<X>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
 
flatMap(Iterable<G>, Function<K, V>) - Static method in class org.apache.flink.util.IterableUtils
Flatmap the two-dimensional Iterable into an one-dimensional Iterable and convert the keys into items.
FlatMapFunction<T,O> - Interface in org.apache.flink.api.common.functions
Base interface for flatMap functions.
FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
 
FlatMapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
FlatMapOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
FlatMapOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
flatten(CloseableIterator<T>...) - Static method in interface org.apache.flink.util.CloseableIterator
 
flatten(Properties) - Static method in class org.apache.flink.util.PropertiesUtil
Flatten a recursive Properties to a first level property map.
FLINK_BASE_DIR_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
This parameter should not be used any more. A running Flink cluster should make no assumption about its location.
FLINK_CLI_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
 
FLINK_CONF_FILENAME - Static variable in class org.apache.flink.configuration.GlobalConfiguration
 
FLINK_HADOOP_CONF_DIR - Static variable in class org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_HBASE_CONF_DIR - Static variable in class org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_HS_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
 
FLINK_JM_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
 
FLINK_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
FLINK_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
 
FLINK_LOG_DIR - Static variable in class org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_LOG_MAX - Static variable in class org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_PID_DIR - Static variable in class org.apache.flink.configuration.CoreOptions
The config parameter defining the directory for Flink PID file.
FLINK_SSH_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FLINK_TM_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
 
FLINK_YARN_CONF_DIR - Static variable in class org.apache.flink.configuration.CoreOptions
This options is here only for documentation generation, it is only evaluated in the shell scripts.
FlinkConnectorRateLimiter - Interface in org.apache.flink.api.common.io.ratelimiting
An interface to create a ratelimiter
FlinkException - Exception in org.apache.flink.util
Base class of all Flink-specific checked exceptions.
FlinkException(String) - Constructor for exception org.apache.flink.util.FlinkException
Creates a new Exception with the given message and null as the cause.
FlinkException(Throwable) - Constructor for exception org.apache.flink.util.FlinkException
Creates a new exception with a null message and the given cause.
FlinkException(String, Throwable) - Constructor for exception org.apache.flink.util.FlinkException
Creates a new exception with the given message and cause.
FlinkRuntimeException - Exception in org.apache.flink.util
Base class of all Flink-specific unchecked exceptions.
FlinkRuntimeException(String) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
Creates a new Exception with the given message and null as the cause.
FlinkRuntimeException(Throwable) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
Creates a new exception with a null message and the given cause.
FlinkRuntimeException(String, Throwable) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
Creates a new exception with the given message and cause.
FlinkSecurityManager - Class in org.apache.flink.core.security
FlinkSecurityManager to control certain behaviors that can be captured by Java system security manager.
FlinkUserCodeClassLoader - Class in org.apache.flink.util
This class loader accepts a custom handler if an exception occurs in FlinkUserCodeClassLoader.loadClass(String, boolean).
FlinkUserCodeClassLoader(URL[], ClassLoader) - Constructor for class org.apache.flink.util.FlinkUserCodeClassLoader
 
FlinkUserCodeClassLoader(URL[], ClassLoader, Consumer<Throwable>) - Constructor for class org.apache.flink.util.FlinkUserCodeClassLoader
 
flipSignBit(long) - Static method in class org.apache.flink.util.MathUtils
Flips the sign bit (most-significant-bit) of the input.
FLOAT - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive float and Float.
FLOAT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
FLOAT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
FLOAT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
FLOAT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
FloatComparator - Class in org.apache.flink.api.common.typeutils.base
 
FloatComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.FloatComparator
 
FloatParser - Class in org.apache.flink.types.parser
Parses a text field into a Float.
FloatParser() - Constructor for class org.apache.flink.types.parser.FloatParser
 
FloatPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
FloatPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
FloatPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for float arrays.
FloatPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
FloatPrimitiveArraySerializer.FloatPrimitiveArraySerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base.array
Serializer configuration snapshot for compatibility and format evolution.
FloatPrimitiveArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer.FloatPrimitiveArraySerializerSnapshot
 
FloatSerializer - Class in org.apache.flink.api.common.typeutils.base
Type serializer for Float.
FloatSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
FloatSerializer.FloatSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
FloatSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatSerializer.FloatSerializerSnapshot
 
floatType() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Float type.
FloatValue - Class in org.apache.flink.types
Boxed serializable and comparable single precision floating point type, representing the primitive type float.
FloatValue() - Constructor for class org.apache.flink.types.FloatValue
Initializes the encapsulated float with 0.0.
FloatValue(float) - Constructor for class org.apache.flink.types.FloatValue
Initializes the encapsulated float with the provided value.
FloatValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for FloatValue based on CopyableValueComparator.
FloatValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
FloatValueParser - Class in org.apache.flink.types.parser
Parses a text field into a FloatValue
FloatValueParser() - Constructor for class org.apache.flink.types.parser.FloatValueParser
 
FloatValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
FloatValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
FloatValueSerializer.FloatValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
FloatValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatValueSerializer.FloatValueSerializerSnapshot
 
flush() - Method in interface org.apache.flink.api.common.serialization.BulkWriter
Flushes all intermediate buffered data to the output stream.
flush() - Method in class org.apache.flink.core.fs.FSDataOutputStream
Flushes the stream, writing any data currently buffered in stream implementation to the proper output stream.
flush() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
flush() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
forBoundedOutOfOrderness(Duration) - Static method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a watermark strategy for situations where records are out of order, but you can place an upper bound on how far the events are out of order.
FORCE_AVRO - Static variable in class org.apache.flink.configuration.PipelineOptions
 
FORCE_KRYO - Static variable in class org.apache.flink.configuration.PipelineOptions
 
forceProcessExit(int) - Static method in class org.apache.flink.core.security.FlinkSecurityManager
Use this method to circumvent the configured FlinkSecurityManager behavior, ensuring that the current JVM process will always stop via System.exit() or Runtime.getRuntime().halt().
forEach(LinkedOptionalMap.ConsumerWithException<K, V, E>) - Method in class org.apache.flink.util.LinkedOptionalMap
 
forEachRemaining(Consumer<? super E>) - Method in class org.apache.flink.util.CloseableIterator.IteratorAdapter
 
forGenerator(WatermarkGeneratorSupplier<T>) - Static method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a watermark strategy based on an existing WatermarkGeneratorSupplier.
forInputsCount(int) - Static method in class org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
 
FORK_JOIN_EXECUTOR_PARALLELISM_FACTOR - Static variable in class org.apache.flink.configuration.AkkaOptions
 
FORK_JOIN_EXECUTOR_PARALLELISM_MAX - Static variable in class org.apache.flink.configuration.AkkaOptions
 
FORK_JOIN_EXECUTOR_PARALLELISM_MIN - Static variable in class org.apache.flink.configuration.AkkaOptions
 
format(Description) - Method in class org.apache.flink.configuration.description.Formatter
Formats the description into a String using format specific tags.
format(LinkElement) - Method in class org.apache.flink.configuration.description.Formatter
 
format(TextElement) - Method in class org.apache.flink.configuration.description.Formatter
 
format(LineBreakElement) - Method in class org.apache.flink.configuration.description.Formatter
 
format(ListElement) - Method in class org.apache.flink.configuration.description.Formatter
 
format(Formatter) - Method in class org.apache.flink.configuration.description.LineBreakElement
 
format(Formatter) - Method in class org.apache.flink.configuration.description.LinkElement
 
format(Formatter) - Method in class org.apache.flink.configuration.description.ListElement
 
format(Formatter) - Method in class org.apache.flink.configuration.description.TextElement
 
formatLineBreak(StringBuilder) - Method in class org.apache.flink.configuration.description.Formatter
 
formatLineBreak(StringBuilder) - Method in class org.apache.flink.configuration.description.HtmlFormatter
 
formatLink(StringBuilder, String, String) - Method in class org.apache.flink.configuration.description.Formatter
 
formatLink(StringBuilder, String, String) - Method in class org.apache.flink.configuration.description.HtmlFormatter
 
formatList(StringBuilder, String[]) - Method in class org.apache.flink.configuration.description.Formatter
 
formatList(StringBuilder, String[]) - Method in class org.apache.flink.configuration.description.HtmlFormatter
 
Formatter - Class in org.apache.flink.configuration.description
Allows providing multiple formatters for the description.
Formatter() - Constructor for class org.apache.flink.configuration.description.Formatter
 
formatText(StringBuilder, String, String[], EnumSet<TextElement.TextStyle>) - Method in class org.apache.flink.configuration.description.Formatter
 
formatText(StringBuilder, String, String[], EnumSet<TextElement.TextStyle>) - Method in class org.apache.flink.configuration.description.HtmlFormatter
 
formatWithHighestUnit(Duration) - Static method in class org.apache.flink.util.TimeUtils
Pretty prints the duration as a lowest granularity unit that does not lose precision.
formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSinkBase
 
formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
 
forMonotonousTimestamps() - Static method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a watermark strategy for situations with monotonously ascending timestamps.
forward(CompletableFuture<T>, CompletableFuture<T>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Forwards the value from the source future to the target future.
forwardAsync(CompletableFuture<T>, CompletableFuture<T>, Executor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Forwards the value from the source future to the target future using the provided executor.
FractionalTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for numeric fractional primitive types (double, float).
FractionalTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.FractionalTypeInfo
 
FRAMESIZE - Static variable in class org.apache.flink.configuration.AkkaOptions
Maximum framesize of akka messages.
FRAMEWORK_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Framework Heap Memory size for TaskExecutors.
FRAMEWORK_OFF_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Framework Off-Heap Memory size for TaskExecutors.
free() - Method in class org.apache.flink.core.memory.MemorySegment
Frees this memory segment.
from() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
fromBoolean(boolean) - Static method in enum org.apache.flink.util.TernaryBoolean
Converts the given boolean to a TernaryBoolean, TernaryBoolean.TRUE or TernaryBoolean.FALSE respectively.
fromBoxedBoolean(Boolean) - Static method in enum org.apache.flink.util.TernaryBoolean
Converts the given boxed Boolean to a TernaryBoolean.
fromByteArray(byte[]) - Static method in class org.apache.flink.api.common.JobID
Creates a new JobID from the given byte sequence.
fromByteBuffer(ByteBuffer) - Static method in class org.apache.flink.api.common.JobID
 
fromBytes(byte[]) - Static method in class org.apache.flink.util.CompressedSerializedValue
Construct a compressed serialized value with a serialized byte array.
fromBytes(byte[]) - Static method in class org.apache.flink.util.SerializedValue
Constructs serialized value from serialized data.
fromByteValue(byte) - Static method in enum org.apache.flink.types.RowKind
Creates a RowKind from the given byte value.
fromConfig(Configuration, String) - Static method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
Parses and returns the settings for connection limiting, for the file system with the given file system scheme.
fromConfiguration(ReadableConfig) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
fromConfiguration(Configuration) - Static method in class org.apache.flink.core.plugin.PluginConfig
 
fromDuration(Duration) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the number of milliseconds in the given duration.
fromHexString(String) - Static method in class org.apache.flink.api.common.JobID
Parses a JobID from the given string.
fromJobSubmissionResult(JobSubmissionResult) - Static method in class org.apache.flink.api.common.JobExecutionResult
Deprecated.
Will be removed in future versions.
fromList(List<T>, Consumer<T>) - Static method in interface org.apache.flink.util.CloseableIterator
 
fromLocalFile(File) - Static method in class org.apache.flink.core.fs.Path
Creates a path for the given local file.
fromMap(Map<String, String>) - Static method in class org.apache.flink.configuration.Configuration
Creates a new configuration that is initialized with the options of the given map.
fromNow(Duration) - Static method in class org.apache.flink.api.common.time.Deadline
Constructs a Deadline that is a given duration after now.
fromNowWithClock(Duration, Clock) - Static method in class org.apache.flink.api.common.time.Deadline
Constructs a Deadline that is a given duration after now, where now and all other times from this deadline are defined by the given Clock.
fromObject(T) - Static method in class org.apache.flink.util.CompressedSerializedValue
Constructs a compressed serialized value for the given object.
FS_SMALL_FILE_THRESHOLD - Static variable in class org.apache.flink.configuration.CheckpointingOptions
The minimum size of state data files.
FS_STREAM_OPENING_TIMEOUT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the timeout for filesystem stream opening.
FS_WRITE_BUFFER_SIZE - Static variable in class org.apache.flink.configuration.CheckpointingOptions
The default size of the write buffer for the checkpoint streams that write to file systems.
FSDataInputStream - Class in org.apache.flink.core.fs
Interface for a data input stream to a file on a FileSystem.
FSDataInputStream() - Constructor for class org.apache.flink.core.fs.FSDataInputStream
 
FSDataInputStreamWrapper - Class in org.apache.flink.core.fs
Simple forwarding wrapper around FSDataInputStream.
FSDataInputStreamWrapper(FSDataInputStream) - Constructor for class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
FSDataOutputStream - Class in org.apache.flink.core.fs
An output stream to a file that is created via a FileSystem.
FSDataOutputStream() - Constructor for class org.apache.flink.core.fs.FSDataOutputStream
 
FSDataOutputStreamWrapper - Class in org.apache.flink.core.fs
Simple forwarding wrapper around FSDataInputStream.
FSDataOutputStreamWrapper(FSDataOutputStream) - Constructor for class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
FullTypeInfo(Class<?>, ReflectionUtil.FullTypeInfo[]) - Constructor for class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
Function - Interface in org.apache.flink.api.common.functions
The base interface for all user-defined functions.
FunctionUtils - Class in org.apache.flink.api.common.functions.util
Utility class that contains helper methods to work with Flink Function class.
FunctionUtils - Class in org.apache.flink.util.function
Utility class for Flink's functions.
FunctionWithException<T,R,E extends Throwable> - Interface in org.apache.flink.util.function
A functional interface for a Function that may throw exceptions.
FutureConsumerWithException<T,E extends Throwable> - Interface in org.apache.flink.util.concurrent
A checked extension of the Consumer interface which rethrows exceptions wrapped in a CompletionException.
FutureTaskWithException<V> - Class in org.apache.flink.util.function
FutureTask that also implements RunnableWithException.
FutureTaskWithException(Callable<V>) - Constructor for class org.apache.flink.util.function.FutureTaskWithException
 
FutureTaskWithException(RunnableWithException) - Constructor for class org.apache.flink.util.function.FutureTaskWithException
 
FutureUtils - Class in org.apache.flink.util.concurrent
A collection of utilities that expand the usage of CompletableFuture.
FutureUtils() - Constructor for class org.apache.flink.util.concurrent.FutureUtils
 
FutureUtils.ConjunctFuture<T> - Class in org.apache.flink.util.concurrent
A future that is complete once multiple other futures completed.
FutureUtils.RetryException - Exception in org.apache.flink.util.concurrent
Exception with which the returned future is completed if the FutureUtils.retry(Supplier, int, Executor) operation fails.

G

generate() - Static method in class org.apache.flink.api.common.JobID
Creates a new (statistically) random JobID.
generateEntropy() - Method in interface org.apache.flink.core.fs.EntropyInjectingFileSystem
Creates a string with random entropy to be injected into a path.
generateRandomAlphanumericString(Random, int) - Static method in class org.apache.flink.util.StringUtils
Creates a random alphanumeric string of given length.
GENERIC(Class<T>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns generic type information for any Java object.
GENERIC_TYPES - Static variable in class org.apache.flink.configuration.PipelineOptions
 
GenericArraySerializer<C> - Class in org.apache.flink.api.common.typeutils.base
A serializer for arrays of objects.
GenericArraySerializer(Class<C>, TypeSerializer<C>) - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
GenericArraySerializerConfigSnapshot<C> - Class in org.apache.flink.api.common.typeutils.base
Deprecated.
this is deprecated and no longer used by the GenericArraySerializer. It has been replaced by GenericArraySerializerSnapshot.
GenericArraySerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
Deprecated.
Constructor for read instantiation.
GenericArraySerializerConfigSnapshot(GenericArraySerializer<C>) - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
Deprecated.
Constructor to create the snapshot for writing.
GenericArraySerializerSnapshot<C> - Class in org.apache.flink.api.common.typeutils.base
Point-in-time configuration of a GenericArraySerializer.
GenericArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
Constructor to be used for read instantiation.
GenericArraySerializerSnapshot(GenericArraySerializer<C>) - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
Constructor to be used for writing the snapshot.
GenericCsvInputFormat<OT> - Class in org.apache.flink.api.common.io
 
GenericCsvInputFormat() - Constructor for class org.apache.flink.api.common.io.GenericCsvInputFormat
 
GenericCsvInputFormat(Path) - Constructor for class org.apache.flink.api.common.io.GenericCsvInputFormat
 
GenericDataSinkBase<IN> - Class in org.apache.flink.api.common.operators
Operator for nodes that act as data sinks, storing the data they receive.
GenericDataSinkBase(OutputFormat<IN>, UnaryOperatorInformation<IN, Nothing>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSinkBase
Creates a GenericDataSink with the provided OutputFormat implementation and the given name.
GenericDataSinkBase(UserCodeWrapper<? extends OutputFormat<IN>>, UnaryOperatorInformation<IN, Nothing>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSinkBase
Creates a GenericDataSink with the provided OutputFormat implementation and the given name.
GenericDataSourceBase<OUT,T extends InputFormat<OUT,?>> - Class in org.apache.flink.api.common.operators
Abstract superclass for data sources in a Pact plan.
GenericDataSourceBase(T, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
Creates a new instance for the given file using the given input format.
GenericDataSourceBase(T, OperatorInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
Creates a new instance for the given file using the given input format, using the default name.
GenericDataSourceBase(Class<? extends T>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
Creates a new instance for the given file using the given input format.
GenericDataSourceBase(Class<? extends T>, OperatorInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
Creates a new instance for the given file using the given input format, using the default name.
GenericDataSourceBase.SplitDataProperties<T> - Interface in org.apache.flink.api.common.operators
 
GenericInputFormat<OT> - Class in org.apache.flink.api.common.io
Generic base class for all Rich inputs that are not based on files.
GenericInputFormat() - Constructor for class org.apache.flink.api.common.io.GenericInputFormat
 
GenericInputSplit - Class in org.apache.flink.core.io
A generic input split that has only a partition number.
GenericInputSplit(int, int) - Constructor for class org.apache.flink.core.io.GenericInputSplit
Creates a generic input split with the given split number.
genericKeyWithSuffix(String) - Static method in class org.apache.flink.configuration.ExternalResourceOptions
 
GenericPairComparator<T1,T2> - Class in org.apache.flink.api.common.typeutils
 
GenericPairComparator(TypeComparator<T1>, TypeComparator<T2>) - Constructor for class org.apache.flink.api.common.typeutils.GenericPairComparator
 
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
 
GenericTypeSerializerConfigSnapshot<T> - Class in org.apache.flink.api.common.typeutils
Configuration snapshot for serializers for generic types.
GenericTypeSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
GenericTypeSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
GenericTypeSerializerSnapshot<T,S extends TypeSerializer> - Class in org.apache.flink.api.common.typeutils
Base TypeSerializerSnapshot for serializers for generic types.
GenericTypeSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
GenericTypeSerializerSnapshot(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
get(int) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
get() - Method in interface org.apache.flink.api.common.state.AppendingState
Returns the current value for the state.
get(UK) - Method in interface org.apache.flink.api.common.state.MapState
Returns the current value associated with the given key.
get(K) - Method in interface org.apache.flink.api.common.state.ReadOnlyBroadcastState
Returns the current value associated with the given key.
get(ConfigOption<T>) - Method in class org.apache.flink.configuration.Configuration
 
get(ConfigOption<T>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
get(ConfigOption<T>) - Method in interface org.apache.flink.configuration.ReadableConfig
Reads a value using the metadata included in ConfigOption.
get(URI) - Static method in class org.apache.flink.core.fs.FileSystem
Returns a reference to the FileSystem instance for accessing the file system identified by the given URI.
get(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads the byte at the given position.
get(int, byte[]) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk get method.
get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk get method.
get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
 
get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk get method.
get() - Method in class org.apache.flink.types.BooleanValue
 
get(int) - Method in class org.apache.flink.types.ListValue
 
get(Object) - Method in class org.apache.flink.types.MapValue
 
get() - Method in class org.apache.flink.types.SerializableOptional
 
get() - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
 
get(long, TimeUnit) - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
 
get() - Method in interface org.apache.flink.util.function.SupplierWithException
Gets the result of this supplier.
get() - Method in class org.apache.flink.util.OptionalFailure
 
get(Throwable, ClassLoader) - Static method in exception org.apache.flink.util.SerializedThrowable
 
getAccessTime() - Method in interface org.apache.flink.core.fs.FileStatus
Get the access time of the file.
getAccessTime() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getAccumulatedRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
Returns the accumulated record count.
getAccumulator(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Get an existing accumulator object.
getAccumulator(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAccumulatorResult(String) - Method in class org.apache.flink.api.common.JobExecutionResult
Gets the accumulator with the given name.
getAccumulatorResult(String) - Method in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
getAccumulators() - Method in interface org.apache.flink.core.execution.JobClient
Requests the accumulators of the associated job.
getActualBytes() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
getAddress() - Method in class org.apache.flink.core.memory.MemorySegment
Returns the memory address of off-heap memory segments.
getAddressSize() - Method in enum org.apache.flink.util.ProcessorArchitecture
Gets the address size of the memory (32 bit, 64 bit).
getAggregate() - Method in interface org.apache.flink.api.common.aggregators.Aggregator
Gets the aggregator's current aggregate.
getAggregate() - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
getAggregate() - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
 
getAggregate() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
getAggregateFunction() - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
Returns the aggregate function to be used for the state.
getAggregateFunctionAccumulatorType(AggregateFunction<IN, ACC, ?>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getAggregateFunctionReturnType(AggregateFunction<IN, ?, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value aggregating state.
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value folding state.
getAggregator() - Method in class org.apache.flink.api.common.aggregators.AggregatorWithName
Gets the aggregator.
getAggregators() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
getAggregators() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
getAggregators() - Method in interface org.apache.flink.api.common.operators.IterationOperator
 
getAllAccumulatorResults() - Method in class org.apache.flink.api.common.JobExecutionResult
Gets all accumulators produced by the job.
getAllAccumulatorResults() - Method in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
getAllDeclaredFields(Class<?>, boolean) - 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.
getAllDeclaredMethods(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Returns all declared methods of a class including methods of superclasses.
getAllocationIDAsString() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAllocationIDAsString() - Method in class org.apache.flink.api.common.TaskInfo
Returns the allocation id for where this task is executed.
getAllRegisteredAggregators() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getAllUnits() - Static method in enum org.apache.flink.configuration.MemorySize.MemoryUnit
 
getAlternativeNames() - Method in enum org.apache.flink.util.ProcessorArchitecture
Gets the alternative names for the processor architecture.
getAlwaysParentFirstPatterns() - Method in class org.apache.flink.core.plugin.PluginConfig
 
getAmountConfigOptionForResource(String) - Static method in class org.apache.flink.configuration.ExternalResourceOptions
Generate the config option key for the amount of external resource with resource_name.
getArchitectureName() - Method in enum org.apache.flink.util.ProcessorArchitecture
Gets the primary name of the processor architecture.
getArity() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Gets the arity of this type - the number of fields without nesting.
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.EitherTypeInfo
 
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.ListTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
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.runtime.RowSerializer
 
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.types.Row
Returns the number of fields in the row.
getArray() - Method in class org.apache.flink.core.memory.MemorySegment
Returns the byte array of on-heap memory segments.
getAsBoolean() - Method in enum org.apache.flink.util.TernaryBoolean
Gets this ternary boolean as a boxed boolean.
getAttemptNumber() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the attempt number of this parallel subtask.
getAttemptNumber() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAttemptNumber() - Method in class org.apache.flink.api.common.TaskInfo
Gets the attempt number of this parallel subtask.
getAutoWatermarkInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the interval of the automatic watermark emission.
getAvailablePort() - Static method in class org.apache.flink.util.NetUtils
Find a non-occupied port.
getAverageRecordWidth() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the estimated average number of bytes per record.
getAverageRecordWidth() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Gets the average width of a record, in bytes.
getAvgOutputRecordSize() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
getAvroUtils() - Static method in class org.apache.flink.api.java.typeutils.AvroUtils
Returns either the default AvroUtils which throw an exception in cases where Avro would be needed or loads the specific utils for Avro from flink-avro.
getBackoffMultiplier() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
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
 
getBinaryLength() - Method in class org.apache.flink.types.BooleanValue
 
getBinaryLength() - Method in class org.apache.flink.types.ByteValue
 
getBinaryLength() - Method in class org.apache.flink.types.CharValue
 
getBinaryLength() - Method in interface org.apache.flink.types.CopyableValue
Gets the length of the data type when it is serialized, in bytes.
getBinaryLength() - Method in class org.apache.flink.types.DoubleValue
 
getBinaryLength() - Method in class org.apache.flink.types.FloatValue
 
getBinaryLength() - Method in class org.apache.flink.types.IntValue
 
getBinaryLength() - Method in class org.apache.flink.types.LongValue
 
getBinaryLength() - Method in class org.apache.flink.types.NullValue
 
getBinaryLength() - Method in class org.apache.flink.types.Record
 
getBinaryLength() - Method in class org.apache.flink.types.ShortValue
 
getBinaryLength() - Method in class org.apache.flink.types.StringValue
 
getBinaryOperatorReturnType(Function, Class<?>, int, int, int, int[], TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Returns the binary operator's return type.
getBlockLocations() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getBlockLocations() - Method in interface org.apache.flink.core.fs.LocatedFileStatus
Gets the location information for the file.
getBlocks() - Method in class org.apache.flink.configuration.description.Description
 
getBlockSize() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getBlockSize() - Method in interface org.apache.flink.core.fs.FileStatus
Get the block size of the file.
getBlockSize() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getBoolean(String, boolean) - Method in class org.apache.flink.configuration.Configuration
getBoolean(ConfigOption<Boolean>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a boolean.
getBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a boolean.
getBoolean(String, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getBoolean(ConfigOption<Boolean>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getBoolean(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads one byte at the given position and returns its boolean representation.
getBoolean(Properties, String, boolean) - Static method in class org.apache.flink.util.PropertiesUtil
Get boolean from properties.
getBoundedness() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getBoundedness() - Method in interface org.apache.flink.api.connector.source.Source
Get the boundedness of this source.
getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Returns the input, or null, if none is set.
getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
The BulkIteration meta operator cannot have broadcast inputs.
getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
DeltaIteration meta operator cannot have broadcast inputs.
getBroadcastState(MapStateDescriptor<K, V>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Creates (or restores) a broadcast state.
getBroadcastVariable(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the result bound to the broadcast variable identified by the given name.
getBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the result bound to the broadcast variable identified by the given name.
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getBucketBoundary(int, int) - Method in interface org.apache.flink.api.common.distributions.DataDistribution
Returns the i'th bucket's upper bound, given that the distribution is to be split into totalBuckets buckets.
getBuf() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
getBufferSize() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getBufferTimeout() - Method in class org.apache.flink.api.dag.Transformation
Returns the buffer timeout of this Transformation.
getBuildComparator() - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
 
getBuildSerializer() - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
 
getByteArray() - Method in class org.apache.flink.core.memory.DataOutputSerializer
Deprecated.
Replaced by DataOutputSerializer.getSharedBuffer() for a better, safer name.
getByteArray() - Method in class org.apache.flink.util.SerializedValue
Returns byte array for serialized data.
getBytes(String, byte[]) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given key as a byte array.
getBytes(String, byte[]) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in bytes.
getBytes() - Method in class org.apache.flink.util.AbstractID
Gets the bytes underlying this ID.
getCachedFiles() - Method in class org.apache.flink.api.common.Plan
Return the registered cached files.
getChar(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a char value from the given position, in the system's native byte order.
getCharArray() - Method in class org.apache.flink.types.StringValue
Returns this StringValue's internal character data.
getCharBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a character value (16 bit, 2 bytes) from the given position, in big-endian byte order.
getCharLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a character value (16 bit, 2 bytes) from the given position, in little-endian byte order.
getCharset() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Get the character set used for the row delimiter.
getCharset() - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
Gets the charset used by this schema for serialization.
getCharset() - Method in class org.apache.flink.types.parser.FieldParser
Gets the character set used for this parser.
getClass(String, Class<? extends T>, ClassLoader) - Method in class org.apache.flink.configuration.Configuration
Returns the class associated with the given key as a string.
getClass(String, Class<? extends T>, ClassLoader) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getClassLoader() - Method in class org.apache.flink.core.fs.ConnectionLimitingFactory
 
getClassLoader() - Method in class org.apache.flink.core.fs.PluginFileSystemFactory
 
getClassLoader() - Method in interface org.apache.flink.core.plugin.Plugin
Helper method to get the class loader used to load the plugin.
getClazz() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
getClazzIterator() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
getCleanupSize() - Method in class org.apache.flink.api.common.state.StateTtlConfig.IncrementalCleanupStrategy
 
getCleanupStrategies() - Method in class org.apache.flink.api.common.state.StateTtlConfig
 
getClosureCleanerLevel() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the configured ExecutionConfig.ClosureCleanerLevel.
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
 
getCoLocationGroupKey() - Method in class org.apache.flink.api.dag.Transformation
NOTE: This is an internal undocumented feature for now.
getCombinedWatermark() - Method in class org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
 
getCombineHint() - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
getCommentPrefix() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getCommitRecoverableSerializer() - Method in class org.apache.flink.core.fs.local.LocalRecoverableWriter
 
getCommitRecoverableSerializer() - Method in interface org.apache.flink.core.fs.RecoverableWriter
The serializer for the CommitRecoverable types created in this writer.
getCommittableSerializer() - Method in interface org.apache.flink.api.connector.sink.Sink
Returns the serializer of the committable type.
getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 
getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 
getCommonFileExtensions() - Method in interface org.apache.flink.api.common.io.compression.InflaterInputStreamFactory
Lists a collection of typical file extensions (e.g., "gz", "gzip") that are associated with the compression algorithm in the InflaterInputStream T.
getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.XZInputStreamFactory
 
getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.ZStandardInputStreamFactory
 
getCompatibleStateNames() - Method in interface org.apache.flink.api.connector.sink.Sink
A list of state names of sinks from which the state can be restored.
getCompatibleVersions() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
Deprecated.
 
getCompatibleVersions() - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
Returns the compatible version values.
getCompilerHints() - Method in class org.apache.flink.api.common.operators.Operator
Gets the compiler hints for this contract instance.
getComponentClass() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Gets the class that represents the component type.
getComponentClass() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
getComponentInfo() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getComponentInfo() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getComponentSerializer() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
getComponentType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Gets the type information of the component type.
getComponentTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getConfiguration() - Method in interface org.apache.flink.api.connector.source.SourceReaderContext
Gets the configuration with which Flink was started.
getContainingBulkIteration() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
getContainingWorksetIteration() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
getContainingWorksetIteration() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
getConvergenceCriterion() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getCopyOfBuffer() - Method in class org.apache.flink.core.memory.DataOutputSerializer
Gets a copy of the buffer that has the right length for the data serialized so far.
getCorrectHostnamePort(String) - Static method in class org.apache.flink.util.NetUtils
Converts a string of the form "host:port" into an URL.
getCpuCores() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getCpuCores() - Method in class org.apache.flink.api.common.operators.SlotSharingGroup
 
getCrossHint() - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
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
 
getCurrent() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
getCurrent() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
getCurrent() - Method in class org.apache.flink.util.NumberSequenceIterator
 
getCurrentOperatingSystem() - Static method in enum org.apache.flink.util.OperatingSystem
Gets the operating system that the JVM runs on from the java system properties.
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Returns the version of the current outer snapshot's written binary format.
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
getCurrentProcessingTime() - Method in interface org.apache.flink.api.connector.sink.Sink.ProcessingTimeService
Returns the current processing time.
getCurrentState() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getCurrentState() - Method in interface org.apache.flink.api.common.io.CheckpointableInputFormat
Returns the split currently being read, along with its current state.
getCurrentState() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getCurrentVersion() - Method in class org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
getCurrentVersion() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
getCurrentVersion() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
Deprecated.
 
getCurrentVersion() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
getCurrentVersion() - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
getCurrentVersion() - Method in class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
getCurrentVersion() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Deprecated.
 
getCurrentVersion() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Returns the version of the current snapshot's written binary format.
getCurrentVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
Deprecated.
 
getCurrentVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
getCurrentVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
getCurrentWorkingDirectory() - Static method in class org.apache.flink.util.FileUtils
Returns the current working directory as specified by the user.dir system property.
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
getDataSinks() - Method in class org.apache.flink.api.common.Plan
Gets all the data sinks of this job.
getDataType() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
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
 
getDefaultBlockSize() - Method in class org.apache.flink.core.fs.FileSystem
Deprecated.
This value is no longer used and is meaningless.
getDefaultBlockSize() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Deprecated.
getDefaultBlockSize() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getDefaultFsUri() - Static method in class org.apache.flink.core.fs.FileSystem
Gets the default file system URI that is used for paths and file systems that do not specify and explicit scheme.
getDefaultInputDependencyConstraint() - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
due to the deprecation of InputDependencyConstraint.
getDefaultKryoSerializerClasses() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered default Kryo Serializer classes.
getDefaultKryoSerializers() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered default Kryo Serializers.
getDefaultParallelism() - Method in class org.apache.flink.api.common.Plan
Gets the default parallelism for this job.
getDefaultValue() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns the default value.
getDeferredOutput(String) - Method in class org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Returns a deferred WatermarkOutput for the given output ID.
getDelay(TimeUnit) - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
 
getDelayBetweenAttemptsInterval() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getDelayBetweenAttemptsInterval() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getDelimiter() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getDescription() - Method in enum org.apache.flink.api.common.BatchShuffleMode
 
getDescription() - Method in enum org.apache.flink.api.common.ExecutionConfig.ClosureCleanerLevel
 
getDescription() - Method in interface org.apache.flink.api.common.ProgramDescription
Returns a description of the plan that is generated by the assembler and also of the arguments if they are available.
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration
Returns a description which is shown in the web interface.
getDescription() - Method in enum org.apache.flink.configuration.ClusterOptions.UserSystemExitMode
 
getDescription() - Method in interface org.apache.flink.configuration.DescribedEnum
Returns the description for the enum constant.
getDescriptionPrefix() - Method in class org.apache.flink.api.common.operators.util.FieldList
 
getDescriptionPrefix() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
getDescriptionSuffix() - Method in class org.apache.flink.api.common.operators.util.FieldList
 
getDescriptionSuffix() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
getDirectoryFileName(int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
getDistributedCache() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the DistributedCache to get the local temporary file copies of files otherwise not locally accessible.
getDistributedCache() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getDistribution() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getDouble(String, double) - Method in class org.apache.flink.configuration.Configuration
getDouble(ConfigOption<Double>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a double.
getDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a double.
getDouble(String, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getDouble(ConfigOption<Double>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getDouble(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in the system's native byte order.
getDoubleBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in big endian byte order.
getDoubleCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for doubles.
getDoubleCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getDoubleLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in little endian byte order.
getElements() - Method in class org.apache.flink.configuration.description.TextElement
 
getElementSerializer() - Method in class org.apache.flink.api.common.state.ListStateDescriptor
Gets the serializer for the elements contained in the list.
getElementSerializer() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
Gets the serializer for the elements of the list.
getElementTypeInfo() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
Gets the type information for the elements contained in the list
getElementTypeInfo() - Method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
Gets the type information for the elements contained in the Multiset
getEntries() - Method in class org.apache.flink.configuration.description.ListElement
 
getEntropyInjectionKey() - Method in interface org.apache.flink.core.fs.EntropyInjectingFileSystem
Gets the marker string that represents the substring of a path to be replaced by the entropy characters.
getEnum(Class<T>, ConfigOption<String>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as an enum.
getEnum(Class<T>, ConfigOption<String>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getEnumeratorCheckpointSerializer() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getEnumeratorCheckpointSerializer() - Method in interface org.apache.flink.api.connector.source.Source
Creates the serializer for the SplitEnumerator checkpoint.
getErrorState() - Method in class org.apache.flink.types.parser.FieldParser
Gets the error state of the parser, as a value of the enumeration FieldParser.ParseErrorState.
getExecutionConfig() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the ExecutionConfig for the currently executing job.
getExecutionConfig() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getExecutionConfig() - Method in class org.apache.flink.api.common.Plan
Gets the execution config object.
getExecutionMode() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getExecutionMode() - Method in class org.apache.flink.api.common.ExecutionConfig
Gets the execution mode used to execute the program.
getExecutionRetryDelay() - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
Should no longer be used because it is subsumed by RestartStrategyConfiguration
getExecutor(Configuration) - Method in interface org.apache.flink.core.execution.PipelineExecutorFactory
Instantiates an PipelineExecutor compatible with the provided configuration.
getExecutorFactory(Configuration) - Method in class org.apache.flink.core.execution.DefaultExecutorServiceLoader
 
getExecutorFactory(Configuration) - Method in interface org.apache.flink.core.execution.PipelineExecutorServiceLoader
Loads the PipelineExecutorFactory which is compatible with the provided configuration.
getExecutorNames() - Method in class org.apache.flink.core.execution.DefaultExecutorServiceLoader
 
getExecutorNames() - Method in interface org.apache.flink.core.execution.PipelineExecutorServiceLoader
Loads and returns a stream of the names of all available executors.
getExtendedResource(String) - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getExtendedResources() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getExternalResourceDriverFactoryConfigOptionForResource(String) - Static method in class org.apache.flink.configuration.ExternalResourceOptions
Generate the config option key for the factory class name of ExternalResourceDriver.
getExternalResourceInfos(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Get the specific external resource information by the resourceName.
getExternalResourceInfos(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getExternalResourceParamConfigPrefixForResource(String) - Static method in class org.apache.flink.configuration.ExternalResourceOptions
Generate the suffix option key prefix for the user-defined params for external resources.
getExternalResources() - Method in class org.apache.flink.api.common.operators.SlotSharingGroup
 
getFailureCause() - Method in class org.apache.flink.util.OptionalFailure
 
getFailureInterval() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getField(T, int) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
Get field of existing instance.
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
 
getField(int, Class<T>) - Method in class org.apache.flink.types.Record
Gets the field at the given position from the record.
getField(int, T) - Method in class org.apache.flink.types.Record
Gets the field at the given position.
getField(int) - Method in class org.apache.flink.types.Row
Returns the field's content at the specified field position.
getField(String) - Method in class org.apache.flink.types.Row
Returns the field's content using the specified field name.
getFieldAs(int) - Method in class org.apache.flink.types.Row
Returns the field's content at the specified field position.
getFieldAs(String) - Method in class org.apache.flink.types.Row
Returns the field's content using the specified field name.
getFieldDelimiter() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getFieldIndex(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the field index of the composite field of the given name.
getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getFieldInto(int, Value) - Method in class org.apache.flink.types.Record
Gets the field at the given position.
getFieldName() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
getFieldNames() - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the names of the composite fields of this type.
getFieldNames() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFieldNames() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
getFieldNames() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getFieldNames(boolean) - Method in class org.apache.flink.types.Row
Returns the set of field names if this row operates in name-based field mode, otherwise null.
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.
getFieldNumber(int) - Method in class org.apache.flink.api.common.operators.Ordering
 
getFieldNumber() - Method in exception org.apache.flink.types.KeyFieldOutOfBoundsException
Gets the field number that was attempted to access.
getFieldNumber() - Method in exception org.apache.flink.types.NullKeyFieldException
Gets the field number that was attempted to access.
getFieldOrders() - Method in class org.apache.flink.api.common.operators.Ordering
 
getFieldParsers() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getFieldPos() - Method in exception org.apache.flink.types.NullFieldException
Gets the field number that was attempted to access.
getFieldPositions() - Method in class org.apache.flink.api.common.operators.Ordering
 
getFieldSerializers() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getFieldsInto(int[], Value[]) - Method in class org.apache.flink.types.Record
Gets the fields at the given positions into an array.
getFieldsIntoCheckingNull(int[], Value[]) - Method in class org.apache.flink.types.Record
Gets the fields at the given positions into an array.
getFieldSortDirections() - Method in class org.apache.flink.api.common.operators.Ordering
 
getFieldToSerializerConfigSnapshot() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
getFieldTypes() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
Returns the field types.
getFile(String) - Method in class org.apache.flink.api.common.cache.DistributedCache
 
getFile() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getFile() - Method in class org.apache.flink.core.fs.RefCountedFile
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.FileSystem
Return an array containing hostnames, offset and size of portions of the given file.
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getFilePath() - Method in class org.apache.flink.api.common.io.FileInputFormat
Deprecated.
Please use getFilePaths() instead.
getFilePaths() - Method in class org.apache.flink.api.common.io.FileInputFormat
Returns the paths of all files to be read by the FileInputFormat.
getFiles() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getFileStats(FileInputFormat.FileBaseStatistics, Path[], ArrayList<FileStatus>) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getFileStats(FileInputFormat.FileBaseStatistics, Path, FileSystem, ArrayList<FileStatus>) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getFileStatus(Path) - Method in class org.apache.flink.core.fs.FileSystem
Return a file status object that represents the path.
getFileStatus(Path) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getFileStatus(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getFileStatus(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getFileSystem() - Method in class org.apache.flink.core.fs.Path
Returns the FileSystem that owns this Path.
getFilterFactor() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
getFinalResult() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
getFirstInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Returns the first input, or null, if none is set.
getFirstInputType() - Method in class org.apache.flink.api.common.operators.BinaryOperatorInformation
 
getFirstRecordStart() - Method in class org.apache.flink.api.common.io.BlockInfo
Returns the firstRecordStart.
getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeComparator
 
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.RowComparator
 
getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Get the field comparators.
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.NullAwareComparator
 
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
getFlatFields(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the flat field descriptors for the given field expression.
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Computes the flat field descriptors for the given field expression with the given offset.
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.RowTypeInfo
 
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, float) - Method in class org.apache.flink.configuration.Configuration
getFloat(ConfigOption<Float>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a float.
getFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a float.
getFloat(String, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getFloat(ConfigOption<Float>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getFloat(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in the system's native byte order.
getFloatBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in big endian byte order.
getFloatLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in little endian byte order.
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.configuration.description.TextElement
 
getFormattedTimestamp() - Method in class org.apache.flink.api.common.eventtime.Watermark
Formats the timestamp of this watermark, assuming it is a millisecond timestamp.
getFormatWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Gets the class describing this sinks output format.
getFormatWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Gets the class describing the input format.
getForObject(X) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
getForwardingSourceField(int, int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
Returns the index of the source field on the given input from which the target field has been unmodified copied by a function.
getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
getForwardingTargetFields(int, int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
Returns the indexes of all target fields to which a source field has been unmodified copied by a function.
getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
getFrom() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getFullStringifiedStackTrace() - Method in exception org.apache.flink.util.SerializedThrowable
 
getFullTemplateType(Type, int) - Static method in class org.apache.flink.util.ReflectionUtil
Extract the full template type information from the given type's template parameter at the given position.
getFullTemplateType(Type) - Static method in class org.apache.flink.util.ReflectionUtil
Extract the full type information from the given type.
getFunctionName() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
getGenericFieldTypes() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getGenericParameters() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Optional method for giving Flink's type extraction system information about the mapping of a generic type parameter to the type information of a subtype.
getGenericParameters() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getGenericParameters() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getGibiBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in Gibibytes (= 1024 Mebibytes).
getGlobalCommittableSerializer() - Method in interface org.apache.flink.api.connector.sink.Sink
Returns the serializer of the aggregated committable type.
getGlobalJobParameters() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getGlobalJobParameters() - Method in class org.apache.flink.api.common.ExecutionConfig
 
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
 
getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Gets the value order for an input, i.e.
getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Gets the value order for an input, i.e.
getGroupOrder() - Method in class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
Gets the order of elements within a reduce group.
getGroupOrder() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Gets the order of elements within a reduce group.
getGroupOrderForInputOne() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Gets the order of elements within a group for the first input.
getGroupOrderForInputOne() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Gets the order of elements within a group for the first input.
getGroupOrderForInputTwo() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Gets the order of elements within a group for the second input.
getGroupOrderForInputTwo() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Gets the order of elements within a group for the second input.
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
 
getHeapMemory() - Method in class org.apache.flink.core.memory.MemorySegment
Get the heap byte array object.
getHistogram(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for histograms.
getHistogram(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getHomeDirectory() - Method in class org.apache.flink.core.fs.FileSystem
Returns the path of the user's home directory in this file system.
getHomeDirectory() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getHomeDirectory() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getHomeDirectory() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getHostnameFromFQDN(String) - Static method in class org.apache.flink.util.NetUtils
Turn a fully qualified domain name (fqdn) into a hostname.
getHostnames() - Method in class org.apache.flink.core.io.LocatableInputSplit
Returns the names of the hosts storing the data this input split refers to
getHosts() - Method in interface org.apache.flink.core.fs.BlockLocation
Get the list of hosts (hostname) hosting this block.
getHosts() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
 
getId() - Method in class org.apache.flink.api.dag.Transformation
Returns the unique ID of this Transformation.
getId() - Method in class org.apache.flink.util.OutputTag
 
getImmediateOutput(String) - Method in class org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Returns an immediate WatermarkOutput for the given output ID.
getIncrementalCleanupStrategy() - Method in class org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
getIndexOfSubtask() - Method in interface org.apache.flink.api.connector.source.SourceReaderContext
 
getIndexOfThisSubtask() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the number of this parallel subtask.
getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.TaskInfo
Gets the number of this parallel subtask.
getInflaterInputStreamFactory(String) - Static method in class org.apache.flink.api.common.io.FileInputFormat
 
getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getInfoFor(Class) - Static method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Tries to get the PrimitiveArrayTypeInfo for an array.
getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getInfoFor(TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
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.
getInfoSize() - Method in class org.apache.flink.api.common.io.BlockInfo
 
getInitialBackoff() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getInitialSolutionSet() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Returns the initial solution set input, or null, if none is set.
getInitialWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Returns the initial workset input, or null, if none is set.
getInput() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Returns this operator's input operator.
getInput() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Returns the input operator or data source, or null, if none is set.
getInputFormatTypes(InputFormat<IN, ?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getInputs() - Method in class org.apache.flink.api.dag.Transformation
Returns the transformations that are the immediate predecessors of the current transformation in the transformation graph.
getInputSplitAssigner(FileInputSplit[]) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getInputSplitAssigner(GenericInputSplit[]) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
getInputSplitAssigner(T[]) - Method in interface org.apache.flink.api.common.io.InputFormat
 
getInputSplitAssigner(S[]) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
getInputSplitAssigner(T[]) - Method in interface org.apache.flink.core.io.InputSplitSource
Returns the assigner for the input splits.
getInputSplits() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getInputType() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getInputType() - Method in class org.apache.flink.api.common.operators.UnaryOperatorInformation
 
getInputView() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
getInstance() - Static method in class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 
getInstance() - Static method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
getInstance() - Static method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 
getInstance() - Static method in class org.apache.flink.api.common.io.compression.XZInputStreamFactory
 
getInstance() - Static method in class org.apache.flink.api.common.io.compression.ZStandardInputStreamFactory
 
getInstance() - Static method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
getInstance() - Static method in class org.apache.flink.management.jmx.JMXService
Acquire the global singleton JMXServer instance.
getInstance() - Static method in class org.apache.flink.types.NullValue
Returns the NullValue singleton instance.
getInstance() - Static method in class org.apache.flink.util.clock.SystemClock
 
getInt(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an int value (32bit, 4 bytes) from the given position, in the system's native byte order.
getInt(Properties, String, int) - Static method in class org.apache.flink.util.PropertiesUtil
Get integer from properties.
getIntBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an int value (32bit, 4 bytes) from the given position, in big-endian byte order.
getIntCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for integers.
getIntCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getIntCounterResult(String) - Method in class org.apache.flink.api.common.JobExecutionResult
Deprecated.
Will be removed in future versions. Use JobExecutionResult.getAccumulatorResult(java.lang.String) instead.
getIntCounterResult(String) - Method in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
getInteger(String, int) - Method in class org.apache.flink.configuration.Configuration
getInteger(ConfigOption<Integer>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as an integer.
getInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as an integer.
getInteger(String, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getInteger(ConfigOption<Integer>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getIntLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an int value (32bit, 4 bytes) from the given position, in little-endian byte order.
getInvolvedIndexes() - Method in class org.apache.flink.api.common.operators.Ordering
 
getIterationAggregator(String) - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
 
getIterationRuntimeContext() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
getIterationRuntimeContext() - Method in interface org.apache.flink.api.common.functions.RichFunction
Gets a specialized version of the RuntimeContext, which has additional information about the iteration in which the function is executed.
getIterator() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
getIterator() - Method in interface org.apache.flink.api.connector.source.lib.util.IteratorSourceSplit
Gets the iterator over the elements of this split.
getJarFiles(String[]) - Static method in class org.apache.flink.util.JarUtils
 
getJitterFactor() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getJobExecutionResult() - Method in class org.apache.flink.api.common.JobExecutionResult
 
getJobExecutionResult() - Method in class org.apache.flink.api.common.JobSubmissionResult
Returns the JobExecutionResult if available.
getJobExecutionResult() - Method in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
getJobExecutionResult() - Method in interface org.apache.flink.core.execution.JobClient
Returns the result of the job execution of the submitted job.
getJobId() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
The ID of the current job.
getJobId() - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getJobID() - Method in class org.apache.flink.api.common.JobSubmissionResult
Returns the JobID assigned to the job by the Flink runtime.
getJobId() - Method in class org.apache.flink.api.common.Plan
Gets the ID of the job that the dataflow plan belongs to.
getJobID() - Method in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
getJobID() - Method in interface org.apache.flink.core.execution.JobClient
Returns the JobID that uniquely identifies the job this client is scoped to.
getJobName() - Method in class org.apache.flink.api.common.Plan
Gets the name of this job.
getJobStatus() - Method in interface org.apache.flink.core.execution.JobClient
Requests the JobStatus of the associated job.
getJoinHint() - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
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
 
getKey(IN) - Method in interface org.apache.flink.api.java.functions.KeySelector
User-defined function that deterministically extracts the key from an object.
getKey(T) - Method in class org.apache.flink.api.java.functions.NullByteKeySelector
 
getKey() - Method in class org.apache.flink.configuration.FallbackKey
 
getKey() - Method in class org.apache.flink.util.LinkedOptionalMap.KeyValue
 
getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Gets the column numbers of the key fields in the input records for the given input.
getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
getKeyExtractor() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getKeyFields() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys
 
getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getKeyPositions() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getKeys() - Method in interface org.apache.flink.api.common.externalresource.ExternalResourceInfo
Get all property keys.
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
 
getKeySerializer() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
Gets the serializer for the keys in the state.
getKeySerializer() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
getKeySerializerSnapshot() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
 
getKeyString() - Method in class org.apache.flink.util.StringBasedID
 
getKeyType() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getKeyTypeInfo() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
Gets the type information for the keys in the map
getKeyTypes() - Method in interface org.apache.flink.api.common.distributions.DataDistribution
Gets the type of the key by which the dataSet is partitioned.
getKibiBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in Kibibytes (= 1024 bytes).
getKind() - Method in class org.apache.flink.core.fs.FileSystem
Deprecated.
this method is not used anymore.
getKind() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getKind() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getKind() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getKind() - Method in class org.apache.flink.types.Row
Returns the kind of change that this row describes in a changelog.
getKryo() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
getKryoRegistrations() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
getLastModificationTime() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the timestamp of the last modification.
getLastResult() - Method in class org.apache.flink.types.parser.BigDecParser
 
getLastResult() - Method in class org.apache.flink.types.parser.BigIntParser
 
getLastResult() - Method in class org.apache.flink.types.parser.BooleanParser
 
getLastResult() - Method in class org.apache.flink.types.parser.BooleanValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.ByteParser
 
getLastResult() - Method in class org.apache.flink.types.parser.ByteValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.DoubleParser
 
getLastResult() - Method in class org.apache.flink.types.parser.DoubleValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.FieldParser
Gets the parsed field.
getLastResult() - Method in class org.apache.flink.types.parser.FloatParser
 
getLastResult() - Method in class org.apache.flink.types.parser.FloatValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.IntParser
 
getLastResult() - Method in class org.apache.flink.types.parser.IntValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.LongParser
 
getLastResult() - Method in class org.apache.flink.types.parser.LongValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.ShortParser
 
getLastResult() - Method in class org.apache.flink.types.parser.ShortValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.SqlDateParser
 
getLastResult() - Method in class org.apache.flink.types.parser.SqlTimeParser
 
getLastResult() - Method in class org.apache.flink.types.parser.SqlTimestampParser
 
getLastResult() - Method in class org.apache.flink.types.parser.StringParser
 
getLastResult() - Method in class org.apache.flink.types.parser.StringValueParser
 
getLatencyTrackingInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the latency tracking interval.
getLeaseCount() - Method in class org.apache.flink.util.ResourceGuard
Returns the current count of open leases.
getLeftSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
getLeftType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getLen() - Method in interface org.apache.flink.core.fs.FileStatus
Return the length of this file.
getLen() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Gets the length of the data type, if it is a fix length data type.
getLength() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
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 interface org.apache.flink.core.fs.BlockLocation
Get the length of the block.
getLength() - Method in class org.apache.flink.core.fs.FileInputSplit
Returns the number of bytes in the file to process.
getLength() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
 
getLength() - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
getLineLengthLimit() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getLink() - Method in class org.apache.flink.configuration.description.LinkElement
 
getListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value list state.
getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value list state.
getListState(ListStateDescriptor<S>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Creates (or restores) a list state.
getLoaderExcludePatterns() - Method in class org.apache.flink.core.plugin.PluginDescriptor
 
getLocalFileSystem() - Static method in class org.apache.flink.core.fs.FileSystem
Returns a reference to the FileSystem instance for accessing the local file system.
getLocalFsURI() - Static method in class org.apache.flink.core.fs.local.LocalFileSystem
Gets the URI that represents the local file system.
getLocalHostName() - Method in interface org.apache.flink.api.connector.source.SourceReaderContext
Gets the hostname of the machine where this reader is executed.
getLocalOrder() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Gets the order, in which the data sink writes its data locally.
getLocalValue() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.Histogram
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
getLocation() - Method in class org.apache.flink.api.connector.source.ReaderInfo
 
getLong(String, long) - Method in class org.apache.flink.configuration.Configuration
getLong(ConfigOption<Long>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a long integer.
getLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a long integer.
getLong(String, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getLong(ConfigOption<Long>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getLong(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a long value (64bit, 8 bytes) from the given position, in the system's native byte order.
getLong(Properties, String, long) - Static method in class org.apache.flink.util.PropertiesUtil
Get long from properties.
getLong(Properties, String, long, Logger) - Static method in class org.apache.flink.util.PropertiesUtil
Get long from properties.
getLongBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a long integer value (64bit, 8 bytes) from the given position, in big endian byte order.
getLongCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for longs.
getLongCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getLongLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a long integer value (64bit, 8 bytes) from the given position, in little endian byte order.
getLowerPart() - Method in class org.apache.flink.util.AbstractID
Gets the lower 64 bits of the ID.
getMailboxExecutor() - Method in interface org.apache.flink.api.connector.sink.Sink.InitContext
Returns the mailbox executor that allows to execute Runnables inside the task thread in between record processing.
getManagedMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getManagedMemory() - Method in class org.apache.flink.api.common.operators.SlotSharingGroup
 
getManagedMemoryOperatorScopeUseCaseWeights() - Method in class org.apache.flink.api.dag.Transformation
Get operator scope use cases that this transformation needs managed memory for, and the use-case-specific weights for this transformation.
getManagedMemorySlotScopeUseCases() - Method in class org.apache.flink.api.dag.Transformation
Get slot scope use cases that this transformation needs managed memory for.
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
 
getMapState(MapStateDescriptor<UK, UV>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value map state.
getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getMapState(MapStateDescriptor<UK, UV>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value map state.
getMaxBackoff() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getMaxFailureRate() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getMaximumNumberOfIterations() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
getMaximumNumberOfIterations() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
getMaximumNumberOfSplits() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
getMaximumNumberOfSplits() - Method in class org.apache.flink.util.NumberSequenceIterator
 
getMaximumNumberOfSplits() - Method in class org.apache.flink.util.SplittableIterator
The maximum number of splits into which this iterator can be split up.
getMaximumParallelism() - Method in class org.apache.flink.api.common.Plan
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.BooleanValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.ByteValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.CharValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.IntValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.LongValue
 
getMaxNormalizedKeyLen() - Method in interface org.apache.flink.types.NormalizableKey
Gets the maximal length of normalized keys that the data type would produce to determine the order of instances solely by the normalized key.
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.NullValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.ShortValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.StringValue
 
getMaxNumberOfParallelSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the number of max-parallelism with which the parallel task runs.
getMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
Gets the max parallelism aka the max number of subtasks.
getMaxNumOpenInputStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the maximum number of concurrently open input streams.
getMaxNumOpenOutputStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the maximum number of concurrently open output streams.
getMaxNumOpenStreamsTotal() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the maximum number of concurrently open streams (input + output).
getMaxParallelism() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getMaxParallelism() - Method in class org.apache.flink.api.common.ExecutionConfig
Gets the maximum degree of parallelism defined for the program.
getMaxParallelism() - Method in class org.apache.flink.api.dag.Transformation
Gets the maximum parallelism for this stream transformation.
getMebiBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in Mebibytes (= 1024 Kibibytes).
getMemoryAddressSize() - Static method in enum org.apache.flink.util.ProcessorArchitecture
Gets the MemorySize of the ProcessorArchitecture of this process.
getMerged() - Method in class org.apache.flink.util.LinkedOptionalMap.MergeResult
 
getMetricGroup() - Method in interface org.apache.flink.api.common.eventtime.TimestampAssignerSupplier.Context
Returns the metric group for the context in which the created TimestampAssigner is used.
getMetricGroup() - Method in interface org.apache.flink.api.common.eventtime.WatermarkGeneratorSupplier.Context
Returns the metric group for the context in which the created WatermarkGenerator is used.
getMetricGroup() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the metric group for this parallel subtask.
getMetricGroup() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getMetricGroup() - Method in interface org.apache.flink.api.common.serialization.DeserializationSchema.InitializationContext
Returns the metric group for the parallel subtask of the source that runs this DeserializationSchema.
getMetricGroup() - Method in interface org.apache.flink.api.common.serialization.SerializationSchema.InitializationContext
Returns the metric group for the parallel subtask of the source that runs this SerializationSchema.
getMetricGroup() - Method in class org.apache.flink.api.connector.sink.InitContextInitializationContextAdapter
 
getMinResources() - Method in class org.apache.flink.api.common.operators.Operator
Gets the minimum resources for this operator.
getMinResources() - Method in class org.apache.flink.api.dag.Transformation
Gets the minimum resource of this stream transformation.
getMinSplitSize() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getModificationTime() - Method in interface org.apache.flink.core.fs.FileStatus
Get the modification time of the file.
getModificationTime() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getMultiplier() - Method in enum org.apache.flink.configuration.MemorySize.MemoryUnit
 
getName() - Method in class org.apache.flink.api.common.aggregators.AggregatorWithName
Gets the name that the aggregator is registered under.
getName() - Method in class org.apache.flink.api.common.operators.Operator
Gets the name of the contract instance.
getName() - Method in class org.apache.flink.api.common.operators.SlotSharingGroup
 
getName() - Method in class org.apache.flink.api.common.resources.Resource
 
getName() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns the name of this StateDescriptor.
getName() - Method in class org.apache.flink.api.dag.Transformation
Returns the name of this Transformation.
getName() - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
getName() - Method in interface org.apache.flink.core.execution.PipelineExecutorFactory
Returns the name of the executor that this factory creates.
getName() - Method in class org.apache.flink.core.fs.Path
Returns the final component of this path, i.e., everything that follows the last separator.
getNestedFileEnumeration() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getNestedSerializers(GenericArraySerializer<C>) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
getNestedSerializers(ListSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
 
getNestedSerializers(MapSerializer<K, V>) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
 
getNestedSerializers(S) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Gets the nested serializers from the outer serializer.
getNestedSerializers() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
getNestedSerializers(SingleThreadAccessCheckingTypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot
 
getNestedSerializers(EitherSerializer<L, R>) - Method in class org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
 
getNestedSerializers(NullableSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
getNestedSerializers(RowSerializer) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
getNestedSerializers(TupleSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
getNestedSerializersAndConfigs() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
getNestedSerializerSnapshots() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
getNestedSerializerSnapshots() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
getNestedSerializerSnapshots() - Method in class org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Returns the snapshots of the nested serializers.
getNetRuntime() - Method in class org.apache.flink.api.common.JobExecutionResult
Gets the net execution time of the job, i.e., the execution time in the parallel system, without the pre-flight steps like the optimizer.
getNetRuntime(TimeUnit) - Method in class org.apache.flink.api.common.JobExecutionResult
Gets the net execution time of the job, i.e., the execution time in the parallel system, without the pre-flight steps like the optimizer in a desired time unit.
getNetRuntime() - Method in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
getNewNodeId() - Static method in class org.apache.flink.api.dag.Transformation
 
getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
getNextInputSplit(String, int) - Method in interface org.apache.flink.core.io.InputSplitAssigner
Returns the next input split that shall be consumed.
getNextPartialSolution() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
getNextRetryStrategy() - Method in class org.apache.flink.util.concurrent.ExponentialBackoffRetryStrategy
 
getNextRetryStrategy() - Method in class org.apache.flink.util.concurrent.FixedRetryStrategy
 
getNextRetryStrategy() - Method in interface org.apache.flink.util.concurrent.RetryStrategy
 
getNextWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that has been set as the next workset.
getNonRegisteredSubclassesToSerializerConfigSnapshots() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.InstantComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Gets the number of bytes that the normalized key would maximally take.
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.NullAwareComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
getNumberOfExecutionRetries() - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
Should no longer be used because it is subsumed by RestartStrategyConfiguration
getNumberOfFields() - Method in interface org.apache.flink.api.common.distributions.DataDistribution
The number of fields in the (composite) key.
getNumberOfFields() - Method in class org.apache.flink.api.common.operators.Ordering
 
getNumberOfFieldsTotal() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Gets the number of inputs for this operator.
getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys
 
getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getNumberOfLocalAssignments() - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
getNumberOfNonNullFields() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getNumberOfOpenInputStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the number of currently open input streams.
getNumberOfOpenOutputStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the number of currently open output streams.
getNumberOfParallelSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the parallelism with which the parallel task runs.
getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
Gets the parallelism with which the parallel task runs.
getNumberOfParallelSubtasks() - Method in interface org.apache.flink.api.connector.sink.Sink.InitContext
 
getNumberOfRecords() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the estimates number of records in the file, computed as the file size divided by the average record width, rounded up.
getNumberOfRecords() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Gets the number of records in the input (= base cardinality).
getNumberOfRegisteredCloseables() - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
getNumberOfRemoteAssignments() - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
getNumFields() - Method in class org.apache.flink.types.Record
Gets the number of fields currently in the record.
getNumFuturesCompleted() - Method in class org.apache.flink.util.concurrent.FutureUtils.ConjunctFuture
Gets the number of Futures in the conjunction that are already complete.
getNumFuturesTotal() - Method in class org.apache.flink.util.concurrent.FutureUtils.ConjunctFuture
Gets the total number of Futures in the conjunction.
getNumLineSamples() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getNumRemainingRetries() - Method in class org.apache.flink.util.concurrent.ExponentialBackoffRetryStrategy
 
getNumRemainingRetries() - Method in class org.apache.flink.util.concurrent.FixedRetryStrategy
 
getNumRemainingRetries() - Method in interface org.apache.flink.util.concurrent.RetryStrategy
 
getNumSplits() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getObjectReuseEnabled() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getOffset() - Method in interface org.apache.flink.core.fs.BlockLocation
Get the start offset of the file associated with this block.
getOffset() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
 
getOpenTimeout() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getOperatorInfo() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Gets the information about the operators input/output types.
getOperatorInfo() - Method in class org.apache.flink.api.common.operators.Operator
Gets the information about the operators input/output types.
getOperatorInfo() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Gets the information about the operators input/output types.
getOptional(ConfigOption<T>) - Method in class org.apache.flink.configuration.Configuration
 
getOptional(ConfigOption<T>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getOptional(ConfigOption<T>) - Method in interface org.apache.flink.configuration.ReadableConfig
Reads a value using the metadata included in ConfigOption.
getOrDefault(CompletableFuture<T>, T) - Static method in class org.apache.flink.util.concurrent.FutureUtils
 
getOrDefault(boolean) - Method in enum org.apache.flink.util.TernaryBoolean
Gets the boolean value corresponding to this value.
getOrder(int) - Method in class org.apache.flink.api.common.operators.Ordering
 
getOrdering() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getOriginalError() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
getOriginalErrorClassName() - Method in exception org.apache.flink.util.SerializedThrowable
 
getOriginalKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
getOriginalKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys
 
getOriginalKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getOuterJoinType() - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
getOutputCardinality() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
getOutputDirectoryMode() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
getOutputFilePath() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
getOutputSize() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
getOutputType() - Method in class org.apache.flink.api.common.operators.OperatorInformation
Gets the return type of the user code function.
getOutputType() - Method in class org.apache.flink.api.dag.Transformation
Returns the output type of this Transformation as a TypeInformation.
getOwner() - Method in class org.apache.flink.core.memory.MemorySegment
Gets the owner of this memory segment.
getParallelism() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getParallelism() - Method in class org.apache.flink.api.common.ExecutionConfig
Gets the parallelism with which operation are executed by default.
getParallelism() - Method in class org.apache.flink.api.common.operators.Operator
Gets the parallelism for this contract instance.
getParallelism() - Method in class org.apache.flink.api.dag.Transformation
Returns the parallelism of this Transformation.
getParameters() - Method in class org.apache.flink.api.common.operators.Operator
Gets the stub parameters of this contract.
getParameterType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getParameterTypes() - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
getParent() - Method in class org.apache.flink.core.fs.Path
Returns the parent of a path, i.e., everything that precedes the last separator or null if at root.
getParentFirstLoaderPatterns(Configuration) - Static method in class org.apache.flink.configuration.CoreOptions
 
getParserForType(Class<T>) - Static method in class org.apache.flink.types.parser.FieldParser
Gets the parser for the type specified by the given class.
getPartialSolution() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
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
 
getPartitionMethod() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getPartitionOrdering() - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
getPath() - Method in class org.apache.flink.core.fs.FileInputSplit
Returns the path of the file containing this split's data.
getPath() - Method in interface org.apache.flink.core.fs.FileStatus
Returns the corresponding Path to the FileStatus.
getPath() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getPath() - Method in class org.apache.flink.core.fs.Path
Return full path.
getPluginId() - Method in class org.apache.flink.core.plugin.PluginDescriptor
 
getPluginParentFirstLoaderPatterns(Configuration) - Static method in class org.apache.flink.configuration.CoreOptions
 
getPluginResourceURLs() - Method in class org.apache.flink.core.plugin.PluginDescriptor
 
getPluginsDir() - Static method in class org.apache.flink.core.plugin.PluginConfig
 
getPluginsPath() - Method in class org.apache.flink.core.plugin.PluginConfig
 
getPojoFieldAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getPort() - Static method in class org.apache.flink.management.jmx.JMXService
 
getPortRangeFromString(String) - Static method in class org.apache.flink.util.NetUtils
Returns an iterator over available ports defined by the range definition.
getPos() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
getPos() - Method in class org.apache.flink.core.fs.FSDataInputStream
Gets the current position in the input stream.
getPos() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
getPos() - Method in class org.apache.flink.core.fs.FSDataOutputStream
Gets the position of the stream (non-negative), defined as the number of bytes from the beginning of the file to the current writing position.
getPos() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
getPos() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
getPos() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
getPosition() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
getPosition() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
getPosition() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
getPosition() - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
getPostPassClassName() - Method in class org.apache.flink.api.common.Plan
Gets the optimizer post-pass class for this job.
getPreferredResources() - Method in class org.apache.flink.api.common.operators.Operator
Gets the preferred resources for this contract instance.
getPreferredResources() - Method in class org.apache.flink.api.dag.Transformation
Gets the preferred resource of this stream transformation.
getPrefixedKeyValuePairs(String, Configuration) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Extract and parse Flink configuration properties with a given name prefix and return the result as a Map.
getPresentEntries() - Method in class org.apache.flink.util.LinkedOptionalMap
 
getPreviousIterationAggregate(String) - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
 
getProcessingTimeService() - Method in interface org.apache.flink.api.connector.sink.Sink.InitContext
Returns a Sink.ProcessingTimeService that can be used to get the current time and register timers.
getProcessorArchitecture() - Static method in enum org.apache.flink.util.ProcessorArchitecture
Gets the ProcessorArchitecture of the system running this process.
getProducedType() - Method in class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Gets the type produced by this deserializer.
getProducedType() - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
 
getProducedType() - Method in class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
 
getProducedType() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
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.
getProperty(String) - Method in interface org.apache.flink.api.common.externalresource.ExternalResourceInfo
Get the property indicated by the specified key.
getQueryableStateName() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns the queryable state name.
getQueryTimeAfterNumEntries() - Method in class org.apache.flink.api.common.state.StateTtlConfig.RocksdbCompactFilterCleanupStrategy
 
getRandomFilename(String) - Static method in class org.apache.flink.util.FileUtils
Constructs a random filename with the given prefix and a random part generated from hex characters.
getRandomString(Random, int, int) - Static method in class org.apache.flink.util.StringUtils
Creates a random string with a length within the given interval.
getRandomString(Random, int, int, char, char) - Static method in class org.apache.flink.util.StringUtils
Creates a random string with a length within the given interval.
getRangeIndex(T) - Method in class org.apache.flink.api.common.distributions.CommonRangeBoundaries
 
getRangeIndex(T) - Method in interface org.apache.flink.api.common.distributions.RangeBoundaries
Get the range index of record.
getRate() - Method in interface org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
 
getRate() - Method in class org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
 
getRawClass(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Returns the raw class of both parameterized types and generic arrays.
getReadFields(int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
getReadFields(int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
getReadFields(int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
Returns the position indexes of all fields of an input that are accessed by a function.
getReadFields(int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
getReadVersion() - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
Returns the found serialization version.
getReconfiguredSerializer() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Gets the reconfigured serializer.
getRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
Returns the recordCount.
getRecoverable() - Method in interface org.apache.flink.core.fs.RecoverableFsDataOutputStream.Committer
Gets a recoverable object to recover the committer.
getReduceFunction() - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
Returns the reduce function to be used for the reducing state.
getReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value reducing state.
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value reducing state.
getReferenceCounter() - Method in class org.apache.flink.core.fs.RefCountedFile
 
getReferencesToClose() - Method in class org.apache.flink.core.fs.CloseableRegistry
 
getReferencesToClose() - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
getRegisteredBroadcastStateNames() - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Returns a set with the names of all currently registered broadcast states.
getRegisteredClass() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getRegisteredKryoTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered Kryo types.
getRegisteredPojoTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered POJO types.
getRegisteredStateNames() - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Returns a set with the names of all currently registered states.
getRegisteredSubclassesToSerializerConfigSnapshots() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
getRegisteredTypesWithKryoSerializerClasses() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered types with their Kryo Serializer classes.
getRegisteredTypesWithKryoSerializers() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered types with Kryo Serializers.
getReplicatedInputFormat() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
getReplication() - Method in interface org.apache.flink.core.fs.FileStatus
Get the replication factor of a file.
getReplication() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getResetBackoffThreshold() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
getResource(String) - Method in class org.apache.flink.core.classloading.ComponentClassLoader
 
getResource(String) - Method in class org.apache.flink.util.ChildFirstClassLoader
 
getResources(String) - Method in class org.apache.flink.core.classloading.ComponentClassLoader
 
getResources(String) - Method in class org.apache.flink.util.ChildFirstClassLoader
 
getRestartAttempts() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getRestartStrategy() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the restart strategy which has been set for the current job.
getRestartStrategyDescription() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getRestoredCheckpointId() - Method in interface org.apache.flink.api.connector.sink.Sink.InitContext
Returns id of the restored checkpoint, if state was restored from the snapshot of a previous execution.
getRestoredNestedSerializer(int) - Method in class org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Creates the restore serializer from the pos-th config snapshot.
getRestoredNestedSerializers() - Method in class org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Produces a restore serializer from each contained serializer configuration snapshot.
getResult(ACC) - Method in interface org.apache.flink.api.common.functions.AggregateFunction
Gets the result of the aggregation from the accumulator.
getResult(ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
 
getResultsFormatted(Map<String, Object>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
 
getResumeRecoverableSerializer() - Method in class org.apache.flink.core.fs.local.LocalRecoverableWriter
 
getResumeRecoverableSerializer() - Method in interface org.apache.flink.core.fs.RecoverableWriter
The serializer for the ResumeRecoverable types created in this writer.
getRetryDelay() - Method in class org.apache.flink.util.concurrent.ExponentialBackoffRetryStrategy
 
getRetryDelay() - Method in class org.apache.flink.util.concurrent.FixedRetryStrategy
 
getRetryDelay() - Method in interface org.apache.flink.util.concurrent.RetryStrategy
 
getReturnType() - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
getRightSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
getRightType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getRocksdbCompactFilterCleanupStrategy() - Method in class org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
getRuntimeContext() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
getRuntimeContext() - Method in interface org.apache.flink.api.common.functions.RichFunction
Gets the context that contains information about the UDF's runtime, such as the parallelism of the function, the subtask index of the function, or the name of the task that executes the function.
getRuntimeContext() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
getRuntimeContext() - Method in class org.apache.flink.api.common.io.RichInputFormat
 
getRuntimeContext() - Method in class org.apache.flink.api.common.io.RichOutputFormat
 
getSchedulerType(Configuration) - Static method in class org.apache.flink.configuration.ClusterOptions
 
getScheme() - Method in class org.apache.flink.core.fs.ConnectionLimitingFactory
 
getScheme() - Method in interface org.apache.flink.core.fs.FileSystemFactory
Gets the scheme of the file system created by this factory.
getScheme() - Method in class org.apache.flink.core.fs.local.LocalFileSystemFactory
 
getScheme() - Method in class org.apache.flink.core.fs.PluginFileSystemFactory
 
getSecondInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Returns the second input, or null, if none is set.
getSecondInputType() - Method in class org.apache.flink.api.common.operators.BinaryOperatorInformation
 
getSemanticProperties() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getSemanticProperties() - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
getSemanticProperties() - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
getSerializableSerializerInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializationFormatIdentifier() - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
Deprecated.
 
getSerializedException() - Method in exception org.apache.flink.util.SerializedThrowable
 
getSerializer() - Method in class org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
 
getSerializer() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns the TypeSerializer that can be used to serialize the value in the state.
getSerializer() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
getSerializer(Kryo) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
getSerializerClass() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializerDefinitionType() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSharedBuffer() - Method in class org.apache.flink.core.memory.DataOutputSerializer
Gets a reference to the internal byte buffer.
getSharedInstance() - Static method in class org.apache.flink.core.fs.local.LocalFileSystem
Gets the shared instance of this file system.
getShort(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a short integer value (16 bit, 2 bytes) from the given position, composing them into a short value according to the current byte order.
getShortBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a short integer value (16 bit, 2 bytes) from the given position, in big-endian byte order.
getShortLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a short integer value (16 bit, 2 bytes) from the given position, in little-endian byte order.
getShortName() - Method in enum org.apache.flink.api.common.operators.Order
 
getSingleAbstractMethod(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Extracts a Single Abstract Method (SAM) as defined in Java Specification (4.3.2.
getSingleNestedSerializerAndConfig() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
getSize() - Method in class org.apache.flink.api.common.time.Time
Gets the length of this policy's time interval.
getSize() - Method in class org.apache.flink.util.CompressedSerializedValue
Returns the size of the compressed serialized data.
getSlotSharingGroup() - Method in class org.apache.flink.api.dag.Transformation
Returns the slot sharing group of this transformation if present.
getSolutionSet() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that represents the solution set for the step function.
getSolutionSetDelta() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that has been set as the solution set delta.
getSolutionSetKeyFields() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
getSplit(int, int) - Method in class org.apache.flink.util.SplittableIterator
Splits this iterator into n partitions and returns the i-th partition out of those.
getSplitDataProperties() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Returns the data properties of this data source's splits.
getSplitGroupKeys() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitLength() - Method in class org.apache.flink.api.common.io.FileInputFormat
Gets the length or remaining length of the current split.
getSplitNumber() - Method in class org.apache.flink.core.io.GenericInputSplit
 
getSplitNumber() - Method in interface org.apache.flink.core.io.InputSplit
Returns the number of this input split.
getSplitNumber() - Method in class org.apache.flink.core.io.LocatableInputSplit
 
getSplitOrder() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitPartitioner() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitPartitionKeys() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitSerializer() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getSplitSerializer() - Method in interface org.apache.flink.api.connector.source.Source
Creates a serializer for the source splits.
getSplitStart() - Method in class org.apache.flink.api.common.io.FileInputFormat
Gets the start of the current split.
getStandaloneClusterStartupPeriodTime(Configuration) - Static method in class org.apache.flink.configuration.ConfigurationUtils
 
getStart() - Method in class org.apache.flink.core.fs.FileInputSplit
Returns the position of the first byte in the file to process.
getState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value state.
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value state.
getStateVisibility() - Method in class org.apache.flink.api.common.state.StateTtlConfig
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.FileInputFormat
Obtains basic file statistics containing only file size.
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
getStatistics(BaseStatistics) - Method in interface org.apache.flink.api.common.io.InputFormat
Gets the basic statistics from the input described by this format.
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
getStatisticsKey() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Gets the key under which statistics about this data source may be obtained from the statistics cache.
getStreamInactivityTimeout() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the milliseconds that a stream may spend not writing any bytes before it is closed as inactive.
getStreamOpenTimeout() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the number of milliseconds that a opening a stream may wait for availability in the connection pool.
getString(String, String) - Method in class org.apache.flink.configuration.Configuration
getString(ConfigOption<String>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a string.
getString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a string.
getString(String, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getString(ConfigOption<String>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getStringInMillis(Duration) - Static method in class org.apache.flink.util.TimeUtils
 
getStyles() - Method in class org.apache.flink.configuration.description.TextElement
 
getSubtaskId() - Method in interface org.apache.flink.api.connector.sink.Sink.InitContext
 
getSubtaskId() - Method in class org.apache.flink.api.connector.source.ReaderInfo
 
getSuperstepNumber() - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
Gets the number of the current superstep.
getSuperTemplateTypes(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getSuperTemplateTypes(Class<?>, Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getSynchronizationLock() - Method in class org.apache.flink.util.AbstractCloseableRegistry
Returns the lock on which manipulations to members closeableToRef and closeable must be synchronized.
getSystemConfigKeyConfigOptionForResource(String, String) - Static method in class org.apache.flink.configuration.ExternalResourceOptions
Generate the config option key for the configuration key of external resource in the deploying system.
getSystemResourceMetricsProbingInterval(Configuration) - Static method in class org.apache.flink.configuration.ConfigurationUtils
 
getTaskCancellationInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
Gets the interval (in milliseconds) between consecutive attempts to cancel a running task.
getTaskCancellationTimeout() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the timeout (in milliseconds) after which an ongoing task cancellation leads to a fatal TaskManager error.
getTaskHeapMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getTaskHeapMemory() - Method in class org.apache.flink.api.common.operators.SlotSharingGroup
 
getTaskName() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the name of the task in which the UDF runs, as assigned during plan construction.
getTaskName() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getTaskName() - Method in class org.apache.flink.api.common.TaskInfo
Returns the name of the task
getTaskNameWithSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the name of the task, appended with the subtask indicator, such as "MyTask (3/6)#1", where 3 would be (RuntimeContext.getIndexOfThisSubtask() + 1), and 6 would be RuntimeContext.getNumberOfParallelSubtasks(), and 1 would be RuntimeContext.getAttemptNumber().
getTaskNameWithSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getTaskNameWithSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
Returns the name of the task, appended with the subtask indicator, such as "MyTask (3/6)#1", where 3 would be (TaskInfo.getIndexOfThisSubtask() + 1), and 6 would be TaskInfo.getNumberOfParallelSubtasks(), and 1 would be TaskInfo.getAttemptNumber().
getTaskOffHeapMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getTaskOffHeapMemory() - Method in class org.apache.flink.api.common.operators.SlotSharingGroup
 
getTebiBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in Tebibytes (= 1024 Gibibytes).
getTemplateType(Class<?>, int) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType1(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType1(Type) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType2(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType3(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType4(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType5(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType6(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType7(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType8(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateTypeInfos() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
getTemplateTypes(ParameterizedType) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateTypes(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTerminationCriterion() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
getText() - Method in class org.apache.flink.configuration.description.LinkElement
 
getTimestamp() - Method in class org.apache.flink.api.common.eventtime.Watermark
Returns the timestamp associated with this Watermark.
getTo() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
getTo() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
getTo() - Method in class org.apache.flink.util.NumberSequenceIterator
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Gets the number of logical fields in this type.
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
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.ListTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
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.TupleTypeInfoBase
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getTotalInputSize() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the file size.
getTotalInputSize() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Gets the total size of the input.
getTotalNumberOfOpenStreams() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Gets the total number of open streams (input plus output).
getTotalNumberOfSplits() - Method in class org.apache.flink.core.io.GenericInputSplit
 
getTransitivePredecessors() - Method in class org.apache.flink.api.dag.Transformation
Returns all transitive predecessor Transformations of this Transformation.
getTtl() - Method in class org.apache.flink.api.common.state.StateTtlConfig
 
getTtlConfig() - Method in class org.apache.flink.api.common.state.StateDescriptor
 
getTtlTimeCharacteristic() - Method in class org.apache.flink.api.common.state.StateTtlConfig
 
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
 
getTupleClass() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
getType(int) - Method in class org.apache.flink.api.common.operators.Ordering
 
getType() - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.ListStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.StateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.ValueStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
getTypeAt(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the type of the (nested) field at the given field expression position.
getTypeAt(int) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the type of the (unnested) field at the given field position.
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.RowTypeInfo
 
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.common.typeinfo.BasicArrayTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Gets the class of the type represented by this type information.
getTypeClass() - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the type class of the composite type
getTypeClass() - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
getTypeClass(S) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
Gets the type class from the corresponding serializer.
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
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.ListTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getTypeClass(CopyableValueSerializer) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerSnapshot
 
getTypeClass(ValueSerializer) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerSnapshot
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getTypeException() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTypeHierarchy(List<Type>, Type, Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Traverses the type hierarchy of a type up until a certain stop class is found.
getTypeInfo() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
Gets the type information described by this TypeHint.
getTypeInfo() - Method in class org.apache.flink.util.OutputTag
 
getTypeInfoFactory(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Returns the type information factory for a type using the factory registry or annotations.
getTypeInfoFactory(Field) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Returns the type information factory for an annotated field.
getTypeInformation() - Method in class org.apache.flink.api.java.typeutils.PojoField
 
getTypes() - Method in class org.apache.flink.api.common.operators.Ordering
 
getTypeSerializer() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
Deprecated.
 
getUid() - Method in class org.apache.flink.api.dag.Transformation
Returns the user-specified ID of this transformation.
getUnaryOperatorReturnType(Function, Class<?>, int, int, int[], TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Returns the unary operator's return type.
getUnchecked() - Method in class org.apache.flink.util.OptionalFailure
 
getUnguardedFileSystem(URI) - Static method in class org.apache.flink.core.fs.FileSystem
 
getUnionListState(ListStateDescriptor<S>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Creates (or restores) a list state.
getUniqueFields() - Method in class org.apache.flink.api.common.operators.CompilerHints
Gets the FieldSets that are unique
getUnit() - Method in class org.apache.flink.api.common.time.Time
Gets the time unit for this policy's time interval.
getUnits() - Method in enum org.apache.flink.configuration.MemorySize.MemoryUnit
 
getUpdatedSplitForIterator(NumberSequenceIterator) - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
getUpdatedSplitForIterator(IterT) - Method in interface org.apache.flink.api.connector.source.lib.util.IteratorSourceSplit
Converts an iterator (that may have returned some elements already) back into a source split.
getUpdateType() - Method in class org.apache.flink.api.common.state.StateTtlConfig
 
getUpperPart() - Method in class org.apache.flink.util.AbstractID
Gets the upper 64 bits of the ID.
getUri() - Method in class org.apache.flink.core.fs.FileSystem
Returns a URI whose scheme and authority identify this file system.
getUri() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getUri() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getUri() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getUserCodeAnnotation(Class<A>) - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeAnnotation(Class<A>) - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeAnnotation(Class<A>) - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets an annotation that pertains to the user code class.
getUserCodeClass() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeClass() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeClass() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets the class of the user code.
getUserCodeClassLoader() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the ClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeClassLoader() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getUserCodeClassLoader() - Method in interface org.apache.flink.api.common.serialization.DeserializationSchema.InitializationContext
Gets the UserCodeClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeClassLoader() - Method in interface org.apache.flink.api.common.serialization.SerializationSchema.InitializationContext
Gets the UserCodeClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeClassLoader() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Deprecated.
Returns the user code class loader.
getUserCodeClassLoader() - Method in class org.apache.flink.api.connector.sink.InitContextInitializationContextAdapter
 
getUserCodeClassLoader() - Method in interface org.apache.flink.api.connector.sink.Sink.InitContext
Gets the UserCodeClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeClassLoader() - Method in interface org.apache.flink.api.connector.source.SourceReaderContext
Gets the UserCodeClassLoader to load classes that are not in system's classpath, but are part of the jar file of a user job.
getUserCodeObject(Class<? super T>, ClassLoader) - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeObject(Class<? super T>, ClassLoader) - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeObject(Class<? super T>, ClassLoader) - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets the user code object, which may be either a function or an input or output format.
getUserCodeObject() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets the user code object.
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Gets the function that is held by this operator.
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Gets the class describing the output format.
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Gets the class describing the input format.
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.Operator
Gets the user code wrapper.
getUserProvidedNodeHash() - Method in class org.apache.flink.api.dag.Transformation
Gets the user provided hash.
getValue() - Method in class org.apache.flink.api.common.resources.Resource
 
getValue(ConfigOption<?>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a string.
getValue(ConfigOption<?>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getValue() - Method in class org.apache.flink.types.BooleanValue
 
getValue() - Method in class org.apache.flink.types.ByteValue
Returns the value of the encapsulated byte.
getValue() - Method in class org.apache.flink.types.CharValue
Returns the value of the encapsulated char.
getValue() - Method in class org.apache.flink.types.DoubleValue
Returns the value of the encapsulated primitive double.
getValue() - Method in class org.apache.flink.types.FloatValue
Returns the value of the encapsulated primitive float.
getValue() - Method in class org.apache.flink.types.IntValue
Returns the value of the encapsulated int.
getValue() - Method in class org.apache.flink.types.LongValue
Returns the value of the encapsulated long.
getValue() - Method in class org.apache.flink.types.ShortValue
Returns the value of the encapsulated short.
getValue() - Method in class org.apache.flink.types.StringValue
Gets this StringValue as a String.
getValue() - Method in class org.apache.flink.util.LinkedOptionalMap.KeyValue
 
getValues() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
Returns an iterator over all values that belong to the current key.
getValueSerializer() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
Gets the serializer for the values in the state.
getValueSerializer() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
getValueTypeInfo() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
Gets the type information for the values in the map
getVersion() - Method in class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer.ConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
Deprecated.
 
getVersion() - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
Gets the version with which this serializer serializes.
getVersion() - Method in interface org.apache.flink.core.io.Versioned
Returns the version number of the object.
getWildcardIPAddress() - Static method in class org.apache.flink.util.NetUtils
Returns the wildcard address to listen on all interfaces.
getWithoutException(CompletableFuture<T>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Gets the result of a completable future without any exception thrown.
getWorkingDirectory() - Method in class org.apache.flink.core.fs.FileSystem
Returns the path of the file system's current working directory.
getWorkingDirectory() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
getWorkingDirectory() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getWorkingDirectory() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that represents the workset for the step function.
getWrappedDelegate() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
getWrappedDelegate() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
getWrappedDelegate() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getWrappedDelegate() - Method in interface org.apache.flink.util.WrappingProxy
 
getWriteMode() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
getWriterStateSerializer() - Method in interface org.apache.flink.api.connector.sink.Sink
Any stateful sink needs to provide this state serializer and implement SinkWriter.snapshotState(long) properly.
GLOBAL_JOB_PARAMETERS - Static variable in class org.apache.flink.configuration.PipelineOptions
 
GlobalCommitter<CommT,GlobalCommT> - Interface in org.apache.flink.api.connector.sink
The GlobalCommitter is responsible for creating and committing an aggregated committable, which we call global committable (see GlobalCommitter.combine(java.util.List<CommT>)).
GlobalConfiguration - Class in org.apache.flink.configuration
Global configuration object for Flink.
GlobalJobParameters() - Constructor for class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
 
GlobFilePathFilter - Class in org.apache.flink.api.common.io
Class for determining if a particular file should be included or excluded based on a set of include and exclude glob filters.
GlobFilePathFilter() - Constructor for class org.apache.flink.api.common.io.GlobFilePathFilter
Constructor for GlobFilePathFilter that will match all files
GlobFilePathFilter(List<String>, List<String>) - Constructor for class org.apache.flink.api.common.io.GlobFilePathFilter
Constructor for GlobFilePathFilter
gracefulShutdown(long, TimeUnit, ExecutorService...) - Static method in class org.apache.flink.util.ExecutorUtils
Gracefully shutdown the given ExecutorService.
GroupCombineFunction<IN,OUT> - Interface in org.apache.flink.api.common.functions
Generic interface used for combine functions ("combiners").
GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
Base operator for the combineGroup transformation.
GroupCombineOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
 
GroupReduceFunction<T,O> - Interface in org.apache.flink.api.common.functions
The interface for group reduce functions.
GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
 
GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
groupsFields(FieldSet) - Method in class org.apache.flink.api.common.operators.Ordering
 
GuavaFlinkConnectorRateLimiter - Class in org.apache.flink.api.common.io.ratelimiting
An implementation of FlinkConnectorRateLimiter that uses Guava's RateLimiter for rate limiting.
GuavaFlinkConnectorRateLimiter() - Constructor for class org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
 
GzipInflaterInputStreamFactory - Class in org.apache.flink.api.common.io.compression
Factory for input streams that decompress the GZIP compression format.
GzipInflaterInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 

H

HA_CLUSTER_ID - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
The ID of the Flink cluster, used to separate multiple Flink clusters Needs to be set for standalone clusters, is automatically inferred in YARN.
HA_JOB_DELAY - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
Deprecated.
Don't use this option anymore. It has no effect on Flink.
HA_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Ports used by the job manager if not in 'none' recovery mode.
HA_JOB_MANAGER_PORT_RANGE - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
Optional port (range) used by the job manager in high-availability mode.
HA_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of HighAvailabilityOptions.HA_MODE
HA_MODE - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
Defines high-availability mode used for the cluster execution.
HA_STORAGE_PATH - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
File system path (URI) where Flink persists metadata in high-availability setups.
HA_ZOOKEEPER_CHECKPOINT_COUNTER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
no longer used.
HA_ZOOKEEPER_CHECKPOINTS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
no longer used.
HA_ZOOKEEPER_CLIENT_ACL - Static variable in class org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
ZooKeeper root path (ZNode) for job graphs.
HA_ZOOKEEPER_LATCH_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
no longer used.
HA_ZOOKEEPER_LEADER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
no longer used.
HA_ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_MESOS_WORKERS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
HA_ZOOKEEPER_NAMESPACE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
HA_ZOOKEEPER_QUORUM - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
The ZooKeeper quorum to use, when running Flink in a high-availability mode with ZooKeeper.
HA_ZOOKEEPER_QUORUM_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_ROOT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
The root path under which Flink stores its entries in ZooKeeper.
HA_ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
HA_ZOOKEEPER_STORAGE_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
HADOOP_COPYING - Static variable in class org.apache.flink.api.common.io.FilePathFilter
Name of an unfinished Hadoop file
HALT_ON_FATAL_ERROR - Static variable in class org.apache.flink.configuration.ClusterOptions
 
handleAsyncIfNotDone(CompletableFuture<IN>, Executor, BiFunction<? super IN, Throwable, ? extends OUT>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a handler function for the result of this future.
handleException(CompletableFuture<? extends T>, Class<E>, Function<? super E, ? extends T>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Checks that the given CompletableFuture is not completed exceptionally with the specified class.
handleSourceEvent(int, SourceEvent) - Method in interface org.apache.flink.api.connector.source.SplitEnumerator
Handles a custom source event from the source reader.
handleSourceEvents(SourceEvent) - Method in interface org.apache.flink.api.connector.source.SourceReader
Handle a custom source event sent by the SplitEnumerator.
handleSplitRequest(int, String) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
handleSplitRequest(int, String) - Method in interface org.apache.flink.api.connector.source.SplitEnumerator
Handles the request for a split.
handleUncaughtException(CompletableFuture<?>, Thread.UncaughtExceptionHandler) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Checks that the given CompletableFuture is not completed exceptionally.
hasAbsentKeysOrValues() - Method in class org.apache.flink.util.LinkedOptionalMap
Checks whether there are entries with absent keys or values.
hasAutoGeneratedUIDsEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Checks whether auto generated UIDs are supported.
hasBroadcastVariable(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Tests for the existence of the broadcast variable identified by the given name.
hasBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
hasDefaultValue() - Method in class org.apache.flink.configuration.ConfigOption
Checks if this option has a default value.
hasDeprecatedKeys() - Method in class org.apache.flink.configuration.ConfigOption
Deprecated.
hasDeterministicFieldOrder() - Method in class org.apache.flink.api.common.typeutils.CompositeType
True if this type has an inherent ordering of the fields, such that a user can always be sure in which order the fields will be in.
hasDeterministicFieldOrder() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
hasFallbackKeys() - Method in class org.apache.flink.configuration.ConfigOption
Checks whether this option has fallback keys.
hasField(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns true when this type has a composite field with the given name.
hasGenericTypesDisabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Checks whether generic types are supported.
hash(boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
hash(byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
hash(char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
hash(double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
hash(float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
hash(int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
hash(long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
hash(short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
hash(T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
hash(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
hash(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
hash(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
hash(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
hash(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
hash(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
hash(LocalDate) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
hash(LocalDateTime) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
hash(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
hash(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
hash(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
hash(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
hash(T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Computes a hash value for the given record.
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.NullAwareComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
hash(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
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_JOIN_BLOOM_FILTERS - Static variable in class org.apache.flink.configuration.AlgorithmOptions
 
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.common.cache.DistributedCache.DistributedCacheEntry
 
hashCode() - Method in class org.apache.flink.api.common.eventtime.Watermark
 
hashCode() - Method in class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
 
hashCode() - Method in class org.apache.flink.api.common.ExecutionConfig
 
hashCode() - Method in class org.apache.flink.api.common.operators.Ordering
 
hashCode() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
hashCode() - Method in class org.apache.flink.api.common.operators.SlotSharingGroup
 
hashCode() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
hashCode() - Method in class org.apache.flink.api.common.operators.util.TypeComparable
 
hashCode() - Method in class org.apache.flink.api.common.resources.Resource
 
hashCode() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.ExponentialDelayRestartStrategyConfiguration
 
hashCode() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
hashCode() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
hashCode() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
hashCode() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
hashCode() - Method in class org.apache.flink.api.common.state.StateDescriptor
 
hashCode() - Method in class org.apache.flink.api.common.time.Time
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
Deprecated.
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
Deprecated.
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
hashCode() - Method in class org.apache.flink.api.connector.source.ReaderInfo
 
hashCode() - Method in class org.apache.flink.api.dag.Transformation
 
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.EitherTypeInfo
 
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.ListTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
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.RowTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
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.TupleSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
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.configuration.ConfigOption
 
hashCode() - Method in class org.apache.flink.configuration.Configuration
 
hashCode() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
hashCode() - Method in class org.apache.flink.configuration.FallbackKey
 
hashCode() - Method in class org.apache.flink.configuration.MemorySize
 
hashCode() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
hashCode() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
hashCode() - Method in class org.apache.flink.core.fs.FileInputSplit
 
hashCode() - Method in class org.apache.flink.core.fs.Path
 
hashCode() - Method in class org.apache.flink.core.io.GenericInputSplit
 
hashCode() - Method in class org.apache.flink.core.io.LocatableInputSplit
 
hashCode() - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
hashCode() - Method in class org.apache.flink.types.BooleanValue
 
hashCode() - Method in class org.apache.flink.types.ByteValue
 
hashCode() - Method in class org.apache.flink.types.CharValue
 
hashCode() - Method in class org.apache.flink.types.DoubleValue
 
hashCode() - Method in class org.apache.flink.types.Either.Left
 
hashCode() - Method in class org.apache.flink.types.Either.Right
 
hashCode() - Method in class org.apache.flink.types.FloatValue
 
hashCode() - Method in class org.apache.flink.types.IntValue
 
hashCode() - Method in interface org.apache.flink.types.Key
Deprecated.
All keys must override the hash-code function to generate proper deterministic hash codes, based on their contents.
hashCode() - Method in class org.apache.flink.types.ListValue
 
hashCode() - Method in class org.apache.flink.types.LongValue
 
hashCode() - Method in class org.apache.flink.types.MapValue
 
hashCode() - Method in class org.apache.flink.types.NullValue
 
hashCode() - Method in class org.apache.flink.types.Row
 
hashCode() - Method in class org.apache.flink.types.ShortValue
 
hashCode() - Method in class org.apache.flink.types.StringValue
 
hashCode() - Method in class org.apache.flink.util.AbstractID
 
hashCode() - Method in class org.apache.flink.util.OptionalFailure
 
hashCode() - Method in class org.apache.flink.util.OutputTag
 
hashCode() - Method in class org.apache.flink.util.SerializedValue
 
hashCode() - Method in class org.apache.flink.util.StringBasedID
 
hasMissingKeys() - Method in class org.apache.flink.util.LinkedOptionalMap.MergeResult
 
hasNext() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
 
hasNext() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
hasNext() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
hasNext() - Method in class org.apache.flink.util.CloseableIterator.IteratorAdapter
 
hasNext() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
hasNext() - Method in class org.apache.flink.util.NumberSequenceIterator
 
hasNext() - Method in class org.apache.flink.util.UnionIterator
 
hasObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
hasObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
hasObject() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Checks whether the wrapper already has an object, or whether it needs to instantiate it.
hasPublicNullaryConstructor(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Checks, whether the given class has a public nullary constructor.
hasSuperclass(Class<?>, String) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Returns true if the given class has a superclass of given name.
hasTimeLeft() - Method in class org.apache.flink.api.common.time.Deadline
Returns whether there is any time left between the deadline and now.
hasUnit(String) - Static method in enum org.apache.flink.configuration.MemorySize.MemoryUnit
 
hasWindowsDrive() - Method in class org.apache.flink.core.fs.Path
Checks if the provided path string contains a windows drive letter.
HDFS_DEFAULT_CONFIG - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use environment variable HADOOP_CONF_DIR instead.
HDFS_SITE_CONFIG - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use environment variable HADOOP_CONF_DIR instead.
HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.HeartbeatManagerOptions
Time interval for requesting heartbeat from sender side.
HEARTBEAT_RPC_FAILURE_THRESHOLD - Static variable in class org.apache.flink.configuration.HeartbeatManagerOptions
 
HEARTBEAT_TIMEOUT - Static variable in class org.apache.flink.configuration.HeartbeatManagerOptions
Timeout for requesting and receiving heartbeat for both sender and receiver sides.
HeartbeatManagerOptions - Class in org.apache.flink.configuration
The set of configuration options relating to heartbeat manager settings.
hexStringToByte(String) - Static method in class org.apache.flink.util.StringUtils
Given a hex string this will return the byte array corresponding to the string .
HIDDEN_CONTENT - Static variable in class org.apache.flink.configuration.GlobalConfiguration
 
hideSensitiveValues(Map<String, String>) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Replaces values whose keys are sensitive according to GlobalConfiguration.isSensitive(String) with GlobalConfiguration.HIDDEN_CONTENT.
HighAvailabilityOptions - Class in org.apache.flink.configuration
The set of configuration options relating to high-availability settings.
Histogram - Class in org.apache.flink.api.common.accumulators
Histogram accumulator, which builds a histogram in a distributed manner.
Histogram() - Constructor for class org.apache.flink.api.common.accumulators.Histogram
 
HISTORY_SERVER_ARCHIVE_DIRS - Static variable in class org.apache.flink.configuration.HistoryServerOptions
Comma-separated list of directories which the HistoryServer polls for new archives.
HISTORY_SERVER_ARCHIVE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The interval at which the HistoryServer polls HistoryServerOptions.HISTORY_SERVER_ARCHIVE_DIRS for new archives.
HISTORY_SERVER_CLEANUP_EXPIRED_JOBS - Static variable in class org.apache.flink.configuration.HistoryServerOptions
If this option is enabled then deleted job archives are also deleted from HistoryServer.
HISTORY_SERVER_RETAINED_JOBS - Static variable in class org.apache.flink.configuration.HistoryServerOptions
 
HISTORY_SERVER_WEB_ADDRESS - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The address under which the HistoryServer web-frontend is accessible.
HISTORY_SERVER_WEB_DIR - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The local directory used by the HistoryServer web-frontend.
HISTORY_SERVER_WEB_PORT - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The port under which the HistoryServer web-frontend is accessible.
HISTORY_SERVER_WEB_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The refresh interval for the HistoryServer web-frontend in milliseconds.
HISTORY_SERVER_WEB_SSL_ENABLED - Static variable in class org.apache.flink.configuration.HistoryServerOptions
Enables/Disables SSL support for the HistoryServer web-frontend.
HistoryServerOptions - Class in org.apache.flink.configuration
The set of configuration options relating to the HistoryServer.
HOST - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The external address of the network interface where the TaskManager is exposed.
HOST_BIND_POLICY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The config parameter for automatically defining the TaskManager's binding address, if TaskManagerOptions.HOST configuration option is not set.
hostAndPortToUrlString(String, int) - Static method in class org.apache.flink.util.NetUtils
Normalizes and encodes a hostname and port to be included in URL.
hours(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of hours.
HtmlFormatter - Class in org.apache.flink.configuration.description
Formatter that transforms Description into Html representation.
HtmlFormatter() - Constructor for class org.apache.flink.configuration.description.HtmlFormatter
 

I

id - Variable in class org.apache.flink.api.dag.Transformation
 
idCounter - Static variable in class org.apache.flink.api.dag.Transformation
 
IDLENESS_TIMEOUT - Static variable in class org.apache.flink.configuration.RestOptions
The maximum time in ms for a connection to stay idle before failing.
ifNotPresent(ThrowingRunnable<E>) - Method in class org.apache.flink.util.OptionalConsumer
 
ifPresent(Consumer<? super T>) - Method in class org.apache.flink.types.SerializableOptional
 
ifPresent(Consumer<T>) - Method in class org.apache.flink.util.OptionalConsumer
 
ignoreFn() - Static method in class org.apache.flink.util.function.FunctionUtils
Consumer which ignores the input.
IllegalConfigurationException - Exception in org.apache.flink.configuration
An IllegalConfigurationException is thrown when the values in a given Configuration are not valid.
IllegalConfigurationException(String) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
Constructs an new IllegalConfigurationException with the given error message.
IllegalConfigurationException(String, Object...) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
Constructs an new IllegalConfigurationException with the given error message format and arguments.
IllegalConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
Constructs an new IllegalConfigurationException with the given error message and a given cause.
immutableEntries() - Method in interface org.apache.flink.api.common.state.ReadOnlyBroadcastState
Returns an immutable Iterable over the entries in the state.
incompatible() - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns a result that indicates there is no possible way for the new serializer to be use-able.
IncompatibleKeysException(String) - Constructor for exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
 
IncompatibleKeysException(TypeInformation<?>, TypeInformation<?>) - Constructor for exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
 
INCREMENTAL_CHECKPOINTS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
Option whether the state backend should create incremental checkpoints, if possible.
IndexedCombinedWatermarkStatus - Class in org.apache.flink.api.common.eventtime
Represents combined value and status of a watermark for a set number of input partial watermarks.
indexes - Variable in class org.apache.flink.api.common.operators.Ordering
 
indexOf(Object) - Method in class org.apache.flink.types.ListValue
 
INFLATER_INPUT_STREAM_FACTORIES - Static variable in class org.apache.flink.api.common.io.FileInputFormat
A mapping of file extensions to decompression algorithms based on DEFLATE.
InflaterInputStreamFactory<T extends InputStream> - Interface in org.apache.flink.api.common.io.compression
Creates a new instance of a certain subclass of InflaterInputStream.
inFullSnapshot() - Method in class org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
IngestionTimeAssigner<T> - Class in org.apache.flink.api.common.eventtime
A timestamp assigner that assigns timestamps based on the machine's wall clock.
IngestionTimeAssigner() - Constructor for class org.apache.flink.api.common.eventtime.IngestionTimeAssigner
 
InitContextInitializationContextAdapter - Class in org.apache.flink.api.connector.sink
Adapter between Sink.InitContext and SerializationSchema.InitializationContext.
InitContextInitializationContextAdapter(UserCodeClassLoader, Supplier<MetricGroup>) - Constructor for class org.apache.flink.api.connector.sink.InitContextInitializationContextAdapter
 
initDefaultsFromConfiguration(Configuration) - Static method in class org.apache.flink.api.common.io.FileOutputFormat
Initialize defaults for output format.
INITIAL_REGISTRATION_BACKOFF - Static variable in class org.apache.flink.configuration.TaskManagerOptions
INITIAL_REGISTRATION_TIMEOUT - Static variable in class org.apache.flink.configuration.ClusterOptions
 
initialize(Configuration) - Static method in class org.apache.flink.core.fs.FileSystem
initialize(Configuration, PluginManager) - Static method in class org.apache.flink.core.fs.FileSystem
Initializes the shared file system settings.
initializeBroadcastVariable(Iterable<T>) - Method in interface org.apache.flink.api.common.functions.BroadcastVariableInitializer
The method that reads the data elements from the broadcast variable and creates the transformed data structure.
initializeFields(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
initializeGlobal(int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
Initialization of the distributed file system if it is used.
initializeGlobal(int) - Method in interface org.apache.flink.api.common.io.InitializeOnMaster
The method is invoked on the master (JobManager) before the distributed program execution starts.
InitializeOnMaster - Interface in org.apache.flink.api.common.io
This interface may be implemented by OutputFormats to have the master initialize them globally.
initializeSafetyNetForThread() - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
Activates the safety net for a thread.
initializeSerializerUnlessSet(ExecutionConfig) - Method in class org.apache.flink.api.common.state.StateDescriptor
Initializes the serializer, unless it has been initialized before.
initializeSplit(FileInputSplit, Long) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Initialization method that is called after opening or reopening an input split.
initializeSplit(FileInputSplit, Long) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
initializeTypeComparatorBuilder(int) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.FileSystem
Initializes output directories on distributed file systems according to the given write mode.
initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.FileSystem
Initializes output directories on local file systems according to the given write mode.
initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
InlineElement - Interface in org.apache.flink.configuration.description
Part of description that represents an element inside a block e.g.
InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
InnerJoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
InnerJoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
InnerJoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
input - Variable in class org.apache.flink.api.common.operators.GenericDataSinkBase
 
input - Variable in class org.apache.flink.api.common.operators.SingleInputOperator
The input which produces the data consumed by this operator.
input1 - Variable in class org.apache.flink.api.common.operators.DualInputOperator
The operator producing the first input.
input2 - Variable in class org.apache.flink.api.common.operators.DualInputOperator
The operator producing the second input.
InputDependencyConstraint - Enum in org.apache.flink.api.common
Deprecated.
InputDependencyConstraint is not used anymore and will be deleted in one of the future versions. It was previously used in the scheduler implementations that were removed as part of FLINK-20589.
InputFormat<OT,T extends InputSplit> - Interface in org.apache.flink.api.common.io
The base interface for data sources that produces records.
InputSplit - Interface in org.apache.flink.core.io
This interface must be implemented by all kind of input splits that can be assigned to input formats.
InputSplitAssigner - Interface in org.apache.flink.core.io
An input split assigner distributes the InputSplits among the instances on which a data source exists.
InputSplitOpenThread(FileInputSplit, long) - Constructor for class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
 
InputSplitSource<T extends InputSplit> - Interface in org.apache.flink.core.io
InputSplitSources create InputSplits that define portions of data to be produced by InputFormats.
InputStatus - Enum in org.apache.flink.core.io
An InputStatus indicates the availability of data from an asynchronous input.
inputStream - Variable in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
InputStreamFSInputWrapper - Class in org.apache.flink.api.common.io
This class wraps an InputStream and exposes it as FSDataInputStream.
InputStreamFSInputWrapper(InputStream) - Constructor for class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
inputType - Variable in class org.apache.flink.api.common.operators.UnaryOperatorInformation
Input Type of the operator
inputType1 - Variable in class org.apache.flink.api.common.operators.BinaryOperatorInformation
Input type of the first input
inputType2 - Variable in class org.apache.flink.api.common.operators.BinaryOperatorInformation
Input type of the second input
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
 
inRocksdbCompactFilter() - Method in class org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
insertOrReplace(BT) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
Sharable instance of the BooleanSerializer.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ByteSerializer
Sharable instance of the ByteSerializer.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.CharSerializer
Sharable instance of the CharSerializer.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
Sharable instance of the DoubleSerializer.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.FloatSerializer
Sharable instance of the FloatSerializer.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.IntSerializer
Sharable instance of the IntSerializer.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LongSerializer
Sharable instance of the LongSerializer.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ShortSerializer
Sharable instance of the ShortSerializer.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.StringSerializer
Sharable instance of the StringSerializer.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.VoidSerializer
Sharable instance of the VoidSerializer.
INSTANCE - Static variable in class org.apache.flink.api.java.tuple.Tuple0
 
INSTANCE - Static variable in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
INSTANCE - Static variable in class org.apache.flink.util.FatalExitExceptionHandler
 
INSTANT - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Instant.
INSTANT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
InstantComparator - Class in org.apache.flink.api.common.typeutils.base
Comparator for comparing Java Instant.
InstantComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.InstantComparator
 
instantiate(String, Class<T>, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
Creates a new instance of the given class name and type using the provided ClassLoader.
instantiate(Class<T>, Class<? super T>) - Static method in class org.apache.flink.util.InstantiationUtil
Creates a new instance of the given class.
instantiate(Class<T>) - Static method in class org.apache.flink.util.InstantiationUtil
Creates a new instance of the given class.
instantiateDeserializationUtils() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
InstantiationUtil - Class in org.apache.flink.util
Utility class to create instances from class objects and checking failure reasons.
InstantiationUtil.ClassLoaderObjectInputStream - Class in org.apache.flink.util
A custom ObjectInputStream that can load classes using a specific ClassLoader.
InstantiationUtil.FailureTolerantObjectInputStream - Class in org.apache.flink.util
An ObjectInputStream that ignores serialVersionUID mismatches when deserializing objects of anonymous classes or our Scala serializer classes and also replaces occurences of GenericData.Array (from Avro) by a dummy class so that the KryoSerializer can still be deserialized without Avro being on the classpath.
InstantSerializer - Class in org.apache.flink.api.common.typeutils.base
Serializer for serializing/deserializing Instant values including null values.
InstantSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
InstantSerializer.InstantSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
InstantSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.InstantSerializer.InstantSerializerSnapshot
 
INT - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive int and Integer.
INT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
INT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
INT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
INT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
IntComparator - Class in org.apache.flink.api.common.typeutils.base
 
IntComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.IntComparator
 
IntCounter - Class in org.apache.flink.api.common.accumulators
An accumulator that sums up Integer values.
IntCounter() - Constructor for class org.apache.flink.api.common.accumulators.IntCounter
 
IntCounter(int) - Constructor for class org.apache.flink.api.common.accumulators.IntCounter
 
IntegerTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for numeric integer primitive types: int, long, byte, short, character.
IntegerTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.IntegerTypeInfo
 
INTERCEPT_USER_SYSTEM_EXIT - Static variable in class org.apache.flink.configuration.ClusterOptions
 
IntMaximum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the maximum integer value.
IntMaximum() - Constructor for class org.apache.flink.api.common.accumulators.IntMaximum
 
IntMaximum(int) - Constructor for class org.apache.flink.api.common.accumulators.IntMaximum
 
IntMinimum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the minimum integer value.
IntMinimum() - Constructor for class org.apache.flink.api.common.accumulators.IntMinimum
 
IntMinimum(int) - Constructor for class org.apache.flink.api.common.accumulators.IntMinimum
 
IntParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a IntValue.
IntParser() - Constructor for class org.apache.flink.types.parser.IntParser
 
IntPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
IntPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
IntPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for int arrays.
IntPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
IntPrimitiveArraySerializer.IntPrimitiveArraySerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base.array
Serializer configuration snapshot for compatibility and format evolution.
IntPrimitiveArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer.IntPrimitiveArraySerializerSnapshot
 
IntSerializer - Class in org.apache.flink.api.common.typeutils.base
Type serializer for Integer (and int, via auto-boxing).
IntSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.IntSerializer
 
IntSerializer.IntSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
IntSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.IntSerializer.IntSerializerSnapshot
 
intType() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Integer type.
IntValue - Class in org.apache.flink.types
Boxed serializable and comparable integer type, representing the primitive type int.
IntValue() - Constructor for class org.apache.flink.types.IntValue
Initializes the encapsulated int with 0.
IntValue(int) - Constructor for class org.apache.flink.types.IntValue
Initializes the encapsulated int with the provided value.
IntValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for IntValue based on CopyableValueComparator.
IntValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
IntValueParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a IntValue.
IntValueParser() - Constructor for class org.apache.flink.types.parser.IntValueParser
 
IntValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
IntValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
IntValueSerializer.IntValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
IntValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.IntValueSerializer.IntValueSerializerSnapshot
 
InvalidFieldReferenceException(String) - Constructor for exception org.apache.flink.api.common.typeutils.CompositeType.InvalidFieldReferenceException
 
invalidLineCount - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
InvalidProgramException - Exception in org.apache.flink.api.common
An exception thrown to indicate that the composed program is invalid.
InvalidProgramException() - Constructor for exception org.apache.flink.api.common.InvalidProgramException
Creates a new exception with no message.
InvalidProgramException(String) - Constructor for exception org.apache.flink.api.common.InvalidProgramException
Creates a new exception with the given message.
InvalidProgramException(String, Throwable) - Constructor for exception org.apache.flink.api.common.InvalidProgramException
Creates a new exception with the given message and cause.
InvalidSemanticAnnotationException(String) - Constructor for exception org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
 
InvalidSemanticAnnotationException(String, Throwable) - Constructor for exception org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
 
InvalidTypesException - Exception in org.apache.flink.api.common.functions
A special case of the InvalidProgramException, indicating that the types used in an operation are invalid or inconsistent.
InvalidTypesException() - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
Creates a new exception with no message.
InvalidTypesException(String) - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
Creates a new exception with the given message.
InvalidTypesException(String, Throwable) - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Flag whether normalized key comparisons should be inverted key should be interpreted inverted, i.e.
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.NullAwareComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
invertNormKey - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
IOReadableWritable - Interface in org.apache.flink.core.io
This interface must be implemented by every class whose objects have to be serialized to their binary representation and vice-versa.
IOUtils - Class in org.apache.flink.util
An utility class for I/O related functionality.
ipAddressAndPortToUrlString(InetAddress, int) - Static method in class org.apache.flink.util.NetUtils
Encodes an IP address and port to be included in URL.
ipAddressToUrlString(InetAddress) - Static method in class org.apache.flink.util.NetUtils
Encodes an IP address properly as a URL string.
IPC_PORT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
Defines the network port to connect to for communication with the resource manager.
isAbsolute() - Method in class org.apache.flink.core.fs.Path
Checks if the directory of this path is absolute.
isAdaptiveSchedulerEnabled(Configuration) - Static method in class org.apache.flink.configuration.ClusterOptions
 
isAutoTypeRegistrationDisabled() - Method in class org.apache.flink.api.common.ExecutionConfig
 
isAvailable() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
isAvailable() - Method in interface org.apache.flink.api.connector.source.SourceReader
Returns a future that signals that data is available from the reader.
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Checks if this type information represents a basic type.
isBasicType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
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.ListTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
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.TupleTypeInfoBase
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isBasicValueType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isCancelled() - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
 
isCaseClass() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isClassType(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks if a type can be converted to a Class.
isCleanupInBackground() - Method in class org.apache.flink.api.common.state.StateTtlConfig.CleanupStrategies
 
isCloseableRegistered(Closeable) - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
isClosed() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
isClosed() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
isClosed() - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
isClosed() - Method in class org.apache.flink.util.ResourceGuard
Returns true if the resource guard is closed, i.e.
isClosureCleanerEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns whether the ClosureCleaner is enabled.
isCombinable() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Checks whether the operation is combinable.
isCombinableFirst() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
isCombinableFirst() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
isCombinableSecond() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
isCombinableSecond() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
isCompatibleAfterMigration() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
isCompatibleAfterMigration() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns whether or not the type of the compatibility is Type#COMPATIBLE_AFTER_MIGRATION.
isCompatibleAsIs() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
isCompatibleAsIs() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns whether or not the type of the compatibility is Type#COMPATIBLE_AS_IS.
isCompatibleWith(Configuration) - Method in interface org.apache.flink.core.execution.PipelineExecutorFactory
Returns true if this factory is compatible with the options in the provided configuration, false otherwise.
isCompatibleWithReconfiguredSerializer() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
isCompatibleWithReconfiguredSerializer() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns whether or not the type of the compatibility is Type#COMPATIBLE_WITH_RECONFIGURED_SERIALIZER.
isCompletedNormally(CompletableFuture<?>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
 
isConverged(int, T) - Method in interface org.apache.flink.api.common.aggregators.ConvergenceCriterion
Decide whether the iterative algorithm has converged
isConverged(int, DoubleValue) - Method in class org.apache.flink.api.common.aggregators.DoubleZeroConvergence
Returns true, if the aggregator value is zero, false otherwise.
isConverged(int, LongValue) - Method in class org.apache.flink.api.common.aggregators.LongZeroConvergence
Returns true, if the aggregator value is zero, false otherwise.
isConverged(int, LongValue) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
 
isDeprecated() - Method in class org.apache.flink.configuration.FallbackKey
 
isDir() - Method in interface org.apache.flink.core.fs.FileStatus
Checks if this object represents a directory.
isDir() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
isDirectOutOfMemoryError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a JVM direct out-of-memory error.
isDistributedFS() - Method in class org.apache.flink.core.fs.FileSystem
Returns true if this is a distributed file system.
isDistributedFS() - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
isDistributedFS() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
isDistributedFS() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
isDone() - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
 
isDummy() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
isEmpty() - Method in class org.apache.flink.api.common.operators.Keys
 
isEmpty() - Method in interface org.apache.flink.api.common.state.MapState
Returns true if this state contains no key-value mappings, otherwise false.
isEmpty() - Method in class org.apache.flink.types.ListValue
 
isEmpty() - Method in class org.apache.flink.types.MapValue
 
isEnabled() - Method in class org.apache.flink.api.common.state.StateTtlConfig
 
isEndOfStream(T) - Method in class org.apache.flink.api.common.serialization.AbstractDeserializationSchema
Method to decide whether the element signals the end of the stream.
isEndOfStream(T) - Method in interface org.apache.flink.api.common.serialization.DeserializationSchema
Method to decide whether the element signals the end of the stream.
isEndOfStream(String) - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
 
isEndOfStream(T) - Method in class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
This schema never considers an element to signal end-of-stream, so this method returns always false.
isEntropyInjecting(FileSystem) - Static method in class org.apache.flink.core.fs.EntropyInjector
 
isExactMatch(FieldList) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
isExecutable - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
isFailure() - Method in class org.apache.flink.util.OptionalFailure
 
isFineGrainedResourceManagementEnabled(Configuration) - Static method in class org.apache.flink.configuration.ClusterOptions
 
isForceAvroEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns whether the Apache Avro is the default serializer for POJOs.
isForceKryoEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
 
isFreeBSD() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is FreeBSD.
isFreed() - Method in class org.apache.flink.core.memory.MemorySegment
Checks whether the memory segment was freed.
isGloballyTerminalState() - Method in enum org.apache.flink.api.common.JobStatus
Checks whether this state is globally terminal.
isHeapSpaceOutOfMemoryError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
 
isIdle() - Method in class org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Gets whether the type is an immutable type.
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
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.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
isIncompatible() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
 
isIncompatible() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
Returns whether or not the type of the compatibility is Type#INCOMPATIBLE.
isInternalSSLEnabled(Configuration) - Static method in class org.apache.flink.configuration.SecurityOptions
Checks whether SSL for internal communication (rpc, data transport, blob server) is enabled.
isJarFile(Path) - Static method in class org.apache.flink.util.FileUtils
Checks whether the given file has a jar extension.
isJobExecutionResult() - Method in class org.apache.flink.api.common.JobExecutionResult
 
isJobExecutionResult() - Method in class org.apache.flink.api.common.JobSubmissionResult
Checks if this JobSubmissionResult is also a JobExecutionResult.
isJobExecutionResult() - Method in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
isJvmFatalError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a situation that may leave the JVM in a corrupted state, meaning a state where continued normal operation can only be guaranteed via clean process restart.
isJvmFatalOrOutOfMemoryError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a situation that may leave the JVM in a corrupted state, or an out-of-memory error.
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Checks whether this type can be used as a key.
isKeyType() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
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.ListTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
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.ValueTypeInfo
 
isLatencyTrackingConfigured() - Method in class org.apache.flink.api.common.ExecutionConfig
 
isLeft() - Method in class org.apache.flink.types.Either
 
isLenient() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
isLinux() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Linux.
isMac() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Windows.
isMetaspaceOutOfMemoryError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a JVM metaspace out-of-memory error.
isMetBy(Ordering) - Method in class org.apache.flink.api.common.operators.Ordering
 
isNonStaticInnerClass(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Checks, whether the class is an inner class that is not statically accessible.
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.InstantComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Checks, whether the given number of bytes for a normalized is only a prefix to determine the order of elements of the data type for which this comparator provides the comparison methods.
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.NullAwareComparator
 
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.RowComparator
 
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
 
isNull(int) - Method in class org.apache.flink.types.Record
 
isNullOrEmpty(Collection<?>) - Static method in class org.apache.flink.util.CollectionUtil
 
isNullOrEmpty(Map<?, ?>) - Static method in class org.apache.flink.util.CollectionUtil
 
isNullOrWhitespaceOnly(String) - Static method in class org.apache.flink.util.StringUtils
Checks if the string is null, empty, or contains only whitespace characters.
isObjectReuseEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns whether object reuse has been enabled or disabled.
isOffHeap() - Method in class org.apache.flink.core.memory.MemorySegment
Checks whether this memory segment is backed by off-heap memory.
isOrdered() - Method in enum org.apache.flink.api.common.operators.Order
Checks, if this enum constant represents in fact an order.
isOrderedSubset() - Method in class org.apache.flink.util.LinkedOptionalMap.MergeResult
Returns true if keyNames present at @left, appearing in prefix order at @right.
isOrderEqualOnFirstNFields(Ordering, int) - Method in class org.apache.flink.api.common.operators.Ordering
 
isOuterSnapshotCompatible(S) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Deprecated.
this method is deprecated, and will be removed in the future. Please implement CompositeTypeSerializerSnapshot.resolveOuterSchemaCompatibility(TypeSerializer) instead.
isOverdue() - Method in class org.apache.flink.api.common.time.Deadline
Determines whether the deadline is in the past, i.e.
isPowerOf2(long) - Static method in class org.apache.flink.util.MathUtils
Checks whether the given value is a power of two.
isPresent() - Method in class org.apache.flink.types.SerializableOptional
 
isProperClass(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Checks, whether the class is a proper class, i.e.
isPublic(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Checks, whether the given class is public.
isQueryable() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns whether the state created from this descriptor is queryable.
isResponsibleFor(OutputTag<?>, OutputTag<?>) - Static method in class org.apache.flink.util.OutputTag
 
isRestSSLAuthenticationEnabled(Configuration) - Static method in class org.apache.flink.configuration.SecurityOptions
Checks whether mutual SSL authentication for the external REST endpoint is enabled.
isRestSSLEnabled(Configuration) - Static method in class org.apache.flink.configuration.SecurityOptions
Checks whether SSL for the external REST endpoint is enabled.
isRight() - Method in class org.apache.flink.types.Either
 
isSensitive(String) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Check whether the key is a hidden key.
isSerializable(Object) - Static method in class org.apache.flink.util.InstantiationUtil
 
isSerializerInitialized() - Method in class org.apache.flink.api.common.state.StateDescriptor
Checks whether the serializer has been initialized.
isSkippingFirstLineAsHeader() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
isSolaris() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Solaris.
isSolutionSetUnManaged() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
gets whether the solution set is in managed or unmanaged memory.
isSortKey(int, TypeInformation<?>) - Static method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
isSortKey(String, TypeInformation<?>) - Static method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
isSortKeyType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Checks whether this type can be used as a key for sorting.
isSortKeyType() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
isSortKeyType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
isTerminalState() - Method in enum org.apache.flink.api.common.JobStatus
Checks whether this state is locally terminal.
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Checks if this type information represents a Tuple type.
isTupleType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
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.ListTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
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.TupleTypeInfoBase
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isUseSnapshotCompression() - Method in class org.apache.flink.api.common.ExecutionConfig
 
isValidClientPort(int) - Static method in class org.apache.flink.util.NetUtils
Check whether the given port is in right range when connecting to somewhere.
isValidHostPort(int) - Static method in class org.apache.flink.util.NetUtils
check whether the given port is in right range when getting port from local system.
isValidSubset(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
isValidSubset(FieldList) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
isValidSubset(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
Checks if the given set of fields is a valid subset of this set of fields.
isValidUnorderedPrefix(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
isWindows() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Windows.
isZero() - Method in class org.apache.flink.api.common.resources.Resource
 
isZipped - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
IterableIterator<E> - Interface in org.apache.flink.util
An Iterator that is also Iterable (often by returning itself).
iterableToList(Iterable<E>) - Static method in class org.apache.flink.util.CollectionUtil
Collects the elements in the Iterable in a List.
IterableUtils - Class in org.apache.flink.util
A collection of utilities that expand the usage of Iterable.
IterationOperator - Interface in org.apache.flink.api.common.operators
 
IterationRuntimeContext - Interface in org.apache.flink.api.common.functions
A specialization of the RuntimeContext available in iterative computations of the DataSet API.
iterator() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
 
iterator() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable
 
iterator() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
iterator() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
iterator() - Method in interface org.apache.flink.api.common.state.BroadcastState
Iterates over all the mappings in the state.
iterator() - Method in interface org.apache.flink.api.common.state.MapState
Iterates over all the mappings in the state.
iterator() - Method in class org.apache.flink.types.ListValue
 
iterator() - Method in class org.apache.flink.util.CloseableIterable.Empty
 
iterator() - Method in class org.apache.flink.util.UnionIterator
 
IteratorSourceEnumerator<SplitT extends IteratorSourceSplit<?,?>> - Class in org.apache.flink.api.connector.source.lib.util
A SplitEnumerator for iterator sources.
IteratorSourceEnumerator(SplitEnumeratorContext<SplitT>, Collection<SplitT>) - Constructor for class org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
IteratorSourceReader<E,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>> - Class in org.apache.flink.api.connector.source.lib.util
A SourceReader that returns the values of an iterator, supplied via an IteratorSourceSplit.
IteratorSourceReader(SourceReaderContext) - Constructor for class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
IteratorSourceSplit<E,IterT extends Iterator<E>> - Interface in org.apache.flink.api.connector.source.lib.util
A SourceSplit that represents a sequence of elements captured in an iterator.
iteratorToList(Iterator<E>) - Static method in class org.apache.flink.util.CollectionUtil
Collects the elements in the Iterator in a List.

J

JARS - Static variable in class org.apache.flink.configuration.PipelineOptions
A list of jar files that contain the user-defined function (UDF) classes and all classes used from within the UDFs.
JarUtils - Class in org.apache.flink.util
Utility functions for jar files.
JarUtils() - Constructor for class org.apache.flink.util.JarUtils
 
JavaEitherSerializerSnapshot<L,R> - Class in org.apache.flink.api.java.typeutils.runtime
Snapshot class for the EitherSerializer.
JavaEitherSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
Constructor for read instantiation.
JavaEitherSerializerSnapshot(EitherSerializer<L, R>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
Constructor to create the snapshot for writing.
JavaSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
This is a reimplementation of Kryo's JavaSerializer, that additionally makes sure the ObjectInputStream used for deserialization specifically uses Kryo's registered classloader.
JavaSerializer() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
 
JavaToValueConverter - Class in org.apache.flink.types
 
JavaToValueConverter() - Constructor for class org.apache.flink.types.JavaToValueConverter
 
jenkinsHash(int) - Static method in class org.apache.flink.util.MathUtils
This function hashes an integer value.
JMX_SERVER_PORT - Static variable in class org.apache.flink.configuration.JMXServerOptions
Port configured to enable JMX server for metrics and debugging.
JMXServerOptions - Class in org.apache.flink.configuration
The set of configuration options relating to JMX server.
JMXService - Class in org.apache.flink.management.jmx
Provide a JVM-wide singleton JMX Service.
JMXService() - Constructor for class org.apache.flink.management.jmx.JMXService
 
JOB_LISTENERS - Static variable in class org.apache.flink.configuration.DeploymentOptions
 
JOB_MANAGER_FUTURE_POOL_SIZE - Static variable in class org.apache.flink.configuration.JobManagerOptions
 
JOB_MANAGER_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.JobManagerOptions
Deprecated.
use JobManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and JobManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups.
JOB_MANAGER_HEAP_MEMORY_MB - Static variable in class org.apache.flink.configuration.JobManagerOptions
Deprecated.
use JobManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and JobManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups.
JOB_MANAGER_IO_POOL_SIZE - Static variable in class org.apache.flink.configuration.JobManagerOptions
 
JOB_MANAGER_IPC_ADDRESS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_IPC_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_BACK_PRESSURE_CLEAN_UP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
- no longer used.
JOB_MANAGER_WEB_BACK_PRESSURE_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
- no longer used.
JOB_MANAGER_WEB_BACK_PRESSURE_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
- no longer used.
JOB_MANAGER_WEB_BACK_PRESSURE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
- no longer used.
JOB_MANAGER_WEB_CHECKPOINTS_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not possible to disable any longer. Use history size of 0.
JOB_MANAGER_WEB_CHECKPOINTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_LOG_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use WebOptions.LOG_PATH instead.
JOB_MANAGER_WEB_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use WebOptions.PORT instead.
JOB_MANAGER_WEB_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_SUBMIT_ENABLED_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_TMPDIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use WebOptions.TMP_DIR instead.
JOB_MANAGER_WEB_UPLOAD_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_RESULT_MESSAGE - Static variable in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
JOB_STORE_CACHE_SIZE - Static variable in class org.apache.flink.configuration.JobManagerOptions
The job store cache size in bytes which is used to keep completed jobs in memory.
JOB_STORE_EXPIRATION_TIME - Static variable in class org.apache.flink.configuration.JobManagerOptions
The time in seconds after which a completed job expires and is purged from the job store.
JOB_STORE_MAX_CAPACITY - Static variable in class org.apache.flink.configuration.JobManagerOptions
The max number of completed jobs that can be kept in the job store.
JOB_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
Timeout for jobs which don't have a job manager as leader assigned.
JobClient - Interface in org.apache.flink.core.execution
A client that is scoped to a specific job.
JobExecutionResult - Class in org.apache.flink.api.common
The result of a job execution.
JobExecutionResult(JobID, long, Map<String, OptionalFailure<Object>>) - Constructor for class org.apache.flink.api.common.JobExecutionResult
Creates a new JobExecutionResult.
JobID - Class in org.apache.flink.api.common
Unique (at least statistically unique) identifier for a Flink Job.
JobID() - Constructor for class org.apache.flink.api.common.JobID
Creates a new (statistically) random JobID.
JobID(long, long) - Constructor for class org.apache.flink.api.common.JobID
Creates a new JobID, using the given lower and upper parts.
JobID(byte[]) - Constructor for class org.apache.flink.api.common.JobID
Creates a new JobID from the given byte sequence.
JobListener - Interface in org.apache.flink.core.execution
A listener that is notified on specific job status changed, which should be firstly registered by #registerJobListener of execution environments.
JobManagerOptions - Class in org.apache.flink.configuration
Configuration options for the JobManager.
JobManagerOptions.SchedulerType - Enum in org.apache.flink.configuration
Type of scheduler implementation.
jobName - Variable in class org.apache.flink.api.common.Plan
The name of the job.
JobStatus - Enum in org.apache.flink.api.common
Possible states of a job once it has been accepted by the dispatcher.
JobSubmissionResult - Class in org.apache.flink.api.common
The result of submitting a job to a JobManager.
JobSubmissionResult(JobID) - Constructor for class org.apache.flink.api.common.JobSubmissionResult
 
join(IN1, IN2, Collector<OUT>) - Method in interface org.apache.flink.api.common.functions.FlatJoinFunction
The join method, called once per joined pair of elements.
join(IN1, IN2) - Method in interface org.apache.flink.api.common.functions.JoinFunction
The join method, called once per joined pair of elements.
join(IN1, IN2, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichFlatJoinFunction
 
join(IN1, IN2) - Method in class org.apache.flink.api.common.functions.RichJoinFunction
 
join(Row, Row...) - Static method in class org.apache.flink.types.Row
Creates a new row with fields that are copied from the other rows and appended to the resulting row in the given order.
JoinFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
Interface for Join functions.
JoinHashMap<BT> - Class in org.apache.flink.api.common.operators.util
 
JoinHashMap(TypeSerializer<BT>, TypeComparator<BT>) - Constructor for class org.apache.flink.api.common.operators.util.JoinHashMap
 
JoinHashMap.Prober<PT> - Class in org.apache.flink.api.common.operators.util
 
JoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
JoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
JoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
JoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
JoinOperatorBase.JoinHint - Enum in org.apache.flink.api.common.operators.base
An enumeration of hints, optionally usable to tell the system how exactly execute the join.
JVM_DIRECT_MEMORY_LIMIT_ENABLED - Static variable in class org.apache.flink.configuration.JobManagerOptions
Off-heap Memory size for the JobManager.
JVM_EXIT_ON_FATAL_ERROR - Static variable in class org.apache.flink.configuration.AkkaOptions
Exit JVM on fatal Akka errors.
JVM_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.JobManagerOptions
JVM Heap Memory size for the JobManager.
JVM_METASPACE - Static variable in class org.apache.flink.configuration.JobManagerOptions
JVM Metaspace Size for the JobManager.
JVM_METASPACE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
JVM Metaspace Size for the TaskExecutors.
JVM_OVERHEAD_FRACTION - Static variable in class org.apache.flink.configuration.JobManagerOptions
Fraction of Total Process Memory to be reserved for JVM Overhead.
JVM_OVERHEAD_FRACTION - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Fraction of Total Process Memory to be reserved for JVM Overhead.
JVM_OVERHEAD_MAX - Static variable in class org.apache.flink.configuration.JobManagerOptions
Max JVM Overhead size for the TaskExecutors.
JVM_OVERHEAD_MAX - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Max JVM Overhead size for the TaskExecutors.
JVM_OVERHEAD_MIN - Static variable in class org.apache.flink.configuration.JobManagerOptions
Min JVM Overhead size for the JobManager.
JVM_OVERHEAD_MIN - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Min JVM Overhead size for the TaskExecutors.

K

KERBEROS_FETCH_DELEGATION_TOKEN - Static variable in class org.apache.flink.configuration.SecurityOptions
 
KERBEROS_KRB5_PATH - Static variable in class org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_CONTEXTS - Static variable in class org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_KEYTAB - Static variable in class org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_PRINCIPAL - Static variable in class org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_USETICKETCACHE - Static variable in class org.apache.flink.configuration.SecurityOptions
 
key() - Method in class org.apache.flink.configuration.ConfigOption
Gets the configuration key.
key(String) - Static method in class org.apache.flink.configuration.ConfigOptions
Starts building a new ConfigOption.
Key<T> - Interface in org.apache.flink.types
Deprecated.
The Key type is a relict of a deprecated and removed API and will be removed in future (2.0) versions as well.
KeyedStateStore - Interface in org.apache.flink.api.common.state
This interface contains methods for registering keyed state with a managed store.
KeyFieldOutOfBoundsException - Exception in org.apache.flink.types
An exception specifying that a required key field was not set in a record, i.e.
KeyFieldOutOfBoundsException() - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
Constructs an KeyFieldOutOfBoundsException with null as its error detail message.
KeyFieldOutOfBoundsException(String) - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
Constructs an KeyFieldOutOfBoundsException with the specified detail message.
KeyFieldOutOfBoundsException(int) - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
Constructs an KeyFieldOutOfBoundsException with a default message, referring to given field number as the null key field.
KeyFieldOutOfBoundsException(int, Throwable) - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
 
keyNames() - Method in class org.apache.flink.util.LinkedOptionalMap
Returns the key names added to this map.
keyPositions - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
key positions describe which fields are keys in what order
Keys<T> - Class in org.apache.flink.api.common.operators
 
Keys() - Constructor for class org.apache.flink.api.common.operators.Keys
 
keys() - Method in interface org.apache.flink.api.common.state.MapState
Returns all the keys in the state.
Keys.ExpressionKeys<T> - Class in org.apache.flink.api.common.operators
Represents (nested) field access through string and integer-based keys
Keys.IncompatibleKeysException - Exception in org.apache.flink.api.common.operators
 
Keys.SelectorFunctionKeys<T,K> - Class in org.apache.flink.api.common.operators
 
KeySelector<IN,KEY> - Interface in org.apache.flink.api.java.functions
The KeySelector allows to use deterministic objects for operations such as reduce, reduceGroup, join, coGroup, etc.
keySet() - Method in class org.apache.flink.configuration.Configuration
Returns the keys of all key/value pairs stored inside this configuration object.
keySet() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
keySet() - Method in class org.apache.flink.types.MapValue
 
KILL_ON_OUT_OF_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Whether to kill the TaskManager when the task thread throws an OutOfMemoryError.
KRYO_DEFAULT_SERIALIZERS - Static variable in class org.apache.flink.configuration.PipelineOptions
 
KRYO_REGISTERED_CLASSES - Static variable in class org.apache.flink.configuration.PipelineOptions
 
KryoRegistration - Class in org.apache.flink.api.java.typeutils.runtime
A KryoRegistration resembles a registered class and its serializer in Kryo.
KryoRegistration(Class<?>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
KryoRegistration(Class<?>, Class<? extends Serializer<?>>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
KryoRegistration(Class<?>, ExecutionConfig.SerializableSerializer<? extends Serializer<?>>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
KryoRegistration.SerializerDefinitionType - Enum in org.apache.flink.api.java.typeutils.runtime
IMPORTANT: the order of the enumerations must not change, since their ordinals are used for serialization.
KryoRegistrationSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
Configuration snapshot base class for serializers that use Kryo for serialization.
KryoRegistrationSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
KryoRegistrationSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, KryoRegistration>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass<RC> - Class in org.apache.flink.api.java.typeutils.runtime
Placeholder dummy for a previously registered Kryo serializer that is no longer valid or in classpath on restore.
KryoRegistrationSerializerConfigSnapshot.DummyRegisteredClass - Class in org.apache.flink.api.java.typeutils.runtime
Placeholder dummy for a previously registered class that can no longer be found in classpath on restore.
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.
KryoSerializer.KryoSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
Deprecated.
KryoSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
KryoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, KryoRegistration>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
Deprecated.
 
KryoSerializerSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
KryoSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
KryoUtils - Class in org.apache.flink.api.java.typeutils.runtime
Convenience methods for Kryo
KryoUtils() - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoUtils
 

L

LambdaExecutable(Constructor<?>) - Constructor for class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
LambdaExecutable(Method) - Constructor for class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
LambdaUtil - Class in org.apache.flink.util
This class offers utility functions for Java's lambda features.
lastIndexOf(Object) - Method in class org.apache.flink.types.ListValue
 
LATENCY_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.MetricOptions
The number of measured latencies to maintain at each operator.
LATENCY_INTERVAL - Static variable in class org.apache.flink.configuration.MetricOptions
 
LATENCY_SOURCE_GRANULARITY - Static variable in class org.apache.flink.configuration.MetricOptions
 
LATENCY_TRACK_ENABLED - Static variable in class org.apache.flink.configuration.StateBackendOptions
 
LATENCY_TRACK_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.StateBackendOptions
 
LATENCY_TRACK_SAMPLE_INTERVAL - Static variable in class org.apache.flink.configuration.StateBackendOptions
 
Left(L) - Static method in class org.apache.flink.types.Either
Create a Left value of Either
left() - Method in class org.apache.flink.types.Either
Retrieve the Left value of Either.
Left(L) - Constructor for class org.apache.flink.types.Either.Left
 
left() - Method in class org.apache.flink.types.Either.Left
 
left() - Method in class org.apache.flink.types.Either.Right
 
legacyReadNestedSerializerSnapshots(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Reads the composite snapshot of all the contained serializers in a way that is compatible with Version 1 of the deprecated CompositeTypeSerializerConfigSnapshot.
LegacySerializerSnapshotTransformer<T> - Interface in org.apache.flink.api.common.typeutils
This interface provides a way for TypeSerializers to transform a legacy TypeSerializerSnapshot used in versions before Flink 1.7 during deserialization.
length() - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
length() - Method in class org.apache.flink.types.StringValue
 
lessThanOrEqual(ResourceSpec) - Method in class org.apache.flink.api.common.operators.ResourceSpec
Checks the current resource less than or equal with the other resource by comparing all the fields in the resource.
LIBRARY_CACHE_MANAGER_CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
LimitedConnectionsFileSystem - Class in org.apache.flink.core.fs
A file system that limits the number of concurrently open input streams, output streams, and total streams for a target file system.
LimitedConnectionsFileSystem(FileSystem, int) - Constructor for class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Creates a new output connection limiting file system.
LimitedConnectionsFileSystem(FileSystem, int, long, long) - Constructor for class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Creates a new output connection limiting file system.
LimitedConnectionsFileSystem(FileSystem, int, int, int, long, long) - Constructor for class org.apache.flink.core.fs.LimitedConnectionsFileSystem
Creates a new output connection limiting file system, limiting input and output streams with potentially different quotas.
LimitedConnectionsFileSystem.ConnectionLimitingSettings - Class in org.apache.flink.core.fs
A simple configuration data object capturing the settings for limited connections.
LimitedConnectionsFileSystem.StreamTimeoutException - Exception in org.apache.flink.core.fs
A special IOException, indicating a timeout in the data output stream.
limitInput - Variable in class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The limit for the number of input stream connections, or 0, if no limit.
limitOutput - Variable in class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The limit for the number of output stream connections, or 0, if no limit.
limitTotal - Variable in class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The limit for the total number of connections, or 0, if no limit.
linebreak() - Method in class org.apache.flink.configuration.description.Description.DescriptionBuilder
Creates a line break in the description.
linebreak() - Static method in class org.apache.flink.configuration.description.LineBreakElement
Creates a line break in the description.
LineBreakElement - Class in org.apache.flink.configuration.description
Represents a line break in the Description.
lineDelimiterIsLinebreak - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
link(String, String) - Static method in class org.apache.flink.configuration.description.LinkElement
Creates a link with a given url and description.
link(String) - Static method in class org.apache.flink.configuration.description.LinkElement
Creates a link with a given url.
LinkedOptionalMap<K,V> - Class in org.apache.flink.util
A LinkedOptionalMap is an order preserving map (like LinkedHashMap) where keys have a unique string name, but are optionally present, and the values are optional.
LinkedOptionalMap() - Constructor for class org.apache.flink.util.LinkedOptionalMap
 
LinkedOptionalMap(int) - Constructor for class org.apache.flink.util.LinkedOptionalMap
 
LinkedOptionalMap.ConsumerWithException<K,V,E extends Throwable> - Interface in org.apache.flink.util
A Consumer that throws exceptions.
LinkedOptionalMap.KeyValue<K,V> - Class in org.apache.flink.util
Key-value pairs stored by the underlying map.
LinkedOptionalMap.MergeResult<K,V> - Class in org.apache.flink.util
LinkedOptionalMapSerializer - Class in org.apache.flink.util
LinkedOptionalMapSerializer - A serializer of LinkedOptionalMap.
LinkElement - Class in org.apache.flink.configuration.description
Element that represents a link in the Description.
LIST(TypeInformation<E>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for a Java List.
list(InlineElement...) - Method in class org.apache.flink.configuration.description.Description.DescriptionBuilder
Adds a bulleted list to the description.
list(InlineElement...) - Static method in class org.apache.flink.configuration.description.ListElement
Creates a list with blocks of text.
ListAccumulator<T> - Class in org.apache.flink.api.common.accumulators
This accumulator stores a collection of objects.
ListAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.ListAccumulator
 
ListCollector<T> - Class in org.apache.flink.api.common.functions.util
A Collector that puts the collected elements into a given list.
ListCollector(List<T>) - Constructor for class org.apache.flink.api.common.functions.util.ListCollector
 
listDirectory(Path) - Static method in class org.apache.flink.util.FileUtils
Lists the given directory in a resource-leak-safe way.
ListElement - Class in org.apache.flink.configuration.description
Represents a list in the Description.
listFilesInDirectory(Path, Predicate<Path>) - Static method in class org.apache.flink.util.FileUtils
List the directory recursively and return the files that satisfy the fileFilter.
listIterator() - Method in class org.apache.flink.types.ListValue
 
listIterator(int) - Method in class org.apache.flink.types.ListValue
 
ListKeyGroupedIterator<E> - Class in org.apache.flink.api.common.operators.util
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
ListKeyGroupedIterator(List<E>, TypeSerializer<E>, TypeComparator<E>) - Constructor for class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
Initializes the ListKeyGroupedIterator..
ListKeyGroupedIterator.ValuesIterator - Class in org.apache.flink.api.common.operators.util
 
ListSerializer<T> - Class in org.apache.flink.api.common.typeutils.base
A serializer for Lists.
ListSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.base.ListSerializer
Creates a list serializer that uses the given serializer to serialize the list's elements.
ListSerializerSnapshot<T> - Class in org.apache.flink.api.common.typeutils.base
Snapshot class for the ListSerializer.
ListSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
Constructor for read instantiation.
ListSerializerSnapshot(ListSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.base.ListSerializerSnapshot
Constructor to create the snapshot for writing.
ListState<T> - Interface in org.apache.flink.api.common.state
State interface for partitioned list state in Operations.
ListStateDescriptor<T> - Class in org.apache.flink.api.common.state
ListStateDescriptor(String, Class<T>) - Constructor for class org.apache.flink.api.common.state.ListStateDescriptor
Creates a new ListStateDescriptor with the given name and list element type.
ListStateDescriptor(String, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.state.ListStateDescriptor
Creates a new ListStateDescriptor with the given name and list element type.
ListStateDescriptor(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.state.ListStateDescriptor
Creates a new ListStateDescriptor with the given name and list element type.
listStatus(Path) - Method in class org.apache.flink.core.fs.FileSystem
List the statuses of the files/directories in the given path if the path is a directory.
listStatus(Path) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
listStatus(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
listStatus(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
ListTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
A TypeInformation for the list types of the Java API.
ListTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.ListTypeInfo
 
ListTypeInfo(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.typeutils.ListTypeInfo
 
ListValue<V extends Value> - Class in org.apache.flink.types
Generic list base type for PACT programs that implements the Value and List interfaces.
ListValue() - Constructor for class org.apache.flink.types.ListValue
Initializes the encapsulated list with an empty ArrayList.
ListValue(Collection<V>) - Constructor for class org.apache.flink.types.ListValue
Initializes the encapsulated list with an ArrayList filled with all object contained in the specified Collection object.
load(Class<P>) - Method in class org.apache.flink.core.plugin.DefaultPluginManager
 
load(Class<P>) - Method in class org.apache.flink.core.plugin.PluginLoader
Returns in iterator over all available implementations of the given service interface (SPI) for the plugin.
load(Class<P>) - Method in interface org.apache.flink.core.plugin.PluginManager
Returns in iterator over all available implementations of the given service interface (SPI) in all the plugins known to this plugin manager instance.
loadClass(String, boolean) - Method in class org.apache.flink.core.classloading.ComponentClassLoader
 
loadClass(String, boolean) - Method in class org.apache.flink.util.FlinkUserCodeClassLoader
 
loadClassWithoutExceptionHandling(String, boolean) - Method in class org.apache.flink.util.ChildFirstClassLoader
 
loadClassWithoutExceptionHandling(String, boolean) - Method in class org.apache.flink.util.FlinkUserCodeClassLoader
Same as FlinkUserCodeClassLoader.loadClass(String, boolean) but without exception handling.
loadConfigParameters(Configuration) - Static method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
loadConfiguration() - Static method in class org.apache.flink.configuration.GlobalConfiguration
Loads the global configuration from the environment.
loadConfiguration(Configuration) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Loads the global configuration and adds the given dynamic properties configuration.
loadConfiguration(String) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Loads the configuration files from the specified directory.
loadConfiguration(String, Configuration) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Loads the configuration files from the specified directory.
loadGlobalConfigParams() - Static method in class org.apache.flink.api.common.io.DelimitedInputFormat
Deprecated.
Please use loadConfigParameters(Configuration config
LOCAL_DATE - Static variable in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
LOCAL_DATE - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for LocalDate.
LOCAL_DATE_TIME - Static variable in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
LOCAL_DATE_TIME - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for LocalDateTime.
LOCAL_NUMBER_JOB_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
LOCAL_NUMBER_RESOURCE_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
LOCAL_NUMBER_RESOURCE_MANAGER - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
Deprecated.
LOCAL_NUMBER_TASK_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
Sets the number of local task managers.
LOCAL_RECOVERY - Static variable in class org.apache.flink.configuration.CheckpointingOptions
This option configures local recovery for this state backend.
LOCAL_RECOVERY_TASK_MANAGER_STATE_ROOT_DIRS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
The config parameter defining the root directories for storing file-based state for local recovery.
LOCAL_START_WEBSERVER - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Has no effect; the web-server is always started. Will be removed in 2.0.
LOCAL_TIME - Static variable in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
LOCAL_TIME - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for LocalTime.
LocalBlockLocation - Class in org.apache.flink.core.fs.local
Implementation of the BlockLocation interface for a local file system.
LocalBlockLocation(long) - Constructor for class org.apache.flink.core.fs.local.LocalBlockLocation
 
LocalDataInputStream - Class in org.apache.flink.core.fs.local
The LocalDataInputStream class is a wrapper class for a data input stream to the local file system.
LocalDataInputStream(File) - Constructor for class org.apache.flink.core.fs.local.LocalDataInputStream
Constructs a new LocalDataInputStream object from a given File object.
LocalDataOutputStream - Class in org.apache.flink.core.fs.local
The LocalDataOutputStream class is a wrapper class for a data output stream to the local file system.
LocalDataOutputStream(File) - Constructor for class org.apache.flink.core.fs.local.LocalDataOutputStream
Constructs a new LocalDataOutputStream object from a given File object.
LocalDateComparator - Class in org.apache.flink.api.common.typeutils.base
This class can not extend BasicTypeComparator, because LocalDate is a Comparable of ChronoLocalDate instead of Comparable of LocalDate.
LocalDateComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
LocalDateSerializer - Class in org.apache.flink.api.common.typeutils.base
 
LocalDateSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
LocalDateSerializer.LocalDateSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
LocalDateSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.LocalDateSerializer.LocalDateSerializerSnapshot
 
LocalDateTimeComparator - Class in org.apache.flink.api.common.typeutils.base
This class can not extend BasicTypeComparator, because LocalDateTime is a Comparable of ChronoLocalDateTime instead of Comparable of LocalDateTime.
LocalDateTimeComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
LocalDateTimeSerializer - Class in org.apache.flink.api.common.typeutils.base
 
LocalDateTimeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
LocalDateTimeSerializer.LocalDateTimeSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
LocalDateTimeSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer.LocalDateTimeSerializerSnapshot
 
LocalFileStatus - Class in org.apache.flink.core.fs.local
The class LocalFileStatus provides an implementation of the FileStatus interface for the local file system.
LocalFileStatus(File, FileSystem) - Constructor for class org.apache.flink.core.fs.local.LocalFileStatus
Creates a LocalFileStatus object from a given File object.
LocalFileSystem - Class in org.apache.flink.core.fs.local
The class LocalFileSystem is an implementation of the FileSystem interface for the local file system of the machine where the JVM runs.
LocalFileSystem() - Constructor for class org.apache.flink.core.fs.local.LocalFileSystem
Constructs a new LocalFileSystem object.
LocalFileSystemFactory - Class in org.apache.flink.core.fs.local
A factory for the LocalFileSystem.
LocalFileSystemFactory() - Constructor for class org.apache.flink.core.fs.local.LocalFileSystemFactory
 
LocalRecoverableWriter - Class in org.apache.flink.core.fs.local
LocalRecoverableWriter(LocalFileSystem) - Constructor for class org.apache.flink.core.fs.local.LocalRecoverableWriter
 
LocalTimeComparator - Class in org.apache.flink.api.common.typeutils.base
 
LocalTimeComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
LocalTimeSerializer - Class in org.apache.flink.api.common.typeutils.base
 
LocalTimeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
LocalTimeSerializer.LocalTimeSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
LocalTimeSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer.LocalTimeSerializerSnapshot
 
LocalTimeTypeInfo<T extends java.time.temporal.Temporal> - Class in org.apache.flink.api.common.typeinfo
Type information for Java LocalDate/LocalTime/LocalDateTime.
LocalTimeTypeInfo(Class<T>, TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
LocatableInputSplit - Class in org.apache.flink.core.io
A locatable input split is an input split referring to input data which is located on one or more hosts.
LocatableInputSplit(int, String[]) - Constructor for class org.apache.flink.core.io.LocatableInputSplit
Creates a new locatable input split that refers to a multiple host as its data location.
LocatableInputSplit(int, String) - Constructor for class org.apache.flink.core.io.LocatableInputSplit
Creates a new locatable input split that refers to a single host as its data location.
LocatableInputSplitAssigner - Class in org.apache.flink.api.common.io
The locatable input split assigner assigns to each host splits that are local, before assigning splits that are not local.
LocatableInputSplitAssigner(Collection<LocatableInputSplit>) - Constructor for class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
LocatableInputSplitAssigner(LocatableInputSplit[]) - Constructor for class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
LocatedFileStatus - Interface in org.apache.flink.core.fs
A LocatedFileStatus is a FileStatus that contains additionally the location information of the file directly.
log2floor(int) - Static method in class org.apache.flink.util.MathUtils
Computes the logarithm of the given value to the base of 2, rounded down.
log2strict(int) - Static method in class org.apache.flink.util.MathUtils
Computes the logarithm of the given value to the base of 2.
LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.AkkaOptions
Log lifecycle events.
LOG_PATH - Static variable in class org.apache.flink.configuration.WebOptions
The log file location (may be in /log for standalone but under log directory when using YARN).
LONG - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive long and Long.
LONG_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
LONG_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
LONG_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
LONG_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
LongComparator - Class in org.apache.flink.api.common.typeutils.base
 
LongComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.LongComparator
 
LongCounter - Class in org.apache.flink.api.common.accumulators
An accumulator that sums up long values.
LongCounter() - Constructor for class org.apache.flink.api.common.accumulators.LongCounter
 
LongCounter(long) - Constructor for class org.apache.flink.api.common.accumulators.LongCounter
 
LongFunctionWithException<R,E extends Throwable> - Interface in org.apache.flink.util.function
Similar to LongFunction but can throw Exception.
LongMaximum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the maximum long value.
LongMaximum() - Constructor for class org.apache.flink.api.common.accumulators.LongMaximum
 
LongMaximum(long) - Constructor for class org.apache.flink.api.common.accumulators.LongMaximum
 
LongMinimum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the minimum long value.
LongMinimum() - Constructor for class org.apache.flink.api.common.accumulators.LongMinimum
 
LongMinimum(long) - Constructor for class org.apache.flink.api.common.accumulators.LongMinimum
 
LongParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a LongValue.
LongParser() - Constructor for class org.apache.flink.types.parser.LongParser
 
LongPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
LongPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
LongPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for long arrays.
LongPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
LongPrimitiveArraySerializer.LongPrimitiveArraySerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base.array
Serializer configuration snapshot for compatibility and format evolution.
LongPrimitiveArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer.LongPrimitiveArraySerializerSnapshot
 
LongSerializer - Class in org.apache.flink.api.common.typeutils.base
Type serializer for Long.
LongSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.LongSerializer
 
LongSerializer.LongSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
LongSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.LongSerializer.LongSerializerSnapshot
 
LongSumAggregator - Class in org.apache.flink.api.common.aggregators
An Aggregator that sums up long values.
LongSumAggregator() - Constructor for class org.apache.flink.api.common.aggregators.LongSumAggregator
 
longToIntWithBitMixing(long) - Static method in class org.apache.flink.util.MathUtils
Pseudo-randomly maps a long (64-bit) to an integer (32-bit) using some bit-mixing for better distribution.
longType() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of Long type.
LongValue - Class in org.apache.flink.types
Boxed serializable and comparable long integer type, representing the primitive type long.
LongValue() - Constructor for class org.apache.flink.types.LongValue
Initializes the encapsulated long with 0.
LongValue(long) - Constructor for class org.apache.flink.types.LongValue
Initializes the encapsulated long with the specified value.
LongValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for LongValue based on CopyableValueComparator.
LongValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
LongValueParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a LongValue.
LongValueParser() - Constructor for class org.apache.flink.types.parser.LongValueParser
 
LongValueSequenceIterator - Class in org.apache.flink.util
The LongValueSequenceIterator is an iterator that returns a sequence of numbers (as LongValue)s.
LongValueSequenceIterator(long, long) - Constructor for class org.apache.flink.util.LongValueSequenceIterator
Creates a new splittable iterator, returning the range [from, to].
LongValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
LongValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
LongValueSerializer.LongValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
LongValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.LongValueSerializer.LongValueSerializerSnapshot
 
LongZeroConvergence - Class in org.apache.flink.api.common.aggregators
A ConvergenceCriterion over an Aggregator that defines convergence as reached once the aggregator holds the value zero.
LongZeroConvergence() - Constructor for class org.apache.flink.api.common.aggregators.LongZeroConvergence
 
LOOKUP_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
LOOKUP_TIMEOUT_DURATION - Static variable in class org.apache.flink.configuration.AkkaOptions
Timeout for all blocking calls that look up remote actors.
lookupMatch(PT) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap.Prober
 
lowerPart - Variable in class org.apache.flink.util.AbstractID
The lower part of the actual ID.

M

MailboxExecutor - Interface in org.apache.flink.api.common.operators
Executor like interface for an build around a mailbox-based execution model.
makeQualified(FileSystem) - Method in class org.apache.flink.core.fs.Path
Returns a qualified path object.
makeSpace(int) - Method in class org.apache.flink.types.Record
Reserves space for at least the given number of fields in the internal arrays.
MANAGED_MEMORY_CONSUMER_NAME_DATAPROC - Static variable in class org.apache.flink.configuration.TaskManagerOptions
MANAGED_MEMORY_CONSUMER_NAME_OPERATOR - Static variable in class org.apache.flink.configuration.TaskManagerOptions
 
MANAGED_MEMORY_CONSUMER_NAME_PYTHON - Static variable in class org.apache.flink.configuration.TaskManagerOptions
 
MANAGED_MEMORY_CONSUMER_NAME_STATE_BACKEND - Static variable in class org.apache.flink.configuration.TaskManagerOptions
 
MANAGED_MEMORY_CONSUMER_WEIGHTS - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Weights of managed memory consumers.
MANAGED_MEMORY_FRACTION - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Fraction of Total Flink Memory to be used as Managed Memory, if TaskManagerOptions.MANAGED_MEMORY_SIZE is not specified.
MANAGED_MEMORY_SIZE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Managed Memory size for TaskExecutors.
ManagedMemoryUseCase - Enum in org.apache.flink.core.memory
Use cases of managed memory.
ManagedMemoryUseCase.Scope - Enum in org.apache.flink.core.memory
Scope at which memory is managed for a use case.
ManualClock - Class in org.apache.flink.util.clock
A Clock implementation which allows to advance time manually.
ManualClock() - Constructor for class org.apache.flink.util.clock.ManualClock
 
ManualClock(long) - Constructor for class org.apache.flink.util.clock.ManualClock
 
map(T) - Method in interface org.apache.flink.api.common.functions.MapFunction
The mapping method.
map(IN) - Method in class org.apache.flink.api.common.functions.RichMapFunction
 
MAP(TypeInformation<K>, TypeInformation<V>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for a Java Map.
map(Function<? super T, ? extends R>) - Method in class org.apache.flink.types.SerializableOptional
 
MapFunction<T,O> - Interface in org.apache.flink.api.common.functions
Base interface for Map functions.
MapOperatorBase<IN,OUT,FT extends MapFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
 
MapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapOperatorBase
 
MapOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapOperatorBase
 
MapOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapOperatorBase
 
mapPartition(Iterable<T>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.MapPartitionFunction
A user-implemented function that modifies or transforms an incoming object.
mapPartition(Iterable<I>, Collector<O>) - Method in class org.apache.flink.api.common.functions.RichMapPartitionFunction
 
MapPartitionFunction<T,O> - Interface in org.apache.flink.api.common.functions
Interface for "mapPartition" functions.
MapPartitionOperatorBase<IN,OUT,FT extends MapPartitionFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
 
MapPartitionOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
MapPartitionOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
MapPartitionOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
MapSerializer<K,V> - Class in org.apache.flink.api.common.typeutils.base
A serializer for Map.
MapSerializer(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.api.common.typeutils.base.MapSerializer
Creates a map serializer that uses the given serializers to serialize the key-value pairs in the map.
MapSerializerConfigSnapshot<K,V> - Class in org.apache.flink.api.common.typeutils.base
Deprecated.
this snapshot class should not be used by any serializer anymore.
MapSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
MapSerializerConfigSnapshot(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
Deprecated.
 
MapSerializerSnapshot<K,V> - Class in org.apache.flink.api.common.typeutils.base
Snapshot class for the MapSerializer.
MapSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
Constructor for read instantiation.
MapSerializerSnapshot(MapSerializer<K, V>) - Constructor for class org.apache.flink.api.common.typeutils.base.MapSerializerSnapshot
Constructor to create the snapshot for writing.
MapState<UK,UV> - Interface in org.apache.flink.api.common.state
State interface for partitioned key-value state.
MapStateDescriptor<UK,UV> - Class in org.apache.flink.api.common.state
MapStateDescriptor(String, TypeSerializer<UK>, TypeSerializer<UV>) - Constructor for class org.apache.flink.api.common.state.MapStateDescriptor
Create a new MapStateDescriptor with the given name and the given type serializers.
MapStateDescriptor(String, TypeInformation<UK>, TypeInformation<UV>) - Constructor for class org.apache.flink.api.common.state.MapStateDescriptor
Create a new MapStateDescriptor with the given name and the given type information.
MapStateDescriptor(String, Class<UK>, Class<UV>) - Constructor for class org.apache.flink.api.common.state.MapStateDescriptor
Create a new MapStateDescriptor with the given name and the given type information.
mapType() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be a set of properties, which can be represented as Map<String, String>.
MapTypeInfo<K,V> - Class in org.apache.flink.api.java.typeutils
Special TypeInformation used by MapStateDescriptor.
MapTypeInfo(TypeInformation<K>, TypeInformation<V>) - Constructor for class org.apache.flink.api.java.typeutils.MapTypeInfo
 
MapTypeInfo(Class<K>, Class<V>) - Constructor for class org.apache.flink.api.java.typeutils.MapTypeInfo
 
MapValue<K extends Value,V extends Value> - Class in org.apache.flink.types
Generic map base type for PACT programs that implements the Value and Map interfaces.
MapValue() - Constructor for class org.apache.flink.types.MapValue
Initializes the encapsulated map with an empty HashMap.
MapValue(Map<K, V>) - Constructor for class org.apache.flink.types.MapValue
Initializes the encapsulated map with a HashMap filled with all entries of the provided map.
mapWithIndex(Collection<T>, BiFunction<T, Integer, R>) - Static method in class org.apache.flink.util.CollectionUtil
 
mark(int) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
mark(int) - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
markActive() - Method in interface org.apache.flink.api.common.eventtime.WatermarkOutput
Marks this output as active, meaning that downstream operations should wait for watermarks from this output.
markIdle() - Method in interface org.apache.flink.api.common.eventtime.WatermarkOutput
Marks this output as idle, meaning that downstream operations do not wait for watermarks from this output.
markIdle() - Method in interface org.apache.flink.api.connector.source.ReaderOutput
Marks this output as idle, meaning that downstream operations do not wait for watermarks from this output.
markSupported() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
markSupported() - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
MaskUtils - Class in org.apache.flink.api.java.typeutils.runtime
Utilities for reading and writing binary masks.
MaskUtils() - Constructor for class org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
MathUtils - Class in org.apache.flink.util
Collection of simple mathematical routines.
MAX_ARITY - Static variable in class org.apache.flink.api.java.tuple.Tuple
 
MAX_ARRAY_SIZE - Static variable in class org.apache.flink.util.CollectionUtil
A safe maximum size for arrays in the JVM.
MAX_ATTEMPTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.JobManagerOptions
The maximum number of prior execution attempts kept in history.
MAX_EXCEPTION_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.WebOptions
The maximum number of failures kept in the exception history.
MAX_PARALLELISM - Static variable in class org.apache.flink.configuration.PipelineOptions
 
MAX_REGISTRATION_TIMEOUT - Static variable in class org.apache.flink.configuration.ClusterOptions
 
MAX_RETAINED_CHECKPOINTS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
The maximum number of completed checkpoints to retain.
MAX_SLOT_NUM - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
 
MAX_TOTAL_CPU - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
 
MAX_TOTAL_MEM - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
 
MAX_VALUE - Static variable in class org.apache.flink.configuration.MemorySize
 
MAX_WATERMARK - Static variable in class org.apache.flink.api.common.eventtime.Watermark
The watermark that signifies end-of-event-time.
MEMORY_SEGMENT_SIZE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Size of memory buffers used by the network stack and the memory manager.
MemorySegment - Class in org.apache.flink.core.memory
This class represents a piece of memory managed by Flink.
MemorySegmentFactory - Class in org.apache.flink.core.memory
A factory for memory segments (MemorySegment).
MemorySegmentFactory() - Constructor for class org.apache.flink.core.memory.MemorySegmentFactory
 
MemorySegmentInputStreamWithPos - Class in org.apache.flink.core.memory
Un-synchronized input stream using the given memory segment.
MemorySegmentInputStreamWithPos(MemorySegment, int, int) - Constructor for class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
MemorySegmentProvider - Interface in org.apache.flink.core.memory
The provider used for requesting and releasing batch of memory segments.
MemorySegmentSource - Interface in org.apache.flink.core.memory
Interface describing entities that can provide memory segments.
MemorySegmentWritable - Interface in org.apache.flink.core.memory
Provides the interface for write(Segment).
MemorySize - Class in org.apache.flink.configuration
MemorySize is a representation of a number of bytes, viewable in different units.
MemorySize(long) - Constructor for class org.apache.flink.configuration.MemorySize
Constructs a new MemorySize.
MemorySize.MemoryUnit - Enum in org.apache.flink.configuration
Enum which defines memory unit, mostly used to parse value from configuration file.
memoryType() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of MemorySize type.
MemoryUtils - Class in org.apache.flink.core.memory
Utility class for memory operations.
merge(Accumulator<V, R>) - Method in interface org.apache.flink.api.common.accumulators.Accumulator
Used by system internally to merge the collected parts of an accumulator at the end of the job.
merge(Accumulator<Double, Double>) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
merge(Accumulator<Double, Double>) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
merge(Accumulator<Double, Double>) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
merge(Accumulator<Double, Double>) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
merge(Accumulator<Integer, TreeMap<Integer, Integer>>) - Method in class org.apache.flink.api.common.accumulators.Histogram
 
merge(Accumulator<Integer, Integer>) - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
merge(Accumulator<Integer, Integer>) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
merge(Accumulator<Integer, Integer>) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
merge(Accumulator<T, ArrayList<T>>) - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
merge(Accumulator<Long, Long>) - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
merge(Accumulator<Long, Long>) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
merge(Accumulator<Long, Long>) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
merge(Accumulator<T, ArrayList<byte[]>>) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
merge(ACC, ACC) - Method in interface org.apache.flink.api.common.functions.AggregateFunction
Merges two accumulators, returning an accumulator with the merged state.
merge(ACC, ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
 
merge(ResourceSpec) - Method in class org.apache.flink.api.common.operators.ResourceSpec
Used by system internally to merge the other resources of chained operators when generating the job graph.
merge(T) - Method in class org.apache.flink.api.common.resources.Resource
 
mergeInto(Map<String, OptionalFailure<Accumulator<?, ?>>>, Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
Merge two collections of accumulators.
mergeRightIntoLeft(LinkedOptionalMap<K, V>, LinkedOptionalMap<K, V>) - Static method in class org.apache.flink.util.LinkedOptionalMap
Tries to merges the keys and the values of @right into @left.
MergingState<IN,OUT> - Interface in org.apache.flink.api.common.state
Extension of AppendingState that allows merging of state.
MESOS_ARTIFACT_SERVER_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_ARTIFACT_SERVER_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_FAILOVER_TIMEOUT_SECONDS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_INITIAL_TASKS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_MASTER_URL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_MAX_FAILED_TASKS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_NAME - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_PRINCIPAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_ROLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_SECRET - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
MESOS_RESOURCEMANAGER_FRAMEWORK_USER - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
METRIC_FETCHER_UPDATE_INTERVAL - Static variable in class org.apache.flink.configuration.MetricOptions
The config parameter defining the update interval for the metric fetcher used by the web UI in milliseconds.
metricGroup() - Method in interface org.apache.flink.api.connector.sink.Sink.InitContext
 
metricGroup() - Method in interface org.apache.flink.api.connector.source.SourceReaderContext
 
metricGroup() - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
 
MetricOptions - Class in org.apache.flink.configuration
Configuration options for metrics and metric reporters.
METRICS_LATENCY_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_REPORTER_CLASS_SUFFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
The class of the reporter to use.
METRICS_REPORTER_EXCLUDED_VARIABLES - Static variable in class org.apache.flink.configuration.ConfigConstants
The set of variables that should be excluded.
METRICS_REPORTER_FACTORY_CLASS_SUFFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
The class of the reporter factory to use.
METRICS_REPORTER_INTERVAL_SUFFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
The interval between reports.
METRICS_REPORTER_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
The prefix for per-reporter configs.
METRICS_REPORTER_SCOPE_DELIMITER - Static variable in class org.apache.flink.configuration.ConfigConstants
The delimiter used to assemble the metric identifier.
METRICS_REPORTERS_LIST - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_DELIMITER - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_JM - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_JM_JOB - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_OPERATOR - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_TASK - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_TM - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_TM_JOB - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
MIGRATION_NOT_SUPPORTED_MSG - Static variable in exception org.apache.flink.util.StateMigrationException
 
milliseconds(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of milliseconds.
MIN_JVM_HEAP_SIZE - Static variable in class org.apache.flink.configuration.JobManagerOptions
 
MIN_MEMORY_SEGMENT_SIZE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Minimum possible size of memory buffers used by the network stack and the memory manager.
MIN_PARALLELISM_INCREASE - Static variable in class org.apache.flink.configuration.JobManagerOptions
 
minSplitSize - Variable in class org.apache.flink.api.common.io.FileInputFormat
The minimal split size, set by the configure() method.
minutes(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of minutes.
missingKeys() - Method in class org.apache.flink.util.LinkedOptionalMap.MergeResult
 
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
 
mkdirs(Path) - Method in class org.apache.flink.core.fs.FileSystem
Make the given file and all non-existent parents into directories.
mkdirs(Path) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
mkdirs(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
Recursively creates the directory specified by the provided path.
mkdirs(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
monitorUserSystemExitForCurrentThread() - Static method in class org.apache.flink.core.security.FlinkSecurityManager
 
multiply(BigDecimal) - Method in class org.apache.flink.api.common.resources.Resource
 
multiply(int) - Method in class org.apache.flink.api.common.resources.Resource
 
multiply(double) - Method in class org.apache.flink.configuration.MemorySize
 
MultisetTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
A TypeInformation for the Multiset types of the Java API.
MultisetTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
MultisetTypeInfo(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
murmurHash(int) - Static method in class org.apache.flink.util.MathUtils
This function hashes an integer value.
MutableObjectIterator<E> - Interface in org.apache.flink.util
A simple iterator interface.

N

name - Variable in class org.apache.flink.api.common.operators.Operator
 
NAME - Static variable in class org.apache.flink.api.common.resources.CPUResource
 
name - Variable in class org.apache.flink.api.common.state.StateDescriptor
Name that uniquely identifies state created from this StateDescriptor.
name - Variable in class org.apache.flink.api.dag.Transformation
 
NAME - Static variable in class org.apache.flink.configuration.PipelineOptions
The job name used for printing and logging.
NamedFlatFieldDescriptor(String, int, TypeInformation<?>) - Constructor for class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
NATIVE_BLOCK_SIZE - Static variable in class org.apache.flink.api.common.io.BinaryInputFormat
 
NATIVE_BLOCK_SIZE - Static variable in class org.apache.flink.api.common.io.BinaryOutputFormat
 
NATIVE_BYTE_ORDER - Static variable in class org.apache.flink.core.memory.MemoryUtils
The native byte order of the platform on which the system currently runs.
NestedSerializersSnapshotDelegate - Class in org.apache.flink.api.common.typeutils
A NestedSerializersSnapshotDelegate represents the snapshots of multiple serializers that are used by an outer serializer.
NestedSerializersSnapshotDelegate(TypeSerializer<?>...) - Constructor for class org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Constructor to create a snapshot for writing.
NettyShuffleEnvironmentOptions - Class in org.apache.flink.configuration
The set of configuration options relating to network stack.
NetUtils - Class in org.apache.flink.util
Utility for various network related tasks (such as finding free ports).
NetUtils() - Constructor for class org.apache.flink.util.NetUtils
 
NetUtils.SocketFactory - Interface in org.apache.flink.util
A factory for a local socket from port number.
NETWORK_BATCH_SHUFFLE_READ_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Size of direct memory used by blocking shuffle for shuffle data read (currently only used by sort-merge shuffle).
NETWORK_BLOCKING_SHUFFLE_TYPE - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NETWORK_BUFFERS_MEMORY_FRACTION - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
NETWORK_BUFFERS_MEMORY_MAX - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Deprecated.
NETWORK_BUFFERS_MEMORY_MIN - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Deprecated.
NETWORK_BUFFERS_PER_CHANNEL - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Number of network buffers to use for each outgoing/incoming channel (subpartition/input channel).
NETWORK_DETAILED_METRICS - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Boolean flag to enable/disable more detailed metrics about inbound/outbound network queue lengths.
NETWORK_EXCLUSIVE_BUFFERS_REQUEST_TIMEOUT_MILLISECONDS - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
The timeout for requesting exclusive buffers for each channel.
NETWORK_EXTRA_BUFFERS_PER_GATE - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Number of extra network buffers to use for each outgoing/incoming gate (result partition/input gate).
NETWORK_MAX_BUFFERS_PER_CHANNEL - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Number of max buffers can be used for each output subparition.
NETWORK_MEMORY_FRACTION - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Fraction of Total Flink Memory to be used as Network Memory.
NETWORK_MEMORY_MAX - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Max Network Memory size for TaskExecutors.
NETWORK_MEMORY_MIN - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Min Network Memory size for TaskExecutors.
NETWORK_NUM_BUFFERS - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
NETWORK_REQUEST_BACKOFF_INITIAL - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Minimum backoff for partition requests of input channels.
NETWORK_REQUEST_BACKOFF_MAX - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Maximum backoff for partition requests of input channels.
NETWORK_RETRIES - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NETWORK_SORT_SHUFFLE_MIN_BUFFERS - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Minimum number of network buffers required per sort-merge blocking result partition.
NETWORK_SORT_SHUFFLE_MIN_PARALLELISM - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
Parallelism threshold to switch between sort-merge based blocking shuffle and the default hash-based blocking shuffle.
NeverCompleteFuture - Class in org.apache.flink.util.concurrent
A future that never completes.
NeverCompleteFuture(long) - Constructor for class org.apache.flink.util.concurrent.NeverCompleteFuture
 
neverReturnExpired() - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
 
newBuilder(double, int) - Static method in class org.apache.flink.api.common.operators.ResourceSpec
 
newBuilder(double, MemorySize) - Static method in class org.apache.flink.api.common.operators.ResourceSpec
 
newBuilder(String) - Static method in class org.apache.flink.api.common.operators.SlotSharingGroup
 
newBuilder(Time) - Static method in class org.apache.flink.api.common.state.StateTtlConfig
 
newDirectExecutorService() - Static method in class org.apache.flink.util.concurrent.Executors
Return a new direct executor service.
newInstance(int) - Static method in class org.apache.flink.api.java.tuple.Tuple
 
newInstance() - Method in class org.apache.flink.configuration.description.Formatter
 
newInstance() - Method in class org.apache.flink.configuration.description.HtmlFormatter
 
newInstance(Class<T>) - Static method in class org.apache.flink.util.ReflectionUtil
 
newThread(Runnable) - Method in class org.apache.flink.util.concurrent.ExecutorThreadFactory
 
next() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
 
next() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
next() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
next() - Method in class org.apache.flink.util.CloseableIterator.IteratorAdapter
 
next() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
next(E) - Method in interface org.apache.flink.util.MutableObjectIterator
Gets the next element from the collection.
next() - Method in interface org.apache.flink.util.MutableObjectIterator
Gets the next element from the collection.
next() - Method in class org.apache.flink.util.NumberSequenceIterator
 
next(StringValue) - Method in class org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
Gets the next token from the string.
next() - Method in class org.apache.flink.util.UnionIterator
 
next(int) - Method in class org.apache.flink.util.XORShiftRandom
All other methods like nextInt()/nextDouble()...
nextKey() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
Moves the iterator to the next key.
nextRecord(T) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
nextRecord(OT) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
nextRecord(OT) - Method in interface org.apache.flink.api.common.io.InputFormat
Reads the next record from the input.
nextRecord(OT) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
nextSegment() - Method in interface org.apache.flink.core.memory.MemorySegmentSource
Gets the next memory segment.
nextStringEndPos(byte[], int, int, byte[]) - Method in class org.apache.flink.types.parser.FieldParser
Returns the end position of a string.
nextStringLength(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.FieldParser
Returns the length of a string.
NO_INDEX - Static variable in class org.apache.flink.api.java.typeutils.TypeExtractor
 
NO_TIMESTAMP - Static variable in interface org.apache.flink.api.common.eventtime.TimestampAssigner
The value that is passed to TimestampAssigner.extractTimestamp(T, long) when there is no previous timestamp attached to the record.
noDefaultValue() - Method in class org.apache.flink.configuration.ConfigOptions.ListConfigOptionBuilder
Creates a ConfigOption without a default value.
noDefaultValue() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Deprecated.
define the type explicitly first with one of the intType(), stringType(), etc.
noDefaultValue() - Method in class org.apache.flink.configuration.ConfigOptions.TypedConfigOptionBuilder
Creates a ConfigOption without a default value.
NoFetchingInput - Class in org.apache.flink.api.java.typeutils.runtime
 
NoFetchingInput(InputStream) - Constructor for class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
nonBlockingShutdown(long, TimeUnit, ExecutorService...) - Static method in class org.apache.flink.util.ExecutorUtils
Shuts the given ExecutorService down in a non-blocking fashion.
NONE - Static variable in class org.apache.flink.configuration.ExternalResourceOptions
Indicate an empty external resources list.
NonParallelInput - Interface in org.apache.flink.api.common.io
This interface acts as a marker for input formats for inputs which cannot be split.
NonSerializableUserCodeException - Exception in org.apache.flink.api.common
An special case of the InvalidProgramException, indicating that a part of the program that needs to be serializable (for shipping) is not serializable.
NonSerializableUserCodeException() - Constructor for exception org.apache.flink.api.common.NonSerializableUserCodeException
Creates a new exception with no message.
NonSerializableUserCodeException(String) - Constructor for exception org.apache.flink.api.common.NonSerializableUserCodeException
Creates a new exception with the given message.
NOOP_EXCEPTION_HANDLER - Static variable in class org.apache.flink.util.FlinkUserCodeClassLoader
 
NoOpFunction - Class in org.apache.flink.api.common.functions.util
An AbstractRichFunction that does nothing.
NoOpFunction() - Constructor for class org.apache.flink.api.common.functions.util.NoOpFunction
 
noRestart() - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates NoRestartStrategyConfiguration.
NoRestartStrategyConfiguration() - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
NormalizableKey<T> - Interface in org.apache.flink.types
The base interface for normalizable keys.
normalizableKeyPrefixLen - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
normalizedKeyLengths - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
NormalizedKeyUtil - Class in org.apache.flink.api.common.typeutils.base
Utilities related to TypeComparator.
NormalizedKeyUtil() - Constructor for class org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
Nothing - Class in org.apache.flink.types
A type for (synthetic) operators that do not output data.
NothingTypeInfo - Class in org.apache.flink.api.common.typeinfo
Placeholder type information for the Nothing type.
NothingTypeInfo() - Constructor for class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
notifyCheckpointAborted(long) - Method in interface org.apache.flink.api.common.state.CheckpointListener
This method is called as a notification once a distributed checkpoint has been aborted.
notifyCheckpointComplete(long) - Method in interface org.apache.flink.api.common.state.CheckpointListener
Notifies the listener that the checkpoint with the given checkpointId completed and was committed.
notifyCheckpointComplete(long) - Method in interface org.apache.flink.api.connector.source.SourceReader
We have an empty default implementation here because most source readers do not have to implement the method.
notifyCheckpointComplete(long) - Method in interface org.apache.flink.api.connector.source.SplitEnumerator
We have an empty default implementation here because most source readers do not have to implement the method.
notifyNoMoreSplits() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
notifyNoMoreSplits() - Method in interface org.apache.flink.api.connector.source.SourceReader
This method is called when the reader is notified that it will not receive any further splits.
notSupported() - Static method in exception org.apache.flink.util.StateMigrationException
 
now() - Static method in class org.apache.flink.api.common.time.Deadline
Constructs a Deadline that has now as the deadline.
noWatermarks() - Static method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a watermark strategy that generates no watermarks at all.
NoWatermarksGenerator<E> - Class in org.apache.flink.api.common.eventtime
An implementation of a WatermarkGenerator that generates no Watermarks.
NoWatermarksGenerator() - Constructor for class org.apache.flink.api.common.eventtime.NoWatermarksGenerator
 
NULL_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
NullableSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
Serializer wrapper to add support of null value serialization.
NullableSerializer.NullableSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards compatibility purposes. It is fully replaced by NullableSerializer.NullableSerializerSnapshot.
NullableSerializer.NullableSerializerSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
Snapshot for serializers of nullable types, containing the snapshot of its original serializer.
NullableSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
NullableSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
NullableSerializerSnapshot(NullableSerializer<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
NullAwareComparator<T> - Class in org.apache.flink.api.java.typeutils.runtime
Null-aware comparator that wraps a comparator which does not support null references.
NullAwareComparator(TypeComparator<T>, boolean) - Constructor for class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
NullByteKeySelector<T> - Class in org.apache.flink.api.java.functions
Used as a dummy KeySelector to allow using keyed operators for non-keyed use cases.
NullByteKeySelector() - Constructor for class org.apache.flink.api.java.functions.NullByteKeySelector
 
NullFieldException - Exception in org.apache.flink.types
An exception specifying that a required field was not set in a record, i.e.
NullFieldException() - Constructor for exception org.apache.flink.types.NullFieldException
Constructs an NullFieldException with null as its error detail message.
NullFieldException(String) - Constructor for exception org.apache.flink.types.NullFieldException
Constructs an NullFieldException with the specified detail message.
NullFieldException(int) - Constructor for exception org.apache.flink.types.NullFieldException
Constructs an NullFieldException with a default message, referring to given field number as the null field.
NullFieldException(int, Throwable) - Constructor for exception org.apache.flink.types.NullFieldException
Constructs an NullFieldException with a default message, referring to given field number as the null field and a cause (Throwable)
nullFn() - Static method in class org.apache.flink.util.function.FunctionUtils
Function which returns null (type: Void).
NullKeyFieldException - Exception in org.apache.flink.types
An exception specifying that a required key field was not set in a record, i.e.
NullKeyFieldException() - Constructor for exception org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with null as its error detail message.
NullKeyFieldException(NullFieldException) - Constructor for exception org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with a default message, referring to the field number given in the NullFieldException.
NullKeyFieldException(String) - Constructor for exception org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with the specified detail message.
NullKeyFieldException(int) - Constructor for exception org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with a default message, referring to given field number as the null key field.
NullValue - Class in org.apache.flink.types
Null base type for programs that implements the Key interface.
NullValue() - Constructor for class org.apache.flink.types.NullValue
Creates a NullValue object.
NullValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for NullValue based on CopyableValueComparator.
NullValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
NullValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
NullValueSerializer.NullValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
NullValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.NullValueSerializer.NullValueSerializerSnapshot
 
NUM_ARENAS - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NUM_RECORDS_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Constant indicating that the number of records is unknown;
NUM_TASK_SLOTS - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The config parameter defining the number of task slots of a task manager.
NUM_THREADS_CLIENT - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NUM_THREADS_SERVER - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
NumberSequenceIterator - Class in org.apache.flink.util
The NumberSequenceIterator is an iterator that returns a sequence of numbers (as Long)s.
NumberSequenceIterator(long, long) - Constructor for class org.apache.flink.util.NumberSequenceIterator
Creates a new splittable iterator, returning the range [from, to].
NumberSequenceSource - Class in org.apache.flink.api.connector.source.lib
A data source that produces a sequence of numbers (longs).
NumberSequenceSource(long, long) - Constructor for class org.apache.flink.api.connector.source.lib.NumberSequenceSource
Creates a new NumberSequenceSource that produces parallel sequences covering the range from to to (both boundaries are inclusive).
NumberSequenceSource.NumberSequenceSplit - Class in org.apache.flink.api.connector.source.lib
A split of the source, representing a number sub-sequence.
NumberSequenceSplit(String, long, long) - Constructor for class org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
NumericTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for numeric primitive types: int, long, double, byte, short, float, char.
NumericTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.NumericTypeInfo
 
numLeadingNormalizableKeys - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
numSplits - Variable in class org.apache.flink.api.common.io.FileInputFormat
The desired number of splits, as set by the configure() method.

O

OBJECT_ARRAY(TypeInformation<E>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Java arrays of object types (such as String[], Integer[]).
OBJECT_REUSE - Static variable in class org.apache.flink.configuration.PipelineOptions
 
ObjectArrayTypeInfo<T,C> - Class in org.apache.flink.api.java.typeutils
 
obtainLeft(Either<L, R>, TypeSerializer<L>) - Static method in class org.apache.flink.types.Either
Utility function for EitherSerializer to support object reuse.
obtainRight(Either<L, R>, TypeSerializer<R>) - Static method in class org.apache.flink.types.Either
Utility function for EitherSerializer to support object reuse.
of(SerializableTimestampAssigner<T>) - Static method in interface org.apache.flink.api.common.eventtime.TimestampAssignerSupplier
 
of(long, TimeUnit) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time of the given duration and TimeUnit.
of(Class<T>) - Static method in class org.apache.flink.api.common.typeinfo.TypeInformation
Creates a TypeInformation for the type described by the given class.
of(TypeHint<T>) - Static method in class org.apache.flink.api.common.typeinfo.TypeInformation
Creates a TypeInformation for a generic type via a utility "type hint".
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.
of(FileSystemFactory) - Static method in class org.apache.flink.core.fs.PluginFileSystemFactory
 
of(L) - Static method in class org.apache.flink.types.Either.Left
Creates a left value of Either
of(R) - Static method in class org.apache.flink.types.Either.Right
Creates a right value of Either
of(Object...) - Static method in class org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode and assigns the given values to the row's fields.
of(T) - Static method in class org.apache.flink.types.SerializableOptional
 
of(Optional<T>) - Static method in class org.apache.flink.util.OptionalConsumer
 
of(T) - Static method in class org.apache.flink.util.OptionalFailure
 
of(ClassLoader) - Static method in class org.apache.flink.util.TemporaryClassLoaderContext
Sets the context class loader to the given ClassLoader and returns a resource that sets it back to the current context ClassLoader when the resource is closed.
ofElement(E, Consumer<E>) - Static method in interface org.apache.flink.util.CloseableIterator
 
ofElements(Consumer<T>, T...) - Static method in interface org.apache.flink.util.CloseableIterator
 
OFF_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.JobManagerOptions
Off-heap Memory size for the JobManager.
ofFailure(Throwable) - Static method in class org.apache.flink.util.OptionalFailure
 
OFFLOAD_MINSIZE - Static variable in class org.apache.flink.configuration.BlobServerOptions
The minimum size for messages to be offloaded to the BlobServer.
ofKind(RowKind, Object...) - Static method in class org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode with given kind and assigns the given values to the row's fields.
ofMebiBytes(long) - Static method in class org.apache.flink.configuration.MemorySize
 
ofNullable(T) - Static method in class org.apache.flink.types.SerializableOptional
 
onEvent(T, long, WatermarkOutput) - Method in class org.apache.flink.api.common.eventtime.BoundedOutOfOrdernessWatermarks
 
onEvent(E, long, WatermarkOutput) - Method in class org.apache.flink.api.common.eventtime.NoWatermarksGenerator
 
onEvent(T, long, WatermarkOutput) - Method in interface org.apache.flink.api.common.eventtime.WatermarkGenerator
Called for every event, allows the watermark generator to examine and remember the event timestamps, or to emit a watermark based on the event itself.
onEvent(T, long, WatermarkOutput) - Method in class org.apache.flink.api.common.eventtime.WatermarksWithIdleness
 
onJobExecuted(JobExecutionResult, Throwable) - Method in interface org.apache.flink.core.execution.JobListener
Callback on job execution finished, successfully or unsuccessfully.
onJobSubmitted(JobClient, Throwable) - Method in interface org.apache.flink.core.execution.JobListener
Callback on job submission.
onPeriodicEmit(WatermarkOutput) - Method in class org.apache.flink.api.common.eventtime.BoundedOutOfOrdernessWatermarks
 
onPeriodicEmit(WatermarkOutput) - Method in class org.apache.flink.api.common.eventtime.NoWatermarksGenerator
 
onPeriodicEmit(WatermarkOutput) - Method in interface org.apache.flink.api.common.eventtime.WatermarkGenerator
Called periodically, and might emit a new watermark, or not.
onPeriodicEmit() - Method in class org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Tells the WatermarkOutputMultiplexer to combine all outstanding deferred watermark updates and possibly emit a new update to the underlying WatermarkOutput.
onPeriodicEmit(WatermarkOutput) - Method in class org.apache.flink.api.common.eventtime.WatermarksWithIdleness
 
onProcessingTime(long) - Method in interface org.apache.flink.api.connector.sink.Sink.ProcessingTimeService.ProcessingTimeCallback
This method is invoked with the time which the callback register for.
open(Configuration) - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
open(Configuration) - Method in interface org.apache.flink.api.common.functions.RichFunction
Initialization method for the function.
open(int, int) - Method in class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
open(FileInputSplit) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
open(int, int) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Opens the given input split.
open(FileInputSplit) - Method in class org.apache.flink.api.common.io.FileInputFormat
Opens an input stream to the file defined in the input format.
open(int, int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
open(GenericInputSplit) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
open(T) - Method in interface org.apache.flink.api.common.io.InputFormat
Opens a parallel instance of the input format to work on a split.
open(int, int) - Method in interface org.apache.flink.api.common.io.OutputFormat
Opens a parallel instance of the output format to store the result of its parallel instance.
open(RuntimeContext) - Method in interface org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
A method that can be used to create and configure a ratelimiter based on the runtimeContext.
open(RuntimeContext) - Method in class org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
Creates a rate limiter with the runtime context provided.
open(S) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
open(Configuration) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
 
open(DeserializationSchema.InitializationContext) - Method in interface org.apache.flink.api.common.serialization.DeserializationSchema
Initialization method for the schema.
open(SerializationSchema.InitializationContext) - Method in interface org.apache.flink.api.common.serialization.SerializationSchema
Initialization method for the schema.
open(Path, int) - Method in class org.apache.flink.core.fs.FileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path) - Method in class org.apache.flink.core.fs.FileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path, int) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
open(Path) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
open(Path, int) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
open(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
open(Path) - Method in class org.apache.flink.core.fs.local.LocalRecoverableWriter
 
open(Path) - Method in interface org.apache.flink.core.fs.RecoverableWriter
Opens a new recoverable stream to write to the given path.
open(Path, int) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
open(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
openFunction(Function, Configuration) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
openInputFormat() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
openInputFormat() - Method in class org.apache.flink.api.common.io.RichInputFormat
Opens this InputFormat instance.
openTimeout - Variable in class org.apache.flink.api.common.io.FileInputFormat
Stream opening timeout.
OperatingSystem - Enum in org.apache.flink.util
An enumeration indicating the operating system that the JVM runs on.
Operator<OUT> - Class in org.apache.flink.api.common.operators
Abstract base class for all operators.
Operator(OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.Operator
Creates a new contract with the given name.
OPERATOR_CHAINING - Static variable in class org.apache.flink.configuration.PipelineOptions
 
operatorInfo - Variable in class org.apache.flink.api.common.operators.Operator
The return type of the user function.
OperatorInformation<OUT> - Class in org.apache.flink.api.common.operators
A class for holding information about an operator, such as input/output TypeInformation.
OperatorInformation(TypeInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.OperatorInformation
 
OperatorStateStore - Interface in org.apache.flink.api.common.state
This interface contains methods for registering operator state with a managed store.
OperatorValidationUtils - Class in org.apache.flink.api.common.operators.util
Utils for checking operators' resource and parallelism settings.
OptimizerOptions - Class in org.apache.flink.configuration
Configuration options for the optimizer.
OptimizerOptions() - Constructor for class org.apache.flink.configuration.OptimizerOptions
 
OptionalConsumer<T> - Class in org.apache.flink.util
Utility class which allows to run code depending on whether the optional has a value or is empty.
OptionalFailure<T> - Class in org.apache.flink.util
Wrapper around an object representing either a success (with a given value) or a failure cause.
optionalMapOf(Map<K, V>, Function<K, String>) - Static method in class org.apache.flink.util.LinkedOptionalMap
Creates an LinkedOptionalMap from the provided map.
Order - Enum in org.apache.flink.api.common.operators
Enumeration representing order.
Ordering - Class in org.apache.flink.api.common.operators
This class represents an ordering on a set of fields.
Ordering() - Constructor for class org.apache.flink.api.common.operators.Ordering
Creates an empty ordering.
Ordering(int, Class<? extends Comparable<?>>, Order) - Constructor for class org.apache.flink.api.common.operators.Ordering
 
orders - Variable in class org.apache.flink.api.common.operators.Ordering
 
org.apache.flink.api.common - package org.apache.flink.api.common
 
org.apache.flink.api.common.accumulators - package org.apache.flink.api.common.accumulators
 
org.apache.flink.api.common.aggregators - package org.apache.flink.api.common.aggregators
 
org.apache.flink.api.common.cache - package org.apache.flink.api.common.cache
 
org.apache.flink.api.common.distributions - package org.apache.flink.api.common.distributions
 
org.apache.flink.api.common.eventtime - package org.apache.flink.api.common.eventtime
 
org.apache.flink.api.common.externalresource - package org.apache.flink.api.common.externalresource
 
org.apache.flink.api.common.functions - package org.apache.flink.api.common.functions
 
org.apache.flink.api.common.functions.util - package org.apache.flink.api.common.functions.util
 
org.apache.flink.api.common.io - package org.apache.flink.api.common.io
 
org.apache.flink.api.common.io.compression - package org.apache.flink.api.common.io.compression
 
org.apache.flink.api.common.io.ratelimiting - package org.apache.flink.api.common.io.ratelimiting
 
org.apache.flink.api.common.io.statistics - package org.apache.flink.api.common.io.statistics
 
org.apache.flink.api.common.operators - package org.apache.flink.api.common.operators
 
org.apache.flink.api.common.operators.base - package org.apache.flink.api.common.operators.base
 
org.apache.flink.api.common.operators.util - package org.apache.flink.api.common.operators.util
 
org.apache.flink.api.common.resources - package org.apache.flink.api.common.resources
 
org.apache.flink.api.common.restartstrategy - package org.apache.flink.api.common.restartstrategy
 
org.apache.flink.api.common.serialization - package org.apache.flink.api.common.serialization
 
org.apache.flink.api.common.state - package org.apache.flink.api.common.state
 
org.apache.flink.api.common.time - package org.apache.flink.api.common.time
 
org.apache.flink.api.common.typeinfo - package org.apache.flink.api.common.typeinfo
 
org.apache.flink.api.common.typeutils - package org.apache.flink.api.common.typeutils
 
org.apache.flink.api.common.typeutils.base - package org.apache.flink.api.common.typeutils.base
 
org.apache.flink.api.common.typeutils.base.array - package org.apache.flink.api.common.typeutils.base.array
 
org.apache.flink.api.connector.sink - package org.apache.flink.api.connector.sink
 
org.apache.flink.api.connector.source - package org.apache.flink.api.connector.source
 
org.apache.flink.api.connector.source.lib - package org.apache.flink.api.connector.source.lib
 
org.apache.flink.api.connector.source.lib.util - package org.apache.flink.api.connector.source.lib.util
 
org.apache.flink.api.dag - package org.apache.flink.api.dag
 
org.apache.flink.api.java - package org.apache.flink.api.java
 
org.apache.flink.api.java.functions - package org.apache.flink.api.java.functions
 
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.configuration - package org.apache.flink.configuration
 
org.apache.flink.configuration.description - package org.apache.flink.configuration.description
 
org.apache.flink.core.classloading - package org.apache.flink.core.classloading
 
org.apache.flink.core.execution - package org.apache.flink.core.execution
 
org.apache.flink.core.fs - package org.apache.flink.core.fs
 
org.apache.flink.core.fs.local - package org.apache.flink.core.fs.local
 
org.apache.flink.core.io - package org.apache.flink.core.io
 
org.apache.flink.core.memory - package org.apache.flink.core.memory
 
org.apache.flink.core.plugin - package org.apache.flink.core.plugin
 
org.apache.flink.core.security - package org.apache.flink.core.security
 
org.apache.flink.management.jmx - package org.apache.flink.management.jmx
 
org.apache.flink.types - package org.apache.flink.types
 
org.apache.flink.types.parser - package org.apache.flink.types.parser
 
org.apache.flink.util - package org.apache.flink.util
 
org.apache.flink.util.clock - package org.apache.flink.util.clock
 
org.apache.flink.util.concurrent - package org.apache.flink.util.concurrent
 
org.apache.flink.util.function - package org.apache.flink.util.function
 
orTimeout(CompletableFuture<T>, long, TimeUnit) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Times the given future out after the timeout.
orTimeout(CompletableFuture<T>, long, TimeUnit, String) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Times the given future out after the timeout.
orTimeout(CompletableFuture<T>, long, TimeUnit, Executor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Times the given future out after the timeout.
orTimeout(CompletableFuture<T>, long, TimeUnit, Executor, String) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Times the given future out after the timeout.
OuterJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
OuterJoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String, OuterJoinOperatorBase.OuterJoinType) - Constructor for class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
OuterJoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String, OuterJoinOperatorBase.OuterJoinType) - Constructor for class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
OuterJoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String, OuterJoinOperatorBase.OuterJoinType) - Constructor for class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
OuterJoinOperatorBase.OuterJoinType - Enum in org.apache.flink.api.common.operators.base
 
outputFilePath - Variable in class org.apache.flink.api.common.io.FileOutputFormat
The path of the file to be written.
OutputFormat<IT> - Interface in org.apache.flink.api.common.io
The base interface for outputs that consumes records.
outputStream - Variable in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
OutputStreamAndPath - Class in org.apache.flink.core.fs
An output stream and a path.
OutputStreamAndPath(FSDataOutputStream, Path) - Constructor for class org.apache.flink.core.fs.OutputStreamAndPath
Creates a OutputStreamAndPath.
OutputTag<T> - Class in org.apache.flink.util
An OutputTag is a typed and named tag to use for tagging side outputs of an operator.
OutputTag(String) - Constructor for class org.apache.flink.util.OutputTag
Creates a new named OutputTag with the given id.
OutputTag(String, TypeInformation<T>) - Constructor for class org.apache.flink.util.OutputTag
Creates a new named OutputTag with the given id and output TypeInformation.
outputType - Variable in class org.apache.flink.api.common.operators.OperatorInformation
Output type of the operator
outputType - Variable in class org.apache.flink.api.dag.Transformation
 
outputView - Variable in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 

P

PACKAGE_SEPARATOR - Static variable in class org.apache.flink.util.FileUtils
 
PARALLELISM_AUTO_MAX - Static variable in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
PARALLELISM_DEFAULT - Static variable in class org.apache.flink.api.common.ExecutionConfig
The flag value indicating use of the default parallelism.
PARALLELISM_UNKNOWN - Static variable in class org.apache.flink.api.common.ExecutionConfig
The flag value indicating an unknown or unset parallelism.
ParameterlessTypeSerializerConfig<T> - Class in org.apache.flink.api.common.typeutils
Deprecated.
this snapshot class is no longer used by any serializers, and is maintained only for backward compatibility reasons. It is fully replaced by SimpleTypeSerializerSnapshot.
ParameterlessTypeSerializerConfig() - Constructor for class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
ParameterlessTypeSerializerConfig(String) - Constructor for class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
Deprecated.
 
parameters - Variable in class org.apache.flink.api.common.operators.Operator
 
PARENT_FIRST_LOGGING_PATTERNS - Static variable in class org.apache.flink.configuration.CoreOptions
 
parse(String) - Static method in class org.apache.flink.configuration.MemorySize
Parses the given string as as MemorySize.
parse(String, MemorySize.MemoryUnit) - Static method in class org.apache.flink.configuration.MemorySize
Parses the given string with a default unit.
parseBytes(String) - Static method in class org.apache.flink.configuration.MemorySize
Parses the given string as bytes.
parseCachedFilesFromString(List<String>) - Static method in class org.apache.flink.api.common.cache.DistributedCache
Parses a list of distributed cache entries encoded in a string.
parseDuration(String) - Static method in class org.apache.flink.util.TimeUtils
Parse the given string to a java Duration.
ParseException - Exception in org.apache.flink.api.common.io
Exception indicating that the parsing of input contents has failed because the data does not match the configured parser.
ParseException() - Constructor for exception org.apache.flink.api.common.io.ParseException
 
ParseException(String) - Constructor for exception org.apache.flink.api.common.io.ParseException
 
ParseException(Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
 
ParseException(String, Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
 
parseField(byte[], int, int, byte[], BigDecimal) - Method in class org.apache.flink.types.parser.BigDecParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.BigDecParser
Static utility to parse a field of type BigDecimal from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.BigDecParser
Static utility to parse a field of type BigDecimal from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], BigInteger) - Method in class org.apache.flink.types.parser.BigIntParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.BigIntParser
Static utility to parse a field of type BigInteger from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.BigIntParser
Static utility to parse a field of type BigInteger from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], Boolean) - Method in class org.apache.flink.types.parser.BooleanParser
 
parseField(byte[], int, int, byte[], BooleanValue) - Method in class org.apache.flink.types.parser.BooleanValueParser
 
parseField(byte[], int, int, byte[], Byte) - Method in class org.apache.flink.types.parser.ByteParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.ByteParser
Static utility to parse a field of type byte from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.ByteParser
Static utility to parse a field of type byte from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], ByteValue) - Method in class org.apache.flink.types.parser.ByteValueParser
 
parseField(byte[], int, int, byte[], Double) - Method in class org.apache.flink.types.parser.DoubleParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.DoubleParser
Static utility to parse a field of type double from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.DoubleParser
Static utility to parse a field of type double from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], DoubleValue) - Method in class org.apache.flink.types.parser.DoubleValueParser
 
parseField(byte[], int, int, byte[], T) - Method in class org.apache.flink.types.parser.FieldParser
Each parser's logic should be implemented inside this method
parseField(byte[], int, int, byte[], Float) - Method in class org.apache.flink.types.parser.FloatParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.FloatParser
Static utility to parse a field of type float from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.FloatParser
Static utility to parse a field of type float from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], FloatValue) - Method in class org.apache.flink.types.parser.FloatValueParser
 
parseField(byte[], int, int, byte[], Integer) - Method in class org.apache.flink.types.parser.IntParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.IntParser
Static utility to parse a field of type int from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.IntParser
Static utility to parse a field of type int from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], IntValue) - Method in class org.apache.flink.types.parser.IntValueParser
 
parseField(byte[], int, int, byte[], Long) - Method in class org.apache.flink.types.parser.LongParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.LongParser
Static utility to parse a field of type long from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.LongParser
Static utility to parse a field of type long from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], LongValue) - Method in class org.apache.flink.types.parser.LongValueParser
 
parseField(byte[], int, int, byte[], Short) - Method in class org.apache.flink.types.parser.ShortParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.ShortParser
Static utility to parse a field of type short from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.ShortParser
Static utility to parse a field of type short from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], ShortValue) - Method in class org.apache.flink.types.parser.ShortValueParser
 
parseField(byte[], int, int, byte[], Date) - Method in class org.apache.flink.types.parser.SqlDateParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.SqlDateParser
Static utility to parse a field of type Date from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.SqlDateParser
Static utility to parse a field of type Date from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], Time) - Method in class org.apache.flink.types.parser.SqlTimeParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.SqlTimeParser
Static utility to parse a field of type Time from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.SqlTimeParser
Static utility to parse a field of type Time from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], Timestamp) - Method in class org.apache.flink.types.parser.SqlTimestampParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.SqlTimestampParser
Static utility to parse a field of type Timestamp from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.SqlTimestampParser
Static utility to parse a field of type Timestamp from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], String) - Method in class org.apache.flink.types.parser.StringParser
 
parseField(byte[], int, int, byte[], StringValue) - Method in class org.apache.flink.types.parser.StringValueParser
 
parseHostPortAddress(String) - Static method in class org.apache.flink.util.NetUtils
Converts a string of the form "host:port" into an InetSocketAddress.
parseJvmArgString(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
 
parseLocalStateDirectories(Configuration) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Extracts the local state directories as defined by CheckpointingOptions.LOCAL_RECOVERY_TASK_MANAGER_STATE_ROOT_DIRS.
parseMap(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Parses a string as a map of strings.
parseParentFirstLoaderPatterns(String, String) - Static method in class org.apache.flink.configuration.CoreOptions
 
parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
parseTempDirectories(Configuration) - Static method in class org.apache.flink.configuration.ConfigurationUtils
Extracts the task manager directories for temporary files as defined by CoreOptions.TMP_DIRS.
parseTmResourceDynamicConfigs(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
 
PartialSolutionPlaceHolder(BulkIterationBase<OT>, OperatorInformation<OT>) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
partition(K, int) - Method in interface org.apache.flink.api.common.functions.Partitioner
Computes the partition for the given key.
partition(Collection<T>, int) - Static method in class org.apache.flink.util.CollectionUtil
Partition a collection into approximately n buckets.
PARTITION_RELEASE_DURING_JOB_EXECUTION - Static variable in class org.apache.flink.configuration.JobManagerOptions
Config parameter controlling whether partitions should already be released during the job execution.
Partitioner<K> - Interface in org.apache.flink.api.common.functions
Function to implement a custom partition assignment for keys.
partitionNumber - Variable in class org.apache.flink.api.common.io.GenericInputFormat
The partition of this split.
PartitionOperatorBase<IN> - Class in org.apache.flink.api.common.operators.base
 
PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, String) - Constructor for class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
PartitionOperatorBase.PartitionMethod - Enum in org.apache.flink.api.common.operators.base
 
path() - Method in class org.apache.flink.core.fs.OutputStreamAndPath
 
Path - Class in org.apache.flink.core.fs
Names a file or directory in a FileSystem.
Path() - Constructor for class org.apache.flink.core.fs.Path
Constructs a new (empty) path object (used to reconstruct path object after RPC call).
Path(URI) - Constructor for class org.apache.flink.core.fs.Path
Constructs a path object from a given URI.
Path(String, String) - Constructor for class org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(Path, String) - Constructor for class org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(String, Path) - Constructor for class org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(Path, Path) - Constructor for class org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(String) - Constructor for class org.apache.flink.core.fs.Path
Construct a path from a String.
Path(String, String, String) - Constructor for class org.apache.flink.core.fs.Path
Construct a Path from a scheme, an authority and a path string.
PATH_HADOOP_CONFIG - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Use environment variable HADOOP_CONF_DIR instead.
pathToFile(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
Converts the given Path to a File for this file system.
persist() - Method in class org.apache.flink.core.fs.RecoverableFsDataOutputStream
Ensures all data so far is persistent (similar to FSDataOutputStream.sync()) and returns a handle to recover the stream at the current position.
Pipeline - Interface in org.apache.flink.api.dag
Common interface for Flink pipelines.
PIPELINE_FIXED_JOB_ID - Static variable in class org.apache.flink.configuration.PipelineOptionsInternal
 
PipelineExecutor - Interface in org.apache.flink.core.execution
The entity responsible for executing a Pipeline, i.e.
PipelineExecutorFactory - Interface in org.apache.flink.core.execution
A factory for selecting and instantiating the adequate PipelineExecutor based on a provided Configuration.
PipelineExecutorServiceLoader - Interface in org.apache.flink.core.execution
An interface to be implemented by the entity responsible for finding the correct PipelineExecutor to execute a given Pipeline.
PipelineOptions - Class in org.apache.flink.configuration
The configuration options for job execution.
PipelineOptions() - Constructor for class org.apache.flink.configuration.PipelineOptions
 
PipelineOptionsInternal - Class in org.apache.flink.configuration
Pipeline options that are not meant to be used by the user.
PipelineOptionsInternal() - Constructor for class org.apache.flink.configuration.PipelineOptionsInternal
 
Plan - Class in org.apache.flink.api.common
This class represents Flink programs, in the form of dataflow plans.
Plan(Collection<? extends GenericDataSinkBase<?>>, String) - Constructor for class org.apache.flink.api.common.Plan
Creates a new dataflow plan with the given name, describing the data flow that ends at the given data sinks.
Plan(Collection<? extends GenericDataSinkBase<?>>, String, int) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with the given name and default parallelism, describing the data flow that ends at the given data sinks.
Plan(GenericDataSinkBase<?>, String) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with the given name, containing initially a single data sink.
Plan(GenericDataSinkBase<?>, String, int) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with the given name and default parallelism, containing initially a single data sink.
Plan(Collection<? extends GenericDataSinkBase<?>>) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan, describing the data flow that ends at the given data sinks.
Plan(Collection<? extends GenericDataSinkBase<?>>, int) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with the given default parallelism, describing the data flow that ends at the given data sinks.
Plan(GenericDataSinkBase<?>) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with single data sink.
Plan(GenericDataSinkBase<?>, int) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with single data sink and the given default parallelism.
Plugin - Interface in org.apache.flink.core.plugin
Interface for plugins.
PLUGIN_ALWAYS_PARENT_FIRST_LOADER_PATTERNS - Static variable in class org.apache.flink.configuration.CoreOptions
PLUGIN_ALWAYS_PARENT_FIRST_LOADER_PATTERNS_ADDITIONAL - Static variable in class org.apache.flink.configuration.CoreOptions
 
PluginConfig - Class in org.apache.flink.core.plugin
Stores the configuration for plugins mechanism.
PluginDescriptor - Class in org.apache.flink.core.plugin
Descriptive meta information for a plugin.
PluginDescriptor(String, URL[], String[]) - Constructor for class org.apache.flink.core.plugin.PluginDescriptor
 
PluginFileSystemFactory - Class in org.apache.flink.core.fs
A wrapper around FileSystemFactory that ensures the plugin classloader is used for all FileSystem operations.
PluginFinder - Interface in org.apache.flink.core.plugin
Implementations of this interface provide mechanisms to locate plugins and create corresponding PluginDescriptor objects.
PluginLoader - Class in org.apache.flink.core.plugin
A PluginLoader is used by the PluginManager to load a single plugin.
PluginLoader(String, URLClassLoader) - Constructor for class org.apache.flink.core.plugin.PluginLoader
 
PluginManager - Interface in org.apache.flink.core.plugin
PluginManager is responsible for managing cluster plugins which are loaded using separate class loaders so that their dependencies don't interfere with Flink's dependencies.
PluginUtils - Class in org.apache.flink.core.plugin
Utility functions for the plugin mechanism.
plus(Duration) - Method in class org.apache.flink.api.common.time.Deadline
 
POJO(Class<T>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for a POJO (Plain Old Java Object).
POJO(Class<T>, Map<String, TypeInformation<?>>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for a POJO (Plain Old Java Object) and allows to specify all fields manually.
POJO_REGISTERED_CLASSES - Static variable in class org.apache.flink.configuration.PipelineOptions
 
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
Constructor to create a new PojoSerializer.
PojoSerializer.PojoSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
Deprecated.
This snapshot class is no longer being used. It has been fully replaced by PojoSerializerSnapshot.
PojoSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
PojoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, LinkedHashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, HashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
PojoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, LinkedHashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, HashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>, boolean) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
PojoSerializerSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
Snapshot class for the PojoSerializer.
PojoSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
Constructor for reading the snapshot.
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
 
pollNext(ReaderOutput<E>) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
pollNext(ReaderOutput<T>) - Method in interface org.apache.flink.api.connector.source.SourceReader
Poll the next available record into the SourceOutput.
PORT - Static variable in class org.apache.flink.configuration.BlobServerOptions
The config parameter defining the server port of the blob service.
PORT - Static variable in class org.apache.flink.configuration.JobManagerOptions
The config parameter defining the network port to connect to for communication with the job manager.
PORT - Static variable in class org.apache.flink.configuration.RestOptions
The port that the REST client connects to and the REST server binds to if RestOptions.BIND_PORT has not been specified.
PORT - Static variable in class org.apache.flink.configuration.WebOptions
Deprecated.
Use RestOptions.PORT instead
PostVersionedIOReadableWritable - Class in org.apache.flink.core.io
A VersionedIOReadableWritable which allows to differentiate whether the previous data was versioned with a VersionedIOReadableWritable.
PostVersionedIOReadableWritable() - Constructor for class org.apache.flink.core.io.PostVersionedIOReadableWritable
 
postVisit(T) - Method in interface org.apache.flink.util.Visitor
Method that is invoked after all child nodes or descendant nodes were visited.
Preconditions - Class in org.apache.flink.util
A collection of static utility methods to validate input.
prepareCommit(boolean) - Method in interface org.apache.flink.api.connector.sink.SinkWriter
Prepare for a commit.
preVisit(T) - Method in interface org.apache.flink.util.Visitor
Method that is invoked on the visit before visiting and child nodes or descendant nodes.
PRIMITIVE_ARRAY(TypeInformation<?>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Java arrays of primitive type (such as byte[]).
PrimitiveArrayComparator<T,C extends BasicTypeComparator> - Class in org.apache.flink.api.common.typeutils.base.array
 
PrimitiveArrayComparator(boolean, C) - Constructor for class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
PrimitiveArrayTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
A TypeInformation for arrays of primitive types (int, long, double, ...).
PrintSinkOutputWriter<IN> - Class in org.apache.flink.api.common.functions.util
Print sink output writer for DataStream and DataSet print API.
PrintSinkOutputWriter() - Constructor for class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
PrintSinkOutputWriter(boolean) - Constructor for class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
PrintSinkOutputWriter(String, boolean) - Constructor for class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
printStackTrace(PrintStream) - Method in exception org.apache.flink.util.SerializedThrowable
 
printStackTrace(PrintWriter) - Method in exception org.apache.flink.util.SerializedThrowable
 
privateDuplicate(TupleComparatorBase<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
Prober(TypeComparator<PT>, TypePairComparator<PT, BT>) - Constructor for class org.apache.flink.api.common.operators.util.JoinHashMap.Prober
 
processAsByteBuffer(Function<ByteBuffer, T>) - Method in class org.apache.flink.core.memory.MemorySegment
Applies the given process function on a ByteBuffer that represents this entire segment.
processAsByteBuffer(Consumer<ByteBuffer>) - Method in class org.apache.flink.core.memory.MemorySegment
Supplies a ByteBuffer that represents this entire segment to the given process consumer.
ProcessorArchitecture - Enum in org.apache.flink.util
The processor architecture of the this system.
ProcessorArchitecture.MemoryAddressSize - Enum in org.apache.flink.util
The memory address size of the processor.
ProgramDescription - Interface in org.apache.flink.api.common
Implementing this interface allows a Program to have a description of the plan which can be shown to the user.
project(Row, int[]) - Static method in class org.apache.flink.types.Row
Creates a new row with projected fields and identical RowKind from another row.
project(Row, String[]) - Static method in class org.apache.flink.types.Row
Creates a new row with projected fields and identical RowKind from another row.
project(Collection<I>, Function<I, O>) - Static method in class org.apache.flink.util.CollectionUtil
 
projectFields(RowTypeInfo, int[]) - Static method in class org.apache.flink.api.java.typeutils.RowTypeInfo
Creates a RowTypeInfo with projected fields.
PropertiesUtil - Class in org.apache.flink.util
Simple utilities for getting typed values from Properties.
PROXY_ASYNC_QUERY_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Number of async query threads for the client proxy (0 => #slots).
PROXY_NETWORK_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Number of network (event loop) threads for the client proxy (0 => #slots).
PROXY_PORT_RANGE - Static variable in class org.apache.flink.configuration.QueryableStateOptions
The config parameter defining the server port range of the queryable state proxy.
put(K, V) - Method in interface org.apache.flink.api.common.state.BroadcastState
Associates a new value with the given key.
put(UK, UV) - Method in interface org.apache.flink.api.common.state.MapState
Associates a new value with the given key.
put(int, byte) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given byte into this buffer at the given position.
put(int, byte[]) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(DataInput, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(K, V) - Method in class org.apache.flink.types.MapValue
 
put(String, K, V) - Method in class org.apache.flink.util.LinkedOptionalMap
 
putAll(Map<K, V>) - Method in interface org.apache.flink.api.common.state.BroadcastState
Copies all of the mappings from the given map into the state.
putAll(Map<UK, UV>) - Method in interface org.apache.flink.api.common.state.MapState
Copies all of the mappings from the given map into the state.
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.flink.types.MapValue
 
putBoolean(int, boolean) - Method in class org.apache.flink.core.memory.MemorySegment
Writes one byte containing the byte value into this buffer at the given position.
putBooleanNormalizedKey(boolean, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putByteNormalizedKey(byte, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putChar(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
Writes a char value to the given position, in the system's native byte order.
putCharBigEndian(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given character (16 bit, 2 bytes) to the given position in big-endian byte order.
putCharLittleEndian(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given character (16 bit, 2 bytes) to the given position in little-endian byte order.
putCharNormalizedKey(char, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putDouble(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in the system's native byte order.
putDoubleBigEndian(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in big endian byte order.
putDoubleLittleEndian(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in little endian byte order.
putFloat(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given single-precision float value (32bit, 4 bytes) to the given position in the system's native byte order.
putFloatBigEndian(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given single-precision float value (32bit, 4 bytes) to the given position in big endian byte order.
putFloatLittleEndian(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given single-precision float value (32bit, 4 bytes) to the given position in little endian byte order.
putInt(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given int value (32bit, 4 bytes) to the given position in the system's native byte order.
putIntBigEndian(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given int value (32bit, 4 bytes) to the given position in big endian byte order.
putIntLittleEndian(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given int value (32bit, 4 bytes) to the given position in little endian byte order.
putIntNormalizedKey(int, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putLong(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given long value (64bit, 8 bytes) to the given position in the system's native byte order.
putLongBigEndian(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given long value (64bit, 8 bytes) to the given position in big endian byte order.
putLongLittleEndian(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given long value (64bit, 8 bytes) to the given position in little endian byte order.
putLongNormalizedKey(long, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
putNormalizedKey(BigDecimal, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
Adds a normalized key containing a normalized order of magnitude of the given record.
putNormalizedKey(BigInteger, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
Adds a normalized key containing the normalized number of bits and MSBs of the given record.
putNormalizedKey(Boolean, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
putNormalizedKey(BooleanValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
putNormalizedKey(Byte, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
putNormalizedKey(ByteValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
putNormalizedKey(Character, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
putNormalizedKey(CharValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
putNormalizedKey(Date, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
putNormalizedKey(Double, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
putNormalizedKey(DoubleValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
putNormalizedKey(Float, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
putNormalizedKey(FloatValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
putNormalizedKey(Instant, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.InstantComparator
 
putNormalizedKey(Integer, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
putNormalizedKey(IntValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
putNormalizedKey(LocalDate, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
putNormalizedKey(LocalDateTime, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
putNormalizedKey(LocalTime, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
putNormalizedKey(Long, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
putNormalizedKey(LongValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
putNormalizedKey(NullValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
putNormalizedKey(Short, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
putNormalizedKey(ShortValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
putNormalizedKey(Date, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
putNormalizedKey(String, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
putNormalizedKey(StringValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Writes a normalized key for the given record into the target byte array, starting at the specified position and writing exactly the given number of bytes.
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.NullAwareComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
putNormalizedKey(Row, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
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
 
putNormalizedKeyDate(Date, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
putNormalizedKeyLocalDate(LocalDate, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
putNormalizedKeyLocalTime(LocalTime, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
putShort(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given short value into this buffer at the given position, using the native byte order of the system.
putShortBigEndian(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given short integer value (16 bit, 2 bytes) to the given position in big-endian byte order.
putShortLittleEndian(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given short integer value (16 bit, 2 bytes) to the given position in little-endian byte order.
putShortNormalizedKey(short, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putUnsignedIntegerNormalizedKey(int, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 
putUnsignedLongNormalizedKey(long, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.NormalizedKeyUtil
 

Q

QuadConsumer<S,T,U,V> - Interface in org.apache.flink.util.function
Operation which is performed on four given arguments.
QuadFunction<S,T,U,V,R> - Interface in org.apache.flink.util.function
Function which takes three arguments.
QUERY_SERVICE_PORT - Static variable in class org.apache.flink.configuration.MetricOptions
The default network port range for Flink's internal metric query service.
QUERY_SERVICE_THREAD_PRIORITY - Static variable in class org.apache.flink.configuration.MetricOptions
The thread priority for Flink's internal metric query service.
QueryableStateOptions - Class in org.apache.flink.configuration
The set of configuration options relating to Queryable State.

R

RangeBoundaries<T> - Interface in org.apache.flink.api.common.distributions
RangeBoundaries is used to split the records into multiple ranges.
reachedEnd() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
reachedEnd() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Checks whether the current split is at its end.
reachedEnd() - Method in interface org.apache.flink.api.common.io.InputFormat
Method used to check if the end of the input is reached.
reachedEnd() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
read() - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
read(byte[]) - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
read(byte[], int, int) - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
read(DataInputView) - Method in class org.apache.flink.api.common.io.BlockInfo
 
read() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
read(byte[], int, int) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
read(byte[]) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
Deprecated.
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
Deprecated.
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
Deprecated.
 
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) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
 
read(Kryo, Input, Class<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroKryoSerializerClass
 
read(Kryo, Input, Class) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
 
read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
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
 
read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.configuration.Configuration
 
read(DataInputView) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
read() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
read(byte[]) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
read(byte[], int, int) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
read() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
read(byte[], int, int) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
read(DataInputView) - Method in class org.apache.flink.core.fs.Path
 
read(DataInputView) - Method in interface org.apache.flink.core.io.IOReadableWritable
Reads the object's internal data from the given data input view.
read(DataInputView, boolean) - Method in class org.apache.flink.core.io.PostVersionedIOReadableWritable
Read from the provided in.
read(InputStream) - Method in class org.apache.flink.core.io.PostVersionedIOReadableWritable
This read attempts to first identify if the input view contains the special PostVersionedIOReadableWritable.VERSIONED_IDENTIFIER by reading and buffering the first few bytes.
read(DataInputView) - Method in class org.apache.flink.core.io.PostVersionedIOReadableWritable
We do not support reading from a DataInputView, because it does not support pushing back already read bytes.
read(DataInputView) - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
 
read(byte[], int, int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
read(byte[]) - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
read(byte[], int, int) - Method in interface org.apache.flink.core.memory.DataInputView
Reads up to len bytes of memory and stores it into b starting at offset off.
read(byte[]) - Method in interface org.apache.flink.core.memory.DataInputView
Tries to fill the given byte array b.
read() - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
read(byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
read(DataInputView) - Method in class org.apache.flink.types.BooleanValue
 
read(DataInputView) - Method in class org.apache.flink.types.ByteValue
 
read(DataInputView) - Method in class org.apache.flink.types.CharValue
 
read(DataInputView) - Method in class org.apache.flink.types.DoubleValue
 
read(DataInputView) - Method in class org.apache.flink.types.FloatValue
 
read(DataInputView) - Method in class org.apache.flink.types.IntValue
 
read(DataInputView) - Method in class org.apache.flink.types.ListValue
 
read(DataInputView) - Method in class org.apache.flink.types.LongValue
 
read(DataInputView) - Method in class org.apache.flink.types.MapValue
 
read(DataInputView) - Method in class org.apache.flink.types.NullValue
 
read(DataInputView) - Method in class org.apache.flink.types.Record
 
read(DataInputView) - Method in class org.apache.flink.types.ShortValue
 
read(DataInputView) - Method in class org.apache.flink.types.StringValue
 
READ_WHOLE_SPLIT_FLAG - Static variable in class org.apache.flink.api.common.io.FileInputFormat
The splitLength is set to -1L for reading the whole split.
ReadableConfig - Interface in org.apache.flink.configuration
Read access to a configuration object.
readAllBytes(Path) - Static method in class org.apache.flink.util.FileUtils
Reads all the bytes from a file.
readAndInstantiateSnapshotClass(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
 
readBigDecimal(DataInputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
readBigInteger(DataInputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
readBoolean() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readByte() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readBytes(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
readChar() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readClassDescriptor() - Method in class org.apache.flink.util.InstantiationUtil.FailureTolerantObjectInputStream
 
readDouble() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
ReaderInfo - Class in org.apache.flink.api.connector.source
A container class hosting the information of a SourceReader.
ReaderInfo(int, String) - Constructor for class org.apache.flink.api.connector.source.ReaderInfo
 
ReaderOutput<T> - Interface in org.apache.flink.api.connector.source
The interface provided by the Flink runtime to the SourceReader to emit records, and optionally watermarks, to downstream operators for message processing.
readFile(File, String) - Static method in class org.apache.flink.util.FileUtils
 
readFileInfoFromConfig(Configuration) - Static method in class org.apache.flink.api.common.cache.DistributedCache
 
readFileUtf8(File) - Static method in class org.apache.flink.util.FileUtils
 
readFloat() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readFully(byte[]) - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readFully(byte[], int, int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readFully(InputStream, byte[], int, int) - Static method in class org.apache.flink.util.IOUtils
Reads len bytes in a loop.
readInt() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readIntoAndCopyMask(DataInputView, DataOutputView, boolean[]) - Static method in class org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
readIntoAndCopyMask(DataInputView, DataOutputView, boolean[], int) - Static method in class org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
readIntoMask(DataInputView, boolean[]) - Static method in class org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
readIntoMask(DataInputView, boolean[], int) - Static method in class org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
readLine() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
readLine() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readLong() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readNestedSerializerSnapshots(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Reads the composite snapshot of all the contained serializers.
readNullableString(DataInputView) - Static method in class org.apache.flink.util.StringUtils
Reads a String from the given input.
readObjectFromConfig(Configuration, String, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
 
ReadOnlyBroadcastState<K,V> - Interface in org.apache.flink.api.common.state
A read-only view of the BroadcastState.
readOptionalMap(DataInputView, BiFunctionWithException<DataInputView, String, K, IOException>, BiFunctionWithException<DataInputView, String, V, IOException>) - Static method in class org.apache.flink.util.LinkedOptionalMapSerializer
 
readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Reads the outer snapshot, i.e.
readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
readParametersFromConfig(Configuration, ClassLoader) - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
 
readParametersFromConfig(Configuration, ClassLoader) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
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(OT, byte[], int, int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
This function parses the given byte array which represents a serialized record.
readSerializersAndConfigsWithResilience(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Deprecated.
Reads from a data input view a list of serializers and their corresponding config snapshots written using TypeSerializerSerializationUtil.writeSerializersAndConfigsWithResilience(DataOutputView, List).
readSerializerSnapshot(DataInputView, ClassLoader, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
readShort() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
Deprecated.
 
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Deprecated.
 
readSnapshot(int, DataInputView, ClassLoader) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Reads the serializer snapshot from the provided DataInputView.
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
Deprecated.
 
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
readString(DataInput) - Static method in class org.apache.flink.types.StringValue
 
readString(DataInputView) - Static method in class org.apache.flink.util.StringUtils
Reads a non-null String from the given input.
readUnsignedByte() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readUnsignedShort() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readUTF() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
readVersionAndDeSerialize(SimpleVersionedSerializer<T>, DataInputView) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
Deserializes the version and datum from a stream.
readVersionAndDeSerialize(SimpleVersionedSerializer<T>, byte[]) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
Deserializes the version and datum from a byte array.
readVersionedSnapshot(DataInputView, ClassLoader) - Static method in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Reads a snapshot from the stream, performing resolving
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
readWithKeyDenormalization(BooleanValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
readWithKeyDenormalization(ByteValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
readWithKeyDenormalization(CharValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
readWithKeyDenormalization(DoubleValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
readWithKeyDenormalization(FloatValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
readWithKeyDenormalization(IntValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
readWithKeyDenormalization(LocalDate, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
readWithKeyDenormalization(LocalDateTime, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
readWithKeyDenormalization(LongValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
readWithKeyDenormalization(NullValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
readWithKeyDenormalization(ShortValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
readWithKeyDenormalization(StringValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Reads the record back while de-normalizing the key fields.
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.NullAwareComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
readWithKeyDenormalization(Row, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
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
 
Record - Class in org.apache.flink.types
The Record represents a multi-valued data record.
Record() - Constructor for class org.apache.flink.types.Record
Required nullary constructor for instantiation by serialization logic.
Record(Value) - Constructor for class org.apache.flink.types.Record
Creates a new record containing only a single field, which is the given value.
Record(Value, Value) - Constructor for class org.apache.flink.types.Record
Creates a new record containing exactly two fields, which are the given values.
Record(int) - Constructor for class org.apache.flink.types.Record
Creates a new record, containing the given number of fields.
RECORD_DELIMITER - Static variable in class org.apache.flink.api.common.io.DelimitedInputFormat
The configuration key to set the record delimiter.
RecordTimestampAssigner<E> - Class in org.apache.flink.api.common.eventtime
A TimestampAssigner that forwards the already-assigned timestamp.
RecordTimestampAssigner() - Constructor for class org.apache.flink.api.common.eventtime.RecordTimestampAssigner
 
recover(RecoverableWriter.ResumeRecoverable) - Method in class org.apache.flink.core.fs.local.LocalRecoverableWriter
 
recover(RecoverableWriter.ResumeRecoverable) - Method in interface org.apache.flink.core.fs.RecoverableWriter
Resumes a recoverable stream consistently at the point indicated by the given ResumeRecoverable.
RecoverableFsDataOutputStream - Class in org.apache.flink.core.fs
An output stream to a file system that can be recovered at well defined points.
RecoverableFsDataOutputStream() - Constructor for class org.apache.flink.core.fs.RecoverableFsDataOutputStream
 
RecoverableFsDataOutputStream.Committer - Interface in org.apache.flink.core.fs
A committer can publish the file of a stream that was closed.
RecoverableWriter - Interface in org.apache.flink.core.fs
The RecoverableWriter creates and recovers RecoverableFsDataOutputStream.
RecoverableWriter.CommitRecoverable - Interface in org.apache.flink.core.fs
A handle to an in-progress stream with a defined and persistent amount of data.
RecoverableWriter.ResumeRecoverable - Interface in org.apache.flink.core.fs
A handle to an in-progress stream with a defined and persistent amount of data.
recoverForCommit(RecoverableWriter.CommitRecoverable) - Method in class org.apache.flink.core.fs.local.LocalRecoverableWriter
 
recoverForCommit(RecoverableWriter.CommitRecoverable) - Method in interface org.apache.flink.core.fs.RecoverableWriter
Recovers a recoverable stream consistently at the point indicated by the given CommitRecoverable for finalizing and committing.
RECOVERY_JOB_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
This option is no longer used and has no effect on Flink.
RECOVERY_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of ConfigConstants.HA_JOB_MANAGER_PORT.
RECOVERY_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of ConfigConstants.HA_MODE.
recursivelyRegisterType(TypeInformation<?>, ExecutionConfig, Set<Class<?>>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
recursivelyRegisterType(Class<?>, ExecutionConfig, Set<Class<?>>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
recycleMemorySegments(Collection<MemorySegment>) - Method in interface org.apache.flink.core.memory.MemorySegmentProvider
 
reduce(Iterable<T>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.GroupReduceFunction
The reduce method.
reduce(T, T) - Method in interface org.apache.flink.api.common.functions.ReduceFunction
The core method of ReduceFunction, combining two values into one value of the same type.
reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichGroupReduceFunction
 
reduce(T, T) - Method in class org.apache.flink.api.common.functions.RichReduceFunction
 
ReduceFunction<T> - Interface in org.apache.flink.api.common.functions
Base interface for Reduce functions.
ReduceOperatorBase<T,FT extends ReduceFunction<T>> - Class in org.apache.flink.api.common.operators.base
Base data flow operator for Reduce user-defined functions.
ReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a grouped reduce data flow operator.
ReduceOperatorBase(FT, UnaryOperatorInformation<T, T>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a grouped reduce data flow operator.
ReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a grouped reduce data flow operator.
ReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a non-grouped reduce data flow operator (all-reduce).
ReduceOperatorBase(FT, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a non-grouped reduce data flow operator (all-reduce).
ReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a non-grouped reduce data flow operator (all-reduce).
ReduceOperatorBase.CombineHint - Enum in org.apache.flink.api.common.operators.base
An enumeration of hints, optionally usable to tell the system exactly how to execute the combiner phase of a reduce.
ReducingState<T> - Interface in org.apache.flink.api.common.state
State interface for reducing state.
ReducingStateDescriptor<T> - Class in org.apache.flink.api.common.state
ReducingStateDescriptor(String, ReduceFunction<T>, Class<T>) - Constructor for class org.apache.flink.api.common.state.ReducingStateDescriptor
Creates a new ReducingStateDescriptor with the given name, type, and default value.
ReducingStateDescriptor(String, ReduceFunction<T>, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.state.ReducingStateDescriptor
Creates a new ReducingStateDescriptor with the given name and default value.
ReducingStateDescriptor(String, ReduceFunction<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.state.ReducingStateDescriptor
Creates a new ValueStateDescriptor with the given name and default value.
REDUNDANT_TASK_MANAGER_NUM - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
The number of redundant task managers.
RefCounted - Interface in org.apache.flink.util
Interface to simply add reference counting functionality.
RefCountedFile - Class in org.apache.flink.core.fs
A reference counted file which is deleted as soon as no caller holds a reference to the wrapped File.
RefCountedFile(File) - Constructor for class org.apache.flink.core.fs.RefCountedFile
 
reference - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
ReflectionUtil - Class in org.apache.flink.util
Utility for reflection operations on classes and generic type parametrization.
ReflectionUtil.FullTypeInfo - Class in org.apache.flink.util
Container for the full type information of a type.
REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.WebOptions
The config parameter defining the refresh interval for the web-frontend in milliseconds.
REFUSED_REGISTRATION_BACKOFF - Static variable in class org.apache.flink.configuration.TaskManagerOptions
REFUSED_REGISTRATION_DELAY - Static variable in class org.apache.flink.configuration.ClusterOptions
 
registerAggregationConvergenceCriterion(String, Aggregator<T>, ConvergenceCriterion<T>) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
registerCachedFile(String, DistributedCache.DistributedCacheEntry) - Method in class org.apache.flink.api.common.Plan
Register cache files at program level.
registerCloseable(C) - Method in class org.apache.flink.util.AbstractCloseableRegistry
Registers a Closeable with the registry.
registeredReaders() - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
Get the currently registered readers.
registerInflaterInputStreamFactory(String, InflaterInputStreamFactory<?>) - Static method in class org.apache.flink.api.common.io.FileInputFormat
Registers a decompression algorithm through a InflaterInputStreamFactory with a file extension for transparent decompression.
registerKryoType(Class<?>) - Method in class org.apache.flink.api.common.ExecutionConfig
Registers the given type with the serialization stack.
registerNewOutput(String) - Method in class org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Registers a new multiplexed output, which creates internal states for that output and returns an output ID that can be used to get a deferred or immediate WatermarkOutput for that output.
registerPojoType(Class<?>) - Method in class org.apache.flink.api.common.ExecutionConfig
Registers the given type with the serialization stack.
registerProcessingTimer(long, Sink.ProcessingTimeService.ProcessingTimeCallback) - Method in interface org.apache.flink.api.connector.sink.Sink.ProcessingTimeService
Invokes the given callback at the given timestamp.
registerReleaseHookIfAbsent(String, Runnable) - Method in class org.apache.flink.util.SimpleUserCodeClassLoader
 
registerReleaseHookIfAbsent(String, Runnable) - Method in interface org.apache.flink.util.UserCodeClassLoader
Registers a release hook which is being executed before the user code class loader is being released.
registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.common.ExecutionConfig
Registers the given type with a Kryo Serializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - Method in class org.apache.flink.api.common.ExecutionConfig
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer
registerUserCodeClassLoaderReleaseHookIfAbsent(String, Runnable) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Registers a custom hook for the user code class loader release.
registerUserCodeClassLoaderReleaseHookIfAbsent(String, Runnable) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
REGISTRATION_MAX_BACKOFF - Static variable in class org.apache.flink.configuration.TaskManagerOptions
REGISTRATION_TIMEOUT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Defines the timeout it can take for the TaskManager registration.
relativeTimeMillis() - Method in class org.apache.flink.util.clock.Clock
Gets the current relative time, in milliseconds.
relativeTimeMillis() - Method in class org.apache.flink.util.clock.ManualClock
 
relativeTimeMillis() - Method in class org.apache.flink.util.clock.SystemClock
 
relativeTimeNanos() - Method in class org.apache.flink.util.clock.Clock
Gets the current relative time, in nanoseconds.
relativeTimeNanos() - Method in class org.apache.flink.util.clock.ManualClock
 
relativeTimeNanos() - Method in class org.apache.flink.util.clock.SystemClock
 
relativizePath(Path, Path) - Static method in class org.apache.flink.util.FileUtils
Relativize the given path with respect to the given base path if it is absolute.
release() - Method in class org.apache.flink.core.fs.RefCountedFile
 
release() - Method in interface org.apache.flink.util.RefCounted
Decreases the reference counter.
releaseArrays() - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
releaseOutputForSplit(String) - Method in interface org.apache.flink.api.connector.source.ReaderOutput
Releases the SourceOutput created for the split with the given ID.
remove() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
 
remove() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
remove() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
remove(K) - Method in interface org.apache.flink.api.common.state.BroadcastState
Deletes the mapping of the given key.
remove(UK) - Method in interface org.apache.flink.api.common.state.MapState
Deletes the mapping of the given key.
remove(int) - Method in class org.apache.flink.types.ListValue
 
remove(Object) - Method in class org.apache.flink.types.ListValue
 
remove(Object) - Method in class org.apache.flink.types.MapValue
 
remove() - Method in class org.apache.flink.util.CloseableIterator.IteratorAdapter
 
remove() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
remove() - Method in class org.apache.flink.util.NumberSequenceIterator
 
remove() - Method in class org.apache.flink.util.UnionIterator
 
removeAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
 
removeCloseableInternal(Closeable) - Method in class org.apache.flink.util.AbstractCloseableRegistry
Removes a mapping from the registry map, respecting locking.
removeConfig(ConfigOption<T>) - Method in class org.apache.flink.configuration.Configuration
Removes given config option from the configuration.
removeConfig(ConfigOption<T>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
removeConfig(ConfigOption<T>) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
removeEntropyMarkerIfPresent(FileSystem, Path) - Static method in class org.apache.flink.core.fs.EntropyInjector
Removes the entropy marker string from the path, if the given file system is an entropy-injecting file system (implements EntropyInjectingFileSystem) and the entropy marker key is present.
removeField(int) - Method in class org.apache.flink.types.Record
Removes the field at the given position.
removeShutdownHook(Thread, String, Logger) - Static method in class org.apache.flink.util.ShutdownHookUtil
Removes a shutdown hook from the JVM.
rename(Path, Path) - Method in class org.apache.flink.core.fs.FileSystem
Renames the file/directory src to dst.
rename(Path, Path) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
 
rename(Path, Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
rename(Path, Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
reopen(FileInputSplit, Tuple2<Long, Long>) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
reopen(S, T) - Method in interface org.apache.flink.api.common.io.CheckpointableInputFormat
Restores the state of a parallel instance reading from an InputFormat.
reopen(FileInputSplit, Long) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
replaceNonWordChars(StringValue, char) - Static method in class org.apache.flink.util.StringValueUtils
Replaces all non-word characters in a string by a given character.
ReplicatingInputFormat<OT,S extends InputSplit> - Class in org.apache.flink.api.common.io
A ReplicatingInputFormat replicates any InputFormat to all parallel instances of a DataSource, i.e., the full input of the replicated InputFormat is completely processed by each parallel instance of the DataSource.
ReplicatingInputFormat(InputFormat<OT, S>) - Constructor for class org.apache.flink.api.common.io.ReplicatingInputFormat
 
ReplicatingInputSplitAssigner - Class in org.apache.flink.api.common.io
Assigns each InputSplit to each requesting parallel instance.
ReplicatingInputSplitAssigner(Collection<InputSplit>) - Constructor for class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
ReplicatingInputSplitAssigner(InputSplit[]) - Constructor for class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
REPORTER_CLASS - Static variable in class org.apache.flink.configuration.MetricOptions
 
REPORTER_CONFIG_PARAMETER - Static variable in class org.apache.flink.configuration.MetricOptions
 
REPORTER_INTERVAL - Static variable in class org.apache.flink.configuration.MetricOptions
 
REPORTERS_LIST - Static variable in class org.apache.flink.configuration.MetricOptions
An optional list of reporter names.
requestMemorySegments(int) - Method in interface org.apache.flink.core.memory.MemorySegmentProvider
 
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.
requiresCleanupOfRecoverableState() - Method in class org.apache.flink.core.fs.local.LocalRecoverableWriter
 
requiresCleanupOfRecoverableState() - Method in interface org.apache.flink.core.fs.RecoverableWriter
Marks if the writer requires to do any additional cleanup/freeing of resources occupied as part of a RecoverableWriter.ResumeRecoverable, e.g.
reset() - Method in interface org.apache.flink.api.common.aggregators.Aggregator
Resets the internal state of the aggregator.
reset() - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
reset() - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
 
reset() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
reset() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
reset() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
reset() - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
resetErrorStateAndParse(byte[], int, int, byte[], T) - Method in class org.apache.flink.types.parser.FieldParser
Parses the value of a field from the byte array, taking care of properly reset the state of this parser.
resetLocal() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
Reset the local value.
resetLocal() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.Histogram
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
resetParserState() - Method in class org.apache.flink.types.parser.FieldParser
Reset the state of the parser.
ResettableValue<T extends Value> - Interface in org.apache.flink.types
 
resolveClass(ObjectStreamClass) - Method in class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
resolveClassByName(DataInputView, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
Loads a class by name from the given input stream and reflectively instantiates it.
resolveClassByName(DataInputView, ClassLoader, Class<? super T>) - Static method in class org.apache.flink.util.InstantiationUtil
Loads a class by name from the given input stream and reflectively instantiates it.
resolveCompatibilityWithNested(TypeSerializerSchemaCompatibility<?>, TypeSerializer<?>...) - Method in class org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Deprecated.
this no method will be removed in the future. Resolving compatibility for nested serializers is now handled by CompositeTypeSerializerSnapshot.
resolveOuterSchemaCompatibility(GenericArraySerializer<C>) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
resolveOuterSchemaCompatibility(S) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Checks the schema compatibility of the given new serializer based on the outer snapshot.
resolveOuterSchemaCompatibility(NullableSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
resolveOuterSchemaCompatibility(RowSerializer) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
resolveProxyClass(String[]) - Method in class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<C>) - Method in class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<C[]>) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<Map<K, V>>) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Checks a new serializer's compatibility to read data written by the prior serializer.
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<Either<L, R>>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<Either<L, R>>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
This legacy snapshot delegates compatibility checks to the PojoSerializerSnapshot.
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
resolveSchemaCompatibility(TypeSerializer<Row>) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibility(TypeSerializer<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
Deprecated.
 
resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<E>) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot.SelfResolvingTypeSerializer
Deprecated.
Resolve Schema Compatibility.
resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<Tuple0>) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
resolveUndefined(boolean) - Method in enum org.apache.flink.util.TernaryBoolean
Gets the boolean value corresponding to this value.
Resource<T extends Resource<T>> - Class in org.apache.flink.api.common.resources
Base class for resources one can specify.
Resource(String, double) - Constructor for class org.apache.flink.api.common.resources.Resource
 
Resource(String, BigDecimal) - Constructor for class org.apache.flink.api.common.resources.Resource
 
RESOURCE_MANAGER_IPC_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
RESOURCE_STABILIZATION_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
 
RESOURCE_WAIT_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
 
ResourceGuard - Class in org.apache.flink.util
This class is a guard for shared resources with the following invariants.
ResourceGuard() - Constructor for class org.apache.flink.util.ResourceGuard
 
ResourceGuard.Lease - Class in org.apache.flink.util
A lease is issued by the ResourceGuard as result of calls to ResourceGuard.acquireResource().
ResourceManagerOptions - Class in org.apache.flink.configuration
The set of configuration options relating to the ResourceManager.
ResourceSpec - Class in org.apache.flink.api.common.operators
Describe the different resource factors of the operator with UDF.
ResourceSpec.Builder - Class in org.apache.flink.api.common.operators
Builder for the ResourceSpec.
RESTART_STRATEGY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
RESTART_STRATEGY - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_BACKOFF_MULTIPLIER - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_INITIAL_BACKOFF - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_JITTER_FACTOR - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_MAX_BACKOFF - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_EXPONENTIAL_DELAY_RESET_BACKOFF_THRESHOLD - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FAILURE_RATE_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FAILURE_RATE_DELAY - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RESTART_STRATEGY_FIXED_DELAY_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
RESTART_STRATEGY_FIXED_DELAY_DELAY - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
 
RestartStrategies - Class in org.apache.flink.api.common.restartstrategy
This class defines methods to generate RestartStrategyConfigurations.
RestartStrategies() - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies
 
RestartStrategies.ExponentialDelayRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
Configuration representing an exponential delay restart strategy.
RestartStrategies.FailureRateRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
Configuration representing a failure rate restart strategy.
RestartStrategies.FallbackRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
Restart strategy configuration that could be used by jobs to use cluster level restart strategy.
RestartStrategies.FixedDelayRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
Configuration representing a fixed delay restart strategy.
RestartStrategies.NoRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
Configuration representing no restart strategy.
RestartStrategies.RestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
Abstract configuration for restart strategies.
RestartStrategyOptions - Class in org.apache.flink.configuration
Config options for restart strategies.
RestOptions - Class in org.apache.flink.configuration
Configuration parameters for REST communication.
RestOptions() - Constructor for class org.apache.flink.configuration.RestOptions
 
restoreEnumerator(SplitEnumeratorContext<NumberSequenceSource.NumberSequenceSplit>, Collection<NumberSequenceSource.NumberSequenceSplit>) - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
restoreEnumerator(SplitEnumeratorContext<SplitT>, EnumChkT) - Method in interface org.apache.flink.api.connector.source.Source
Restores an enumerator from a checkpoint.
restoreSerializer() - Method in class org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
restoreSerializer() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
restoreSerializer() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
Deprecated.
 
restoreSerializer() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
restoreSerializer() - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
restoreSerializer() - Method in class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
restoreSerializer() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Deprecated.
Creates a serializer using this configuration, that is capable of reading data written by the serializer described by this configuration.
restoreSerializer() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Recreates a serializer instance from this snapshot.
restoreSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
Deprecated.
 
restoreSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
restoreSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
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.
retain() - Method in class org.apache.flink.core.fs.RefCountedFile
 
retain() - Method in interface org.apache.flink.util.RefCounted
Increases the reference counter.
retainAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
 
rethrow(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do not allow you to throw an arbitrary Throwable.
rethrow(Throwable, String) - Static method in class org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do not allow you to throw an arbitrary Throwable.
rethrowException(Throwable, String) - Static method in class org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do allow to throw a Exception.
rethrowException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do allow to throw a Exception.
rethrowIfFatalError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Rethrows the given Throwable, if it represents an error that is fatal to the JVM.
rethrowIfFatalErrorOrOOM(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Rethrows the given Throwable, if it represents an error that is fatal to the JVM or an out-of-memory error.
rethrowIOException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Re-throws the given Throwable in scenarios where the signatures allows only IOExceptions (and RuntimeException and Error).
RETRIEVE_TASK_MANAGER_HOSTNAME - Static variable in class org.apache.flink.configuration.JobManagerOptions
Flag indicating whether JobManager would retrieve canonical host name of TaskManager during registration.
retrieveResourceInfo(long) - Method in interface org.apache.flink.api.common.externalresource.ExternalResourceDriver
Retrieve the information of the external resources according to the amount.
retry(Supplier<CompletableFuture<T>>, int, Executor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Retry the given operation the given number of times in case of a failure.
retry(Supplier<CompletableFuture<T>>, int, Predicate<Throwable>, Executor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Retry the given operation the given number of times in case of a failure only when an exception is retryable.
RETRY_DELAY - Static variable in class org.apache.flink.configuration.RestOptions
The time in ms that the client waits between retries.
RETRY_GATE_CLOSED_FOR - Static variable in class org.apache.flink.configuration.AkkaOptions
Milliseconds a gate should be closed for after a remote connection was disconnected.
RETRY_MAX_ATTEMPTS - Static variable in class org.apache.flink.configuration.RestOptions
The number of retries the client will attempt if a retryable operations fails.
RetryException(String) - Constructor for exception org.apache.flink.util.concurrent.FutureUtils.RetryException
 
RetryException(String, Throwable) - Constructor for exception org.apache.flink.util.concurrent.FutureUtils.RetryException
 
RetryException(Throwable) - Constructor for exception org.apache.flink.util.concurrent.FutureUtils.RetryException
 
RetryStrategy - Interface in org.apache.flink.util.concurrent
Interface that encapsulates retry logic.
retrySuccessfulWithDelay(Supplier<CompletableFuture<T>>, Time, Deadline, Predicate<T>, ScheduledExecutor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between successful completions where the result does not match a given predicate.
retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, Predicate<Throwable>, ScheduledExecutor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
retryWithDelay(Supplier<CompletableFuture<T>>, RetryStrategy, Predicate<Throwable>, ScheduledExecutor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, ScheduledExecutor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
retryWithDelay(Supplier<CompletableFuture<T>>, RetryStrategy, ScheduledExecutor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
returnExpiredIfNotCleanedUp() - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
 
returnInputSplit(List<InputSplit>, int) - Method in class org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
returnInputSplit(List<InputSplit>, int) - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
returnInputSplit(List<InputSplit>, int) - Method in class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
returnInputSplit(List<InputSplit>, int) - Method in interface org.apache.flink.core.io.InputSplitAssigner
Return the splits to assigner if the task failed to process it.
RichAggregateFunction<IN,ACC,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the AggregateFunction.
RichAggregateFunction() - Constructor for class org.apache.flink.api.common.functions.RichAggregateFunction
 
RichCoGroupFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the CoGroupFunction.
RichCoGroupFunction() - Constructor for class org.apache.flink.api.common.functions.RichCoGroupFunction
 
RichCrossFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the CrossFunction.
RichCrossFunction() - Constructor for class org.apache.flink.api.common.functions.RichCrossFunction
 
RichFilterFunction<T> - Class in org.apache.flink.api.common.functions
Rich variant of the FilterFunction.
RichFilterFunction() - Constructor for class org.apache.flink.api.common.functions.RichFilterFunction
 
RichFlatJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the FlatJoinFunction.
RichFlatJoinFunction() - Constructor for class org.apache.flink.api.common.functions.RichFlatJoinFunction
 
RichFlatMapFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the FlatMapFunction.
RichFlatMapFunction() - Constructor for class org.apache.flink.api.common.functions.RichFlatMapFunction
 
RichFunction - Interface in org.apache.flink.api.common.functions
An base interface for all rich user-defined functions.
RichGroupCombineFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the GroupCombineFunction.
RichGroupCombineFunction() - Constructor for class org.apache.flink.api.common.functions.RichGroupCombineFunction
 
RichGroupReduceFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the GroupReduceFunction.
RichGroupReduceFunction() - Constructor for class org.apache.flink.api.common.functions.RichGroupReduceFunction
 
RichInputFormat<OT,T extends InputSplit> - Class in org.apache.flink.api.common.io
An abstract stub implementation for Rich input formats.
RichInputFormat() - Constructor for class org.apache.flink.api.common.io.RichInputFormat
 
RichJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the JoinFunction.
RichJoinFunction() - Constructor for class org.apache.flink.api.common.functions.RichJoinFunction
 
RichMapFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the MapFunction.
RichMapFunction() - Constructor for class org.apache.flink.api.common.functions.RichMapFunction
 
RichMapPartitionFunction<I,O> - Class in org.apache.flink.api.common.functions
Rich variant of the MapPartitionFunction.
RichMapPartitionFunction() - Constructor for class org.apache.flink.api.common.functions.RichMapPartitionFunction
 
RichOutputFormat<IT> - Class in org.apache.flink.api.common.io
An abstract stub implementation for Rich output formats.
RichOutputFormat() - Constructor for class org.apache.flink.api.common.io.RichOutputFormat
 
RichReduceFunction<T> - Class in org.apache.flink.api.common.functions
Rich variant of the ReduceFunction.
RichReduceFunction() - Constructor for class org.apache.flink.api.common.functions.RichReduceFunction
 
right() - Method in class org.apache.flink.types.Either.Left
 
Right(R) - Static method in class org.apache.flink.types.Either
Create a Right value of Either
right() - Method in class org.apache.flink.types.Either
Retrieve the Right value of Either.
Right(R) - Constructor for class org.apache.flink.types.Either.Right
 
right() - Method in class org.apache.flink.types.Either.Right
 
roundDownToPowerOf2(int) - Static method in class org.apache.flink.util.MathUtils
Decrements the given number down to the closest power of two.
roundUpToPowerOfTwo(int) - Static method in class org.apache.flink.util.MathUtils
Round the given number to the next power of two.
ROW(TypeInformation<?>...) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Row with fields of the given types.
Row - Class in org.apache.flink.types
A row is a fixed-length, null-aware composite type for storing multiple values in a deterministic field order.
Row(RowKind, int) - Constructor for class org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode.
Row(int) - Constructor for class org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode.
ROW_KIND_OFFSET - Static variable in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
ROW_NAMED(String[], TypeInformation<?>...) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Row with fields of the given types and with given names.
RowComparator - Class in org.apache.flink.api.java.typeutils.runtime
Comparator for Row.
RowComparator(int, int[], TypeComparator<Object>[], TypeSerializer<Object>[], boolean[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowComparator
General constructor for RowComparator.
RowKind - Enum in org.apache.flink.types
Lists all kinds of changes that a row can describe in a changelog.
RowSerializer - Class in org.apache.flink.api.java.typeutils.runtime
Serializer for Row.
RowSerializer(TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
RowSerializer(TypeSerializer<?>[], LinkedHashMap<String, Integer>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
RowSerializer(TypeSerializer<?>[], LinkedHashMap<String, Integer>, boolean) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
RowSerializer.RowSerializerConfigSnapshot - Class in org.apache.flink.api.java.typeutils.runtime
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards compatibility. It is fully replaced by RowSerializer.RowSerializerSnapshot.
RowSerializer.RowSerializerSnapshot - Class in org.apache.flink.api.java.typeutils.runtime
A TypeSerializerSnapshot for RowSerializer.
RowSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
RowSerializerConfigSnapshot(TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
Deprecated.
 
RowSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
 
RowTypeInfo - Class in org.apache.flink.api.java.typeutils
RowTypeInfo(TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.RowTypeInfo
 
RowTypeInfo(TypeInformation<?>[], String[]) - Constructor for class org.apache.flink.api.java.typeutils.RowTypeInfo
 
RowUtils - Class in org.apache.flink.types
Utilities to deal with Row instances.
RPC_BIND_PORT - Static variable in class org.apache.flink.configuration.JobManagerOptions
The local port that the job manager binds to.
RPC_BIND_PORT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The local port that the task manager binds to.
RPC_PORT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The default network port range the task manager expects incoming IPC connections.
run() - Method in class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
 
run() - Method in interface org.apache.flink.util.function.RunnableWithException
The work method.
run() - Method in interface org.apache.flink.util.function.ThrowingRunnable
The work method.
run() - Method in class org.apache.flink.util.ThrowableCatchingRunnable
 
runAfterwards(CompletableFuture<?>, RunnableWithException) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAfterwardsAsync(CompletableFuture<?>, RunnableWithException) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAfterwardsAsync(CompletableFuture<?>, RunnableWithException, Executor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Run the given action after the completion of the given future.
runCleanupForEveryRecord() - Method in class org.apache.flink.api.common.state.StateTtlConfig.IncrementalCleanupStrategy
 
runIfNotDoneAndGet(RunnableFuture<T>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Run the given RunnableFuture if it is not done, and then retrieves its result.
runInCoordinatorThread(Runnable) - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
Invoke the given runnable in the source coordinator thread.
RunnableWithException - Interface in org.apache.flink.util.function
Similar to a Runnable, this interface is used to capture a block of code to be executed.
RUNTIME_HASH_JOIN_BLOOM_FILTERS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
RUNTIME_MODE - Static variable in class org.apache.flink.configuration.ExecutionOptions
 
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
 
RuntimeContext - Interface in org.apache.flink.api.common.functions
A RuntimeContext contains information about the context in which functions are executed.
RuntimeContextInitializationContextAdapters - Class in org.apache.flink.api.common.serialization
RuntimeContextInitializationContextAdapters() - Constructor for class org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
RuntimeExecutionMode - Enum in org.apache.flink.api.common
Runtime execution mode of DataStream programs.
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
 
RuntimeUDFContext - Class in org.apache.flink.api.common.functions.util
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
RuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Future<Path>>, Map<String, Accumulator<?, ?>>, OperatorMetricGroup) - Constructor for class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
RuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Future<Path>>, Map<String, Accumulator<?, ?>>, OperatorMetricGroup, JobID) - Constructor for class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 

S

SafetyNetCloseableRegistry - Class in org.apache.flink.core.fs
This implementation of an AbstractCloseableRegistry registers WrappingProxyCloseable.
SafetyNetWrapperFileSystem - Class in org.apache.flink.core.fs
This is a WrappingProxy around FileSystem which (i) wraps all opened streams as ClosingFSDataInputStream or ClosingFSDataOutputStream and (ii) registers them to a SafetyNetCloseableRegistry.
SafetyNetWrapperFileSystem(FileSystem, SafetyNetCloseableRegistry) - Constructor for class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
SameTypePairComparator<T> - Class in org.apache.flink.api.common.typeutils
 
SameTypePairComparator(TypeComparator<T>) - Constructor for class org.apache.flink.api.common.typeutils.SameTypePairComparator
 
sameTypeVars(Type, Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks whether two types are type variables describing the same.
SAVEPOINT_DIRECTORY - Static variable in class org.apache.flink.configuration.CheckpointingOptions
The default directory for savepoints.
SAVEPOINT_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
SAVEPOINT_FS_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
This key was used in Flink versions <= 1.1.X with the savepoint backend configuration. We now always use the FileSystem for savepoints. For this, the only relevant config key is CheckpointingOptions.SAVEPOINT_DIRECTORY.
schedule(Runnable, long, TimeUnit) - Method in interface org.apache.flink.util.concurrent.ScheduledExecutor
Executes the given command after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface org.apache.flink.util.concurrent.ScheduledExecutor
Executes the given callable after the given delay.
schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.util.concurrent.ScheduledExecutor
Executes the given command periodically.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
ScheduledExecutor - Interface in org.apache.flink.util.concurrent
Extension for the Executor interface which is enriched by method for scheduling tasks in the future.
ScheduledExecutorServiceAdapter - Class in org.apache.flink.util.concurrent
Adapter class for a ScheduledExecutorService which shall be used as a ScheduledExecutor.
ScheduledExecutorServiceAdapter(ScheduledExecutorService) - Constructor for class org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
SCHEDULER - Static variable in class org.apache.flink.configuration.JobManagerOptions
Config parameter determining the scheduler implementation.
SCHEDULER_MODE - Static variable in class org.apache.flink.configuration.JobManagerOptions
 
SchedulerExecutionMode - Enum in org.apache.flink.configuration
Enum for controlling whether REACTIVE mode is enabled or not.
scheduleWithDelay(Runnable, Time, ScheduledExecutor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Schedule the operation with the given delay.
scheduleWithDelay(Supplier<T>, Time, ScheduledExecutor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Schedule the operation with the given delay.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.util.concurrent.ScheduledExecutor
Executed the given command repeatedly with the given delay between the end of an execution and the start of the next execution.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
 
schemaEquals(Object) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
Tests whether an other object describes the same, schema-equivalent row information.
scope - Variable in enum org.apache.flink.core.memory.ManagedMemoryUseCase
 
SCOPE_DELIMITER - Static variable in class org.apache.flink.configuration.MetricOptions
The delimiter used to assemble the metric identifier.
SCOPE_NAMING_JM - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a JobManager.
SCOPE_NAMING_JM_JOB - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a job on a JobManager.
SCOPE_NAMING_OPERATOR - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to an operator.
SCOPE_NAMING_TASK - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a task.
SCOPE_NAMING_TM - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a TaskManager.
SCOPE_NAMING_TM_JOB - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a job on a TaskManager.
seconds(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of seconds.
SECURITY_CONTEXT_FACTORY_CLASSES - Static variable in class org.apache.flink.configuration.SecurityOptions
 
SECURITY_MODULE_FACTORY_CLASSES - Static variable in class org.apache.flink.configuration.SecurityOptions
 
SECURITY_SSL_ALGORITHMS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
SECURITY_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
SECURITY_SSL_KEY_PASSWORD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
SECURITY_SSL_KEYSTORE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
SECURITY_SSL_KEYSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
SECURITY_SSL_PROTOCOL - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
SECURITY_SSL_TRUSTSTORE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
SECURITY_SSL_TRUSTSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.ConfigConstants
SECURITY_SSL_VERIFY_HOSTNAME - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
SecurityOptions - Class in org.apache.flink.configuration
The set of configuration options relating to security.
SecurityOptions() - Constructor for class org.apache.flink.configuration.SecurityOptions
 
seek(long) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
seek(long) - Method in class org.apache.flink.core.fs.FSDataInputStream
Seek to the given offset from the start of the file.
seek(long) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
seek(long) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
SeekableDataInputView - Interface in org.apache.flink.core.memory
Interface marking a DataInputView as seekable.
SeekableDataOutputView - Interface in org.apache.flink.core.memory
Interface marking a DataOutputView as seekable.
SELECT_ALL_CHAR - Static variable in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
SELECT_ALL_CHAR_SCALA - Static variable in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
SelectorFunctionKeys(KeySelector<T, K>, TypeInformation<T>, TypeInformation<K>) - Constructor for class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
SemanticProperties - Interface in org.apache.flink.api.common.operators
Container for the semantic properties associated to an operator.
SemanticProperties.EmptySemanticProperties - Class in org.apache.flink.api.common.operators
 
SemanticProperties.InvalidSemanticAnnotationException - Exception in org.apache.flink.api.common.operators
 
SEND_RECEIVE_BUFFER_SIZE - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
sendEventToSourceReader(int, SourceEvent) - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
Send a source event to a source reader.
sendSourceEventToCoordinator(SourceEvent) - Method in interface org.apache.flink.api.connector.source.SourceReaderContext
Send a source event to the source coordinator.
sendSplitRequest() - Method in interface org.apache.flink.api.connector.source.SourceReaderContext
Sends a split request to the source's SplitEnumerator.
SEPARATOR - Static variable in class org.apache.flink.core.fs.Path
The directory separator, a slash.
SEPARATOR_CHAR - Static variable in class org.apache.flink.core.fs.Path
The directory separator, a slash (character).
SerializableObject - Class in org.apache.flink.util
A simple object that only implements Serializable, so it can be used in serializable classes.
SerializableObject() - Constructor for class org.apache.flink.util.SerializableObject
 
SerializableOptional<T extends Serializable> - Class in org.apache.flink.types
Serializable Optional.
SerializableSerializer(T) - Constructor for class org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
 
SerializableSupplier<T> - Interface in org.apache.flink.util.function
A serializable Supplier.
SerializableTimestampAssigner<T> - Interface in org.apache.flink.api.common.eventtime
serializationAdapter(RuntimeContext) - Static method in class org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
serializationAdapter(RuntimeContext, Function<MetricGroup, MetricGroup>) - Static method in class org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
 
SerializationSchema<T> - Interface in org.apache.flink.api.common.serialization
The serialization schema describes how to turn a data object into a different serialized representation.
SerializationSchema.InitializationContext - Interface in org.apache.flink.api.common.serialization
A contextual information provided for SerializationSchema.open(InitializationContext) method.
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.io.SerializedOutputFormat
 
serialize(T) - Method in interface org.apache.flink.api.common.serialization.SerializationSchema
Serializes the incoming element to a specified type.
serialize(String) - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
 
serialize(T) - Method in class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
 
serialize(boolean[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
serialize(byte[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
serialize(char[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
serialize(double[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
serialize(float[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
serialize(int[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
serialize(long[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
serialize(short[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
serialize(String[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
serialize(BigDecimal, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
serialize(BigInteger, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
serialize(Boolean, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
serialize(BooleanValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
serialize(Byte, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
serialize(ByteValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
serialize(Character, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
serialize(CharValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
serialize(Date, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
serialize(Double, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
serialize(DoubleValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
serialize(Float, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
serialize(FloatValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
serialize(C[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
serialize(Instant, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
serialize(Integer, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
serialize(IntValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
serialize(List<T>, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
serialize(LocalDate, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
serialize(LocalDateTime, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
serialize(LocalTime, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
serialize(Long, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
serialize(LongValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
serialize(Map<K, V>, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
serialize(NullValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
serialize(Short, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
serialize(ShortValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
serialize(Date, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
serialize(Time, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
serialize(Timestamp, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
serialize(String, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
serialize(StringValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
serialize(Void, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Serializes the given record to the given target output view.
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
serialize(Either<L, R>, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
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.NullableSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
serialize(Row, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
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(E) - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
Serializes the given object.
serialize(T, DataOutputView) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
serialize(DataOutputView) - Method in class org.apache.flink.types.Record
Writes this record to the given output view.
SerializedInputFormat<T extends IOReadableWritable> - Class in org.apache.flink.api.common.io
Reads elements by deserializing them with their regular serialization/deserialization functionality.
SerializedInputFormat() - Constructor for class org.apache.flink.api.common.io.SerializedInputFormat
 
SerializedListAccumulator<T> - Class in org.apache.flink.api.common.accumulators
This accumulator stores a collection of objects in serialized form, so that the stored objects are not affected by modifications to the original objects.
SerializedListAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
SerializedOutputFormat<T extends IOReadableWritable> - Class in org.apache.flink.api.common.io
Stores elements by serializing them with their regular serialization/deserialization functionality.
SerializedOutputFormat() - Constructor for class org.apache.flink.api.common.io.SerializedOutputFormat
 
SerializedThrowable - Exception in org.apache.flink.util
Utility class for dealing with user-defined Throwable types that are serialized (for example during RPC/Actor communication), but cannot be resolved with the default class loader.
SerializedThrowable(Throwable) - Constructor for exception org.apache.flink.util.SerializedThrowable
Create a new SerializedThrowable.
SerializedValue<T> - Class in org.apache.flink.util
This class is used to transfer (via serialization) objects whose classes are not available in the system class loader.
SerializedValue(byte[]) - Constructor for class org.apache.flink.util.SerializedValue
 
SerializedValue(T) - Constructor for class org.apache.flink.util.SerializedValue
Constructs a serialized value.
serializeField(Field, ObjectOutputStream) - Static method in class org.apache.flink.api.java.typeutils.runtime.FieldSerializer
 
serializeObject(Object) - Static method in class org.apache.flink.util.InstantiationUtil
 
serializeObject(OutputStream, Object) - Static method in class org.apache.flink.util.InstantiationUtil
 
serializeObjectAndCompress(Object) - Static method in class org.apache.flink.util.InstantiationUtil
 
serializerClass() - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
Gets the serializer's class.
serializerClass() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerSnapshot
 
serializerClass() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerSnapshot
 
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.DummyAvroKryoSerializerClass<T> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
This is used in case we don't have Avro on the classpath.
Serializers.DummyAvroRegisteredClass - Class in org.apache.flink.api.java.typeutils.runtime.kryo
This is used in case we don't have Avro on the classpath.
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
Special serializer for Java's ArrayList used for Avro's GenericData.Array.
serializeToByteArray(TypeSerializer<T>, T) - Static method in class org.apache.flink.util.InstantiationUtil
 
serialVersionUID - Static variable in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
Deprecated.
 
SERVER_ASYNC_QUERY_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Number of async query threads for the KvStateServerHandler (0 => #slots).
SERVER_MAX_CONTENT_LENGTH - Static variable in class org.apache.flink.configuration.RestOptions
The maximum content length that the server will handle.
SERVER_NETWORK_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Number of network (event loop) threads for the KvState server (0 => #slots).
SERVER_NUM_THREADS - Static variable in class org.apache.flink.configuration.RestOptions
 
SERVER_PORT_RANGE - Static variable in class org.apache.flink.configuration.QueryableStateOptions
The config parameter defining the server port range of the queryable state server.
SERVER_SOCKET_WORKER_POOL_SIZE_FACTOR - Static variable in class org.apache.flink.configuration.AkkaOptions
 
SERVER_SOCKET_WORKER_POOL_SIZE_MAX - Static variable in class org.apache.flink.configuration.AkkaOptions
 
SERVER_SOCKET_WORKER_POOL_SIZE_MIN - Static variable in class org.apache.flink.configuration.AkkaOptions
 
SERVER_THREAD_PRIORITY - Static variable in class org.apache.flink.configuration.RestOptions
 
set(ConfigOption<T>, T) - Method in class org.apache.flink.configuration.Configuration
 
set(ConfigOption<T>, T) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
set(ConfigOption<T>, T) - Method in interface org.apache.flink.configuration.WritableConfig
Stores a given value using the metadata included in the ConfigOption.
set(boolean) - Method in class org.apache.flink.types.BooleanValue
 
set(int, V) - Method in class org.apache.flink.types.ListValue
 
setAccumulatedRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
Sets the accumulatedRecordCount to the specified value.
setAutoWatermarkInterval(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the interval of the automatic watermark emission.
setAvgOutputRecordSize(float) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
setBlockSize(long) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
setBoolean(String, boolean) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setBoolean(String, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setBroadcastVariable(String, List<?>) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Binds the result produced by a plan rooted at root to a variable used by the UDF wrapped in this operator.
setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
The BulkIteration meta operator cannot have broadcast inputs.
setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
The DeltaIteration meta operator cannot have broadcast inputs.
setBroadcastVariables(Map<String, Operator<T>>) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Clears all previous broadcast inputs and binds the given inputs as broadcast variables of this operator.
setBroadcastVariables(Map<String, Operator<X>>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
The BulkIteration meta operator cannot have broadcast inputs.
setBroadcastVariables(Map<String, Operator<X>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
The DeltaIteration meta operator cannot have broadcast inputs.
setBuffer(byte[], int, int) - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
setBuffer(ByteBuffer) - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
setBuffer(byte[], int, int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
setBuffer(byte[]) - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
setBufferSize(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setBufferTimeout(long) - Method in class org.apache.flink.api.dag.Transformation
Set the buffer timeout of this Transformation.
setBytes(String, byte[]) - Method in class org.apache.flink.configuration.Configuration
Adds the given byte array to the configuration object.
setBytes(String, byte[]) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setCharset(String) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Set the name of the character set used for the row delimiter.
setCharset(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCharset(Charset) - Method in class org.apache.flink.types.parser.FieldParser
Sets the character set used for this parser.
setClass(String, Class<?>) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setClass(String, Class<?>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setClosureCleanerLevel(ExecutionConfig.ClosureCleanerLevel) - Method in class org.apache.flink.api.common.ExecutionConfig
Configures the closure cleaner.
setCoLocationGroupKey(String) - Method in class org.apache.flink.api.dag.Transformation
NOTE: This is an internal undocumented feature for now.
setCombinable(boolean) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Marks the group reduce operation as combinable.
setCombinableFirst(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
setCombinableFirst(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
setCombinableSecond(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
setCombinableSecond(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
setCommentPrefix(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCpuCores(double) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setCpuCores(double) - Method in class org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the CPU cores for this SlotSharingGroup.
setCrossHint(CrossOperatorBase.CrossHint) - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
setDefaultInputDependencyConstraint(InputDependencyConstraint) - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
due to the deprecation of InputDependencyConstraint.
setDefaultParallelism(int) - Method in class org.apache.flink.api.common.Plan
Sets the default parallelism for this plan.
setDelimiter(byte[]) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setDelimiter(char) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setDelimiter(String) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setDistribution(DataDistribution) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
setDouble(String, double) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setDouble(String, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setErrorState(FieldParser.ParseErrorState) - Method in class org.apache.flink.types.parser.FieldParser
Sets the error state of the parser.
setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.api.common.Plan
Sets the runtime config object defining execution parameters.
setExecutionMode(ExecutionMode) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the execution mode to execute the program.
setExecutionRetryDelay(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
This method will be replaced by ExecutionConfig.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the delay between successive execution attempts.
setExtendedResource(ExternalResource) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
Add the given extended resource.
setExtendedResources(Collection<ExternalResource>) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
Add the given extended resources.
setExternalResource(String, double) - Method in class org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Add the given external resource.
setField(T, int, Object) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
Modify field of existing instance.
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
 
setField(int, Value) - Method in class org.apache.flink.types.Record
Sets the field at the given position to the given value.
setField(int, Object) - Method in class org.apache.flink.types.Row
Sets the field's content at the specified position.
setField(String, Object) - Method in class org.apache.flink.types.Row
Sets the field's content using the specified field name.
setFieldDelimiter(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
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.
setFieldsGeneric(int[], Class<?>[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFieldsGeneric(boolean[], Class<?>[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFieldTypesGeneric(Class<?>...) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFilePath(String) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setFilePath(Path) - Method in class org.apache.flink.api.common.io.FileInputFormat
Sets a single path of a file to be read.
setFilePaths(String...) - Method in class org.apache.flink.api.common.io.FileInputFormat
Sets multiple paths of files to be read.
setFilePaths(Path...) - Method in class org.apache.flink.api.common.io.FileInputFormat
Sets multiple paths of files to be read.
setFilesFilter(FilePathFilter) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setFilterFactor(float) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
setFirstInput(Operator<IN1>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Clears all previous connections and connects the first input to the task wrapped in this contract
setFirstInput(Operator<IN1>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setFirstInputs(List<Operator<IN1>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setFirstRecordStart(long) - Method in class org.apache.flink.api.common.io.BlockInfo
Sets the firstRecordStart to the specified value.
setFloat(String, float) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setFloat(String, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setFromConfiguration(Configuration) - Static method in class org.apache.flink.core.security.FlinkSecurityManager
 
setFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
setGlobalJobParameters(ExecutionConfig.GlobalJobParameters) - Method in class org.apache.flink.api.common.ExecutionConfig
Register a custom, serializable user configuration object.
setGroupOrder(int, Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Sets the order of the elements within a group for the given input.
setGroupOrder(int, Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Sets the order of the elements within a group for the given input.
setGroupOrder(Ordering) - Method in class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
Sets the order of the elements within a reduce group.
setGroupOrder(Ordering) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Sets the order of the elements within a reduce group.
setGroupOrderForInputOne(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Sets the order of the elements within a group for the first input.
setGroupOrderForInputOne(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Sets the order of the elements within a group for the first input.
setGroupOrderForInputTwo(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Sets the order of the elements within a group for the second input.
setGroupOrderForInputTwo(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Sets the order of the elements within a group for the second input.
setInitialSolutionSet(Operator<ST>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the given input as the initial solution set.
setInitialWorkset(Operator<WT>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the given input as the initial workset.
setInput(Operator<IN>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Sets the given operator as the input to this operator.
setInput(Operator<IN>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Sets the given operator as the input to this operator.
setInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setInputs(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setInputs(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setInputs(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
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.
setInteger(String, int) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setInteger(String, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setJobId(JobID) - Method in class org.apache.flink.api.common.Plan
Sets the ID of the job that the dataflow plan belongs to.
setJobName(String) - Method in class org.apache.flink.api.common.Plan
Sets the jobName for this Plan.
setJoinHint(JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
setKind(RowKind) - Method in class org.apache.flink.types.Row
Sets the kind of change that this row describes in a changelog.
setLatencyTrackingInterval(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Interval for sending latency tracking marks from the sources to the sinks.
setLength(int) - Method in class org.apache.flink.types.StringValue
Sets a new length for the string.
setLenient(boolean) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setLineLengthLimit(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setLocalOrder(Ordering) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Sets the order in which the sink must write its data within each fragment in the distributed file system.
setLong(String, long) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setLong(String, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setManagedMemory(MemorySize) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setManagedMemory(MemorySize) - Method in class org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task managed memory for this SlotSharingGroup.
setManagedMemoryMB(int) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setManagedMemoryMB(int) - Method in class org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task managed memory for this SlotSharingGroup in MB.
setMaximumNumberOfIterations(int) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
setMaximumNumberOfIterations(int) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
setMaxParallelism(int) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the maximum degree of parallelism defined for the program.
setMaxParallelism(int) - Method in class org.apache.flink.api.dag.Transformation
Sets the maximum parallelism for this stream transformation.
setMinSplitSize(long) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setName(String) - Method in class org.apache.flink.api.common.operators.Operator
Sets the name of the contract instance.
setName(String) - Method in class org.apache.flink.api.dag.Transformation
Changes the name of this Transformation.
setNestedFileEnumeration(boolean) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setNestedSerializersSnapshots(CompositeTypeSerializerSnapshot<?, ?>, TypeSerializerSnapshot<?>...) - Static method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil
Overrides the existing nested serializer's snapshots with the provided nestedSnapshots.
setNextPartialSolution(Operator<T>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
setNextWorkset(Operator<WT>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the contract of the step function that represents the next workset.
setNull(int) - Method in class org.apache.flink.types.Record
Sets the field at the given position to null.
setNull(long) - Method in class org.apache.flink.types.Record
Sets the fields to null using the given bit mask.
setNull(long[]) - Method in class org.apache.flink.types.Record
Sets the fields to null using the given bit mask.
setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
This method will be replaced by ExecutionConfig.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of execution retries.
setNumFields(int) - Method in class org.apache.flink.types.Record
Sets the number of fields in the record.
setNumLineSamples(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setNumSplits(int) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setOpenTimeout(long) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setOrdering(Ordering) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
setOuterJoinType(OuterJoinOperatorBase.OuterJoinType) - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
setOutputCardinality(long) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
setOutputDirectoryMode(FileOutputFormat.OutputDirectoryMode) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
setOutputFilePath(Path) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
setOutputSize(long) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
setOutputType(TypeInformation<T>) - Method in class org.apache.flink.api.dag.Transformation
Tries to fill in the type information.
setParallelism(int) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the parallelism for operations executed through this environment.
setParallelism(int) - Method in class org.apache.flink.api.common.operators.Operator
Sets the parallelism for this contract instance.
setParallelism(int) - Method in class org.apache.flink.api.dag.Transformation
Sets the parallelism of this Transformation.
setParameter(String, String) - Method in class org.apache.flink.api.common.operators.Operator
Sets a stub parameters in the configuration of this contract.
setParameter(String, int) - Method in class org.apache.flink.api.common.operators.Operator
Sets a stub parameters in the configuration of this contract.
setParameter(String, boolean) - Method in class org.apache.flink.api.common.operators.Operator
Sets a stub parameters in the configuration of this contract.
setPoolName(String) - Method in class org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
setPosition(int) - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
setPosition(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
setPosition(int) - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
setPositionUnsafe(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
setPriorSerializer(TypeSerializer<T>) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Deprecated.
Set the originating serializer of this configuration snapshot.
setQueryable(String) - Method in class org.apache.flink.api.common.state.StateDescriptor
Sets the name for queries of state created from this descriptor.
setRate(long) - Method in interface org.apache.flink.api.common.io.ratelimiting.FlinkConnectorRateLimiter
Sets the desired rate for the rate limiter.
setRate(long) - Method in class org.apache.flink.api.common.io.ratelimiting.GuavaFlinkConnectorRateLimiter
Set the global per consumer and per sub-task rates.
setReadPosition(long) - Method in interface org.apache.flink.core.memory.SeekableDataInputView
Sets the read pointer to the given position.
setRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
Sets the recordCount to the specified value.
setReference(T) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
setReference(T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
setReference(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
setReference(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
setReference(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
setReference(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
setReference(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
setReference(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
setReference(LocalDate) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
setReference(LocalDateTime) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
setReference(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
setReference(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
setReference(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
setReference(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
setReference(T1) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
 
setReference(T) - Method in class org.apache.flink.api.common.typeutils.SameTypePairComparator
 
setReference(T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Sets the given element as the comparison reference for future calls to TypeComparator.equalToReference(Object) and TypeComparator.compareToReference(TypeComparator).
setReference(T1) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
Sets the reference for comparisons.
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.NullAwareComparator
 
setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
setReference(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
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
 
setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.api.common.operators.Operator
Sets the minimum and preferred resources for this contract instance.
setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.api.dag.Transformation
Sets the minimum and preferred resources for this stream transformation.
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the restart strategy to be used for recovery.
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
setRuntimeContext(RuntimeContext) - Method in interface org.apache.flink.api.common.functions.RichFunction
Sets the function's runtime context.
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.RichInputFormat
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.RichOutputFormat
 
setSecondInput(Operator<IN2>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Clears all previous connections and connects the second input to the task wrapped in this contract
setSecondInput(Operator<IN2>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setSecondInputs(List<Operator<IN2>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setSegment(MemorySegment, int, int) - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
setSemanticProperties(DualInputSemanticProperties) - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
setSemanticProperties(SingleInputSemanticProperties) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
setSkipFirstLineAsHeader(boolean) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setSlotSharingGroup(String) - Method in class org.apache.flink.api.dag.Transformation
Sets the slot sharing group of this transformation.
setSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.api.dag.Transformation
Sets the slot sharing group of this transformation.
setSolutionSetDelta(Operator<ST>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the contract of the step function that represents the solution set delta.
setSolutionSetUnManaged(boolean) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or unmanaged memory (objects on heap).
setSplitDataProperties(GenericDataSourceBase.SplitDataProperties<OUT>) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Sets properties of input splits for this data source.
setStateVisibility(StateTtlConfig.StateVisibility) - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
Sets the state visibility.
setStatisticsKey(String) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Sets the key under which statistics about this data source may be obtained from the statistics cache.
setString(String, String) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setString(String, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setStringToTokenize(StringValue) - Method in class org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
Sets the string to be tokenized and resets the state of the tokenizer.
setTaskCancellationInterval(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the configuration parameter specifying the interval (in milliseconds) between consecutive attempts to cancel a running task.
setTaskCancellationTimeout(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the timeout (in milliseconds) after which an ongoing task cancellation is considered failed, leading to a fatal TaskManager error.
setTaskHeapMemory(MemorySize) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setTaskHeapMemory(MemorySize) - Method in class org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task heap memory for this SlotSharingGroup.
setTaskHeapMemoryMB(int) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setTaskHeapMemoryMB(int) - Method in class org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task heap memory for this SlotSharingGroup in MB.
setTaskOffHeapMemory(MemorySize) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setTaskOffHeapMemory(MemorySize) - Method in class org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task off-heap memory for this SlotSharingGroup.
setTaskOffHeapMemoryMB(int) - Method in class org.apache.flink.api.common.operators.ResourceSpec.Builder
 
setTaskOffHeapMemoryMB(int) - Method in class org.apache.flink.api.common.operators.SlotSharingGroup.Builder
Set the task off-heap memory for this SlotSharingGroup in MB.
setTerminationCriterion(Operator<X>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
setThreadPriority(int) - Method in class org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
 
setTtl(Time) - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
Sets the ttl time.
setTtlTimeCharacteristic(StateTtlConfig.TtlTimeCharacteristic) - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
Sets the time characteristic.
setUid(String) - Method in class org.apache.flink.api.dag.Transformation
Sets an ID for this Transformation.
setUidHash(String) - Method in class org.apache.flink.api.dag.Transformation
Sets an user provided hash for this operator.
setUpdateType(StateTtlConfig.UpdateType) - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
Sets the ttl update type.
setUserCodeClassLoader(ClassLoader) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Deprecated.
Set the user code class loader.
setUseSnapshotCompression(boolean) - Method in class org.apache.flink.api.common.ExecutionConfig
 
setValue(boolean) - Method in class org.apache.flink.types.BooleanValue
 
setValue(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
 
setValue(byte) - Method in class org.apache.flink.types.ByteValue
Sets the encapsulated byte to the specified value.
setValue(ByteValue) - Method in class org.apache.flink.types.ByteValue
 
setValue(char) - Method in class org.apache.flink.types.CharValue
Sets the encapsulated char to the specified value.
setValue(CharValue) - Method in class org.apache.flink.types.CharValue
 
setValue(double) - Method in class org.apache.flink.types.DoubleValue
Sets the value of the encapsulated primitive double.
setValue(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
 
setValue(L) - Method in class org.apache.flink.types.Either.Left
Sets the encapsulated value to another value
setValue(R) - Method in class org.apache.flink.types.Either.Right
Sets the encapsulated value to another value
setValue(float) - Method in class org.apache.flink.types.FloatValue
Sets the value of the encapsulated primitive float.
setValue(FloatValue) - Method in class org.apache.flink.types.FloatValue
 
setValue(int) - Method in class org.apache.flink.types.IntValue
Sets the encapsulated int to the specified value.
setValue(IntValue) - Method in class org.apache.flink.types.IntValue
 
setValue(long) - Method in class org.apache.flink.types.LongValue
Sets the value of the encapsulated long to the specified value.
setValue(LongValue) - Method in class org.apache.flink.types.LongValue
 
setValue(T) - Method in interface org.apache.flink.types.ResettableValue
Sets the encapsulated value to another value
setValue(short) - Method in class org.apache.flink.types.ShortValue
Sets the encapsulated short to the specified value.
setValue(ShortValue) - Method in class org.apache.flink.types.ShortValue
 
setValue(CharSequence) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to the given string.
setValue(StringValue) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to the given string.
setValue(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to a substring of the given string.
setValue(CharSequence, int, int) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to a substring of the given string.
setValue(CharBuffer) - Method in class org.apache.flink.types.StringValue
Sets the contents of this string to the contents of the given CharBuffer.
setValue(char[], int, int) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to a substring of the given value.
setValueAscii(byte[], int, int) - Method in class org.apache.flink.types.StringValue
Sets the value of this StringValue, assuming that the binary data is ASCII coded.
setWriteMode(FileSystem.WriteMode) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
setWritePosition(long) - Method in interface org.apache.flink.core.memory.SeekableDataOutputView
Sets the write pointer to the given position.
SHORT - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for both a primitive short and Short.
SHORT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
SHORT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
SHORT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
SHORT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
ShortComparator - Class in org.apache.flink.api.common.typeutils.base
 
ShortComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ShortComparator
 
ShortParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a Short.
ShortParser() - Constructor for class org.apache.flink.types.parser.ShortParser
 
ShortPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
ShortPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
ShortPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for short arrays.
ShortPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
ShortPrimitiveArraySerializer.ShortPrimitiveArraySerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base.array
Serializer configuration snapshot for compatibility and format evolution.
ShortPrimitiveArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer.ShortPrimitiveArraySerializerSnapshot
 
ShortSerializer - Class in org.apache.flink.api.common.typeutils.base
Type serializer for Byte.
ShortSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
ShortSerializer.ShortSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
ShortSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortSerializer.ShortSerializerSnapshot
 
shortString() - Method in enum org.apache.flink.types.RowKind
Returns a short string representation of this RowKind.
ShortValue - Class in org.apache.flink.types
Boxed serializable and comparable short integer type, representing the primitive type short.
ShortValue() - Constructor for class org.apache.flink.types.ShortValue
Initializes the encapsulated short with 0.
ShortValue(short) - Constructor for class org.apache.flink.types.ShortValue
Initializes the encapsulated short with the provided value.
ShortValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for ShortValue based on CopyableValueComparator.
ShortValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
ShortValueParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a ShortValue.
ShortValueParser() - Constructor for class org.apache.flink.types.parser.ShortValueParser
 
ShortValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
ShortValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
ShortValueSerializer.ShortValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
ShortValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortValueSerializer.ShortValueSerializerSnapshot
 
shouldAutocastTo(BasicTypeInfo<?>) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
Returns whether this type should be automatically casted to the target type in an arithmetic operation.
shouldTriggerCheckpoint() - Method in interface org.apache.flink.api.connector.source.ExternallyInducedSourceReader
A method that informs the Flink runtime whether a checkpoint should be triggered on this Source.
showControlCharacters(String) - Static method in class org.apache.flink.util.StringUtils
Replaces control characters by their escape-coded version.
SHUFFLE_COMPRESSION_CODEC - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
The codec to be used when compressing shuffle data.
SHUTDOWN_IF_ATTACHED - Static variable in class org.apache.flink.configuration.DeploymentOptions
 
ShutdownHookUtil - Class in org.apache.flink.util
Utils class for dealing with JVM shutdown hooks.
signalNoMoreSplits(int) - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
Signals a subtask that it will not receive any further split.
SimpleAccumulator<T extends Serializable> - Interface in org.apache.flink.api.common.accumulators
Similar to Accumulator, but the type of items to add and the result value must be the same.
SimpleListIterable(List<IN>, TypeComparator<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable
 
SimpleListIterator(List<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
SimpleStringEncoder<IN> - Class in org.apache.flink.api.common.serialization
A simple Encoder that uses toString() on the input elements and writes them to the output bucket file separated by newline.
SimpleStringEncoder() - Constructor for class org.apache.flink.api.common.serialization.SimpleStringEncoder
Creates a new StringWriter that uses "UTF-8" charset to convert strings to bytes.
SimpleStringEncoder(String) - Constructor for class org.apache.flink.api.common.serialization.SimpleStringEncoder
Creates a new StringWriter that uses the given charset to convert strings to bytes.
SimpleStringSchema - Class in org.apache.flink.api.common.serialization
Very simple serialization schema for strings.
SimpleStringSchema() - Constructor for class org.apache.flink.api.common.serialization.SimpleStringSchema
Creates a new SimpleStringSchema that uses "UTF-8" as the encoding.
SimpleStringSchema(Charset) - Constructor for class org.apache.flink.api.common.serialization.SimpleStringSchema
Creates a new SimpleStringSchema that uses the given charset to convert between strings and bytes.
SimpleTypeSerializerSnapshot<T> - Class in org.apache.flink.api.common.typeutils
A simple base class for TypeSerializerSnapshots, for serializers that have no parameters.
SimpleTypeSerializerSnapshot(Supplier<? extends TypeSerializer<T>>) - Constructor for class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
Constructor to create snapshot from serializer (writing the snapshot).
SimpleUserCodeClassLoader - Class in org.apache.flink.util
Simple UserCodeClassLoader implementation which assumes that the provided class loader will never be released and, hence, will never execute the release hooks.
SimpleVersionedSerialization - Class in org.apache.flink.core.io
Simple serialization / deserialization methods for the SimpleVersionedSerializer.
SimpleVersionedSerializer<E> - Interface in org.apache.flink.core.io
A simple serializer interface for versioned serialization.
SimpleVersionedSerializerTypeSerializerProxy<T> - Class in org.apache.flink.core.io
A TypeSerializer that delegates to an underlying SimpleVersionedSerializer.
SimpleVersionedSerializerTypeSerializerProxy(SerializableSupplier<SimpleVersionedSerializer<T>>) - Constructor for class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
SingleInputOperator<IN,OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
Abstract superclass for for all operators that have one input like "map" or "reduce".
SingleInputOperator(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.SingleInputOperator
Creates a new abstract single-input operator with the given name wrapping the given user function.
SingleInputOperator(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.SingleInputOperator
Creates a new abstract single-input operator with the given name wrapping the given user function.
SingleInputSemanticProperties - Class in org.apache.flink.api.common.operators
Container for the semantic properties associated to a single input operator.
SingleInputSemanticProperties() - Constructor for class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
SingleInputSemanticProperties.AllFieldsForwardedProperties - Class in org.apache.flink.api.common.operators
 
SingleThreadAccessCheckingTypeSerializer<T> - Class in org.apache.flink.api.common.typeutils
 
SingleThreadAccessCheckingTypeSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot<T> - Class in org.apache.flink.api.common.typeutils
 
SingleThreadAccessCheckingTypeSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot
 
Sink<InputT,CommT,WriterStateT,GlobalCommT> - Interface in org.apache.flink.api.connector.sink
This interface lets the sink developer build a simple sink topology, which could guarantee the exactly once semantics in both batch and stream execution mode if there is a Committer or GlobalCommitter.
Sink.InitContext - Interface in org.apache.flink.api.connector.sink
The interface exposes some runtime info for creating a SinkWriter.
Sink.ProcessingTimeService - Interface in org.apache.flink.api.connector.sink
A service that allows to get the current processing time and register timers that will execute the given Sink.ProcessingTimeService.ProcessingTimeCallback when firing.
Sink.ProcessingTimeService.ProcessingTimeCallback - Interface in org.apache.flink.api.connector.sink
sinks - Variable in class org.apache.flink.api.common.Plan
A collection of all sinks in the plan.
SinkWriter<InputT,CommT,WriterStateT> - Interface in org.apache.flink.api.connector.sink
The SinkWriter is responsible for writing data and handling any potential tmp area used to write yet un-staged data, e.g.
SinkWriter.Context - Interface in org.apache.flink.api.connector.sink
Context that SinkWriter.write(InputT, org.apache.flink.api.connector.sink.SinkWriter.Context) can use for getting additional data about an input record.
size() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
size() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
size() - Method in class org.apache.flink.core.memory.MemorySegment
Gets the size of the memory segment, in bytes.
size() - Method in class org.apache.flink.types.ListValue
 
size() - Method in class org.apache.flink.types.MapValue
 
SIZE - Static variable in class org.apache.flink.util.AbstractID
The size of the ID in byte.
size() - Method in class org.apache.flink.util.LinkedOptionalMap
 
SIZE_MISMATCH_MESSAGE - Static variable in exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
 
SIZE_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Constant indicating that the input size is unknown.
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
 
skip(long) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
skip(long) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
skip(long) - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
 
skipBytes(int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
skipBytesToRead(int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
 
skipBytesToRead(int) - Method in interface org.apache.flink.core.memory.DataInputView
Skips numBytes bytes of memory.
skipBytesToRead(int) - Method in class org.apache.flink.core.memory.DataInputViewStreamWrapper
 
skipBytesToWrite(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
skipBytesToWrite(int) - Method in interface org.apache.flink.core.memory.DataOutputView
Skips numBytes bytes memory.
skipBytesToWrite(int) - Method in class org.apache.flink.core.memory.DataOutputViewStreamWrapper
 
skipFields(byte[], int, int, byte[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
skipFully(InputStream, long) - Static method in class org.apache.flink.util.IOUtils
Similar to readFully().
SLOT_IDLE_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
The timeout in milliseconds for a idle slot in Slot Pool.
SLOT_MANAGER_TASK_MANAGER_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
SLOT_REQUEST_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
The timeout in milliseconds for requesting a slot from Slot Pool.
SLOT_REQUEST_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
SLOT_TIMEOUT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Timeout for identifying inactive slots.
SlotSharingGroup - Class in org.apache.flink.api.common.operators
Describe the name and the the different resource components of a slot sharing group.
SlotSharingGroup.Builder - Class in org.apache.flink.api.common.operators
Builder for the SlotSharingGroup.
SlotSharingGroupUtils - Class in org.apache.flink.api.common.operators.util
Utils for SlotSharingGroup.
SlotSharingGroupUtils() - Constructor for class org.apache.flink.api.common.operators.util.SlotSharingGroupUtils
 
SNAPSHOT_COMPRESSION - Static variable in class org.apache.flink.configuration.ExecutionOptions
Should be moved to ExecutionCheckpointingOptions along with ExecutionConfig#useSnapshotCompression, which should be put into CheckpointConfig.
snapshotBackwardsCompatible(TypeSerializer<?>...) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerUtils
Takes snapshots of the given serializers.
snapshotBackwardsCompatible(TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerUtils
Takes a snapshot of the given serializer.
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Snapshots the configuration of this TypeSerializer.
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
 
snapshotState() - Method in interface org.apache.flink.api.connector.sink.SinkWriter
Deprecated.
snapshotState(long) - Method in interface org.apache.flink.api.connector.sink.SinkWriter
 
snapshotState(long) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
snapshotState(long) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
snapshotState(long) - Method in interface org.apache.flink.api.connector.source.SourceReader
Checkpoint on the state of the source.
snapshotState(long) - Method in interface org.apache.flink.api.connector.source.SplitEnumerator
Creates a snapshot of the state of this split enumerator, to be stored in a checkpoint.
SO_TIMEOUT - Static variable in class org.apache.flink.configuration.BlobServerOptions
The socket timeout in milliseconds for the blob client.
socketAddressToUrlString(InetSocketAddress) - Static method in class org.apache.flink.util.NetUtils
Encodes an IP address and port to be included in URL.
SolutionSetPlaceHolder(DeltaIterationBase<ST, ?>, OperatorInformation<ST>) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
SORT_INPUTS - Static variable in class org.apache.flink.configuration.ExecutionOptions
 
SORT_SPILLING_THRESHOLD - Static variable in class org.apache.flink.configuration.AlgorithmOptions
 
SORTED_INPUTS_MEMORY - Static variable in class org.apache.flink.configuration.ExecutionOptions
 
SortPartitionOperatorBase<IN> - Class in org.apache.flink.api.common.operators.base
 
SortPartitionOperatorBase(UnaryOperatorInformation<IN, IN>, Ordering, String) - Constructor for class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
Source<T,SplitT extends SourceSplit,EnumChkT> - Interface in org.apache.flink.api.connector.source
The interface for Source.
SourceEvent - Interface in org.apache.flink.api.connector.source
An base class for the events passed between the SourceReaders and Enumerators.
SourceOutput<T> - Interface in org.apache.flink.api.connector.source
The SourceOutput is the gateway for a SourceReader) to emit the produced records and watermarks.
SourceReader<T,SplitT extends SourceSplit> - Interface in org.apache.flink.api.connector.source
The interface for a source reader which is responsible for reading the records from the source splits assigned by SplitEnumerator.
SourceReaderContext - Interface in org.apache.flink.api.connector.source
The class that expose some context from runtime to the SourceReader.
SourceSplit - Interface in org.apache.flink.api.connector.source
An interface for all the Split types to extend.
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
 
SPILLING_MAX_FAN - Static variable in class org.apache.flink.configuration.AlgorithmOptions
 
split(int) - Method in class org.apache.flink.util.LongValueSequenceIterator
 
split(int) - Method in class org.apache.flink.util.NumberSequenceIterator
 
split(int) - Method in class org.apache.flink.util.SplittableIterator
Splits this iterator into a number disjoint iterators.
SplitEnumerator<SplitT extends SourceSplit,CheckpointT> - Interface in org.apache.flink.api.connector.source
A interface of a split enumerator responsible for the followings: 1.
SplitEnumeratorContext<SplitT extends SourceSplit> - Interface in org.apache.flink.api.connector.source
A context class for the SplitEnumerator.
splitId() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
splitId() - Method in interface org.apache.flink.api.connector.source.SourceSplit
Get the split id of this source split.
splitLength - Variable in class org.apache.flink.api.common.io.FileInputFormat
The length of the split that this parallel instance must consume.
splitNumberRange(long, long, int) - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
 
splitPaths(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
 
SplitsAssignment<SplitT extends SourceSplit> - Class in org.apache.flink.api.connector.source
A class containing the splits assignment to the source readers.
SplitsAssignment(Map<Integer, List<SplitT>>) - Constructor for class org.apache.flink.api.connector.source.SplitsAssignment
 
SplitsAssignment(SplitT, int) - Constructor for class org.apache.flink.api.connector.source.SplitsAssignment
 
splitStart - Variable in class org.apache.flink.api.common.io.FileInputFormat
The start of the split that this parallel instance must consume.
SplittableIterator<T> - Class in org.apache.flink.util
Abstract base class for iterators that can split themselves into multiple disjoint iterators.
SplittableIterator() - Constructor for class org.apache.flink.util.SplittableIterator
 
SQL_DATE - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Date.
SQL_TIME - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Time.
SQL_TIMESTAMP - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Timestamp.
SqlDateParser - Class in org.apache.flink.types.parser
Parses a text field into a Date.
SqlDateParser() - Constructor for class org.apache.flink.types.parser.SqlDateParser
 
SqlDateSerializer - Class in org.apache.flink.api.common.typeutils.base
 
SqlDateSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
SqlDateSerializer.SqlDateSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
SqlDateSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlDateSerializer.SqlDateSerializerSnapshot
 
SqlTimeParser - Class in org.apache.flink.types.parser
Parses a text field into a Time.
SqlTimeParser() - Constructor for class org.apache.flink.types.parser.SqlTimeParser
 
SqlTimeSerializer - Class in org.apache.flink.api.common.typeutils.base
 
SqlTimeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
SqlTimeSerializer.SqlTimeSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
SqlTimeSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer.SqlTimeSerializerSnapshot
 
SqlTimestampComparator - Class in org.apache.flink.api.common.typeutils.base
Comparator for comparing Java SQL Timestamps.
SqlTimestampComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
SqlTimestampParser - Class in org.apache.flink.types.parser
Parses a text field into a Timestamp.
SqlTimestampParser() - Constructor for class org.apache.flink.types.parser.SqlTimestampParser
 
SqlTimestampSerializer - Class in org.apache.flink.api.common.typeutils.base
 
SqlTimestampSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
SqlTimestampSerializer.SqlTimestampSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
SqlTimestampSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer.SqlTimestampSerializerSnapshot
 
SqlTimeTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for Java SQL Date/Time/Timestamp.
SqlTimeTypeInfo(Class<T>, TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
SSL_ALGORITHMS - Static variable in class org.apache.flink.configuration.SecurityOptions
The standard SSL algorithms to be supported.
SSL_ENABLED - Static variable in class org.apache.flink.configuration.AkkaOptions
Override SSL support for the Akka transport.
SSL_ENABLED - Static variable in class org.apache.flink.configuration.BlobServerOptions
Flag to override ssl support for the blob service transport.
SSL_ENABLED - Static variable in class org.apache.flink.configuration.SecurityOptions
SSL_ENABLED - Static variable in class org.apache.flink.configuration.WebOptions
Deprecated.
SSL_INTERNAL_CERT_FINGERPRINT - Static variable in class org.apache.flink.configuration.SecurityOptions
For internal SSL, the sha1 fingerprint of the internal certificate to verify the client.
SSL_INTERNAL_CLOSE_NOTIFY_FLUSH_TIMEOUT - Static variable in class org.apache.flink.configuration.SecurityOptions
SSL session timeout after flushing the close_notify message.
SSL_INTERNAL_ENABLED - Static variable in class org.apache.flink.configuration.SecurityOptions
Enable SSL for internal communication (akka rpc, netty data transport, blob server).
SSL_INTERNAL_HANDSHAKE_TIMEOUT - Static variable in class org.apache.flink.configuration.SecurityOptions
SSL session timeout during handshakes.
SSL_INTERNAL_KEY_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
For internal SSL, the password to decrypt the private key.
SSL_INTERNAL_KEYSTORE - Static variable in class org.apache.flink.configuration.SecurityOptions
For internal SSL, the Java keystore file containing the private key and certificate.
SSL_INTERNAL_KEYSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
For internal SSL, the password to decrypt the keystore file containing the certificate.
SSL_INTERNAL_SESSION_CACHE_SIZE - Static variable in class org.apache.flink.configuration.SecurityOptions
SSL session cache size.
SSL_INTERNAL_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.SecurityOptions
SSL session timeout.
SSL_INTERNAL_TRUSTSTORE - Static variable in class org.apache.flink.configuration.SecurityOptions
For internal SSL, the truststore file containing the public CA certificates to verify the ssl peers.
SSL_INTERNAL_TRUSTSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
For internal SSL, the secret to decrypt the truststore.
SSL_KEY_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
Secret to decrypt the server key.
SSL_KEYSTORE - Static variable in class org.apache.flink.configuration.SecurityOptions
The Java keystore file containing the flink endpoint key and certificate.
SSL_KEYSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
Secret to decrypt the keystore file.
SSL_PROTOCOL - Static variable in class org.apache.flink.configuration.SecurityOptions
SSL protocol version to be supported.
SSL_PROVIDER - Static variable in class org.apache.flink.configuration.SecurityOptions
SSL engine provider.
SSL_REST_AUTHENTICATION_ENABLED - Static variable in class org.apache.flink.configuration.SecurityOptions
Enable mututal SSL authentication for external REST endpoints.
SSL_REST_CERT_FINGERPRINT - Static variable in class org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the sha1 fingerprint of the rest client certificate to verify.
SSL_REST_ENABLED - Static variable in class org.apache.flink.configuration.SecurityOptions
Enable SSL for external REST endpoints.
SSL_REST_KEY_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the password to decrypt the private key.
SSL_REST_KEYSTORE - Static variable in class org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the Java keystore file containing the private key and certificate.
SSL_REST_KEYSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the password to decrypt the keystore file containing the certificate.
SSL_REST_TRUSTSTORE - Static variable in class org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the truststore file containing the public CA certificates to verify the ssl peers.
SSL_REST_TRUSTSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
For external (REST) SSL, the secret to decrypt the truststore.
SSL_TRUSTSTORE - Static variable in class org.apache.flink.configuration.SecurityOptions
The truststore file containing the public CA certificates to verify the ssl peers.
SSL_TRUSTSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.SecurityOptions
Secret to decrypt the truststore.
SSL_VERIFY_HOSTNAME - Static variable in class org.apache.flink.configuration.SecurityOptions
Flag to enable/disable hostname verification for the ssl connections.
STANDALONE_CLUSTER_STARTUP_PERIOD_TIME - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
Time in milliseconds of the start-up period of a standalone cluster.
start() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceEnumerator
 
start() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
 
start() - Method in interface org.apache.flink.api.connector.source.SourceReader
Start the reader.
start() - Method in interface org.apache.flink.api.connector.source.SplitEnumerator
Start the split enumerator.
START_WORKER_MAX_FAILURE_RATE - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
The maximum number of start worker failures (Native Kubernetes / Yarn) per minute before pausing requesting new workers.
START_WORKER_RETRY_INTERVAL - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
The time to wait before requesting new workers (Native Kubernetes / Yarn) once the max failure rate of starting workers (ResourceManagerOptions.START_WORKER_MAX_FAILURE_RATE) is reached.
startInstance(String) - Static method in class org.apache.flink.management.jmx.JMXService
Start the JMV-wide singleton JMX server.
startRecord() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
startsWith(CharSequence, int) - Method in class org.apache.flink.types.StringValue
Checks whether the substring, starting at the specified index, starts with the given prefix string.
startsWith(CharSequence) - Method in class org.apache.flink.types.StringValue
Checks whether this StringValue starts with the given prefix string.
STARTUP_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
Timeout for the startup of the actor system.
State - Interface in org.apache.flink.api.common.state
Interface that different types of partitioned state must implement.
STATE_BACKEND - Static variable in class org.apache.flink.configuration.CheckpointingOptions
STATE_BACKEND - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
STATE_BACKEND - Static variable in class org.apache.flink.configuration.StateBackendOptions
The checkpoint storage used to store operator state locally within the cluster during execution.
STATE_CHANGE_LOG_STORAGE - Static variable in class org.apache.flink.configuration.CheckpointingOptions
Which storage to use to store state changelog.
StateBackendOptions - Class in org.apache.flink.configuration
A collection of all configuration options that relate to state backend.
StateBackendOptions() - Constructor for class org.apache.flink.configuration.StateBackendOptions
 
StateDescriptor<S extends State,T> - Class in org.apache.flink.api.common.state
Base class for state descriptors.
StateDescriptor(String, TypeSerializer<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
Create a new StateDescriptor with the given name and the given type serializer.
StateDescriptor(String, TypeInformation<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
Create a new StateDescriptor with the given name and the given type information.
StateDescriptor(String, Class<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
Create a new StateDescriptor with the given name and the given type information.
StateDescriptor.Type - Enum in org.apache.flink.api.common.state
An enumeration of the types of supported states.
StateMigrationException - Exception in org.apache.flink.util
Base class for state migration related exceptions.
StateMigrationException(String) - Constructor for exception org.apache.flink.util.StateMigrationException
 
StateMigrationException(Throwable) - Constructor for exception org.apache.flink.util.StateMigrationException
 
StateMigrationException(String, Throwable) - Constructor for exception org.apache.flink.util.StateMigrationException
 
StateTtlConfig - Class in org.apache.flink.api.common.state
Configuration of state TTL logic.
StateTtlConfig.Builder - Class in org.apache.flink.api.common.state
Builder for the StateTtlConfig.
StateTtlConfig.CleanupStrategies - Class in org.apache.flink.api.common.state
TTL cleanup strategies.
StateTtlConfig.IncrementalCleanupStrategy - Class in org.apache.flink.api.common.state
Configuration of cleanup strategy while taking the full snapshot.
StateTtlConfig.RocksdbCompactFilterCleanupStrategy - Class in org.apache.flink.api.common.state
Configuration of cleanup strategy using custom compaction filter in RocksDB.
StateTtlConfig.StateVisibility - Enum in org.apache.flink.api.common.state
This option configures whether expired user value can be returned or not.
StateTtlConfig.TtlTimeCharacteristic - Enum in org.apache.flink.api.common.state
This option configures time scale to use for ttl.
StateTtlConfig.UpdateType - Enum in org.apache.flink.api.common.state
This option value configures when to update last access timestamp which prolongs state TTL.
statisticsKey - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
 
stopInstance() - Static method in class org.apache.flink.management.jmx.JMXService
Stop the JMX server.
stopWithSavepoint(boolean, String) - Method in interface org.apache.flink.core.execution.JobClient
Stops the associated job on Flink cluster.
STORAGE_DIRECTORY - Static variable in class org.apache.flink.configuration.BlobServerOptions
The config parameter defining the storage directory to be used by the blob server.
stream - Variable in class org.apache.flink.api.common.io.FileInputFormat
The input stream reading from the input file.
stream - Variable in class org.apache.flink.api.common.io.FileOutputFormat
The stream to which the data is written;
stream() - Method in class org.apache.flink.core.fs.OutputStreamAndPath
 
streamInactivityTimeout - Variable in class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The inactivity timeout for a stream, in milliseconds.
streamOpenTimeout - Variable in class org.apache.flink.core.fs.LimitedConnectionsFileSystem.ConnectionLimitingSettings
The stream opening timeout for a stream, in milliseconds.
StreamTimeoutException() - Constructor for exception org.apache.flink.core.fs.LimitedConnectionsFileSystem.StreamTimeoutException
 
StreamTimeoutException(LimitedConnectionsFileSystem.StreamTimeoutException) - Constructor for exception org.apache.flink.core.fs.LimitedConnectionsFileSystem.StreamTimeoutException
 
STRING - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for String.
STRING_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
STRING_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
STRING_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
StringArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for String arrays.
StringArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
StringArraySerializer.StringArraySerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base.array
Serializer configuration snapshot for compatibility and format evolution.
StringArraySerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer.StringArraySerializerSnapshot
 
StringBasedID - Class in org.apache.flink.util
Base class for typed IDs that are internally represented by a string.
StringBasedID(String) - Constructor for class org.apache.flink.util.StringBasedID
Protected constructor to enforce that subclassing.
StringComparator - Class in org.apache.flink.api.common.typeutils.base
 
StringComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.StringComparator
 
STRINGIFIED_NULL_EXCEPTION - Static variable in class org.apache.flink.util.ExceptionUtils
The stringified representation of a null exception reference.
stringifyException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Makes a string representation of the exception's stack trace, or "(null)", if the exception is null.
StringParser - Class in org.apache.flink.types.parser
Converts a variable length field of a byte array into a String.
StringParser() - Constructor for class org.apache.flink.types.parser.StringParser
 
StringSerializer - Class in org.apache.flink.api.common.typeutils.base
Type serializer for String.
StringSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.StringSerializer
 
StringSerializer.StringSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
StringSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.StringSerializer.StringSerializerSnapshot
 
stringType() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Defines that the value of the option should be of String type.
StringUtils - Class in org.apache.flink.util
Utility class to convert objects into strings in vice-versa.
StringValue - Class in org.apache.flink.types
Mutable string data type that implements the Key interface.
StringValue() - Constructor for class org.apache.flink.types.StringValue
Initializes the encapsulated String object with an empty string.
StringValue(CharSequence) - Constructor for class org.apache.flink.types.StringValue
Initializes this StringValue to the value of the given string.
StringValue(StringValue) - Constructor for class org.apache.flink.types.StringValue
Initializes this StringValue to a copy the given StringValue.
StringValue(StringValue, int, int) - Constructor for class org.apache.flink.types.StringValue
Initializes the StringValue to a sub-string of the given StringValue.
StringValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for StringValue based on CopyableValueComparator.
StringValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
StringValueParser - Class in org.apache.flink.types.parser
Converts a variable length field of a byte array into a StringValue.
StringValueParser() - Constructor for class org.apache.flink.types.parser.StringValueParser
 
StringValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
StringValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
StringValueSerializer.StringValueSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
StringValueSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.StringValueSerializer.StringValueSerializerSnapshot
 
StringValueUtils - Class in org.apache.flink.util
Utility class for efficient operations on StringValue.
StringValueUtils.WhitespaceTokenizer - Class in org.apache.flink.util
A tokenizer for string values that uses whitespace characters as token delimiters.
stripCompletionException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Unpacks an CompletionException and returns its cause.
stripException(Throwable, Class<? extends Throwable>) - Static method in class org.apache.flink.util.ExceptionUtils
Unpacks an specified exception and returns its cause.
stripExecutionException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Unpacks an ExecutionException and returns its cause.
stripFileExtension(String) - Static method in class org.apache.flink.util.FileUtils
Remove the extension of the file name.
stripProxy(WrappingProxy<T>) - Static method in class org.apache.flink.util.WrappingProxyUtil
Expects a proxy, and returns the unproxied delegate.
subList(int, int) - Method in class org.apache.flink.types.ListValue
 
submit(RunnableWithException, String, Object...) - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
submit(RunnableWithException, String) - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
submit(Callable<T>, String, Object...) - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
submit(Callable<T>, String) - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
Submits the given command for execution in the future in the mailbox thread and returns a Future representing that command.
SUBMIT_ENABLE - Static variable in class org.apache.flink.configuration.WebOptions
Config parameter indicating whether jobs can be uploaded and run from the web-frontend.
SubmoduleClassLoader - Class in org.apache.flink.core.classloading
Loads all classes from the submodule jar, except for explicitly white-listed packages.
SubmoduleClassLoader(URL[], ClassLoader) - Constructor for class org.apache.flink.core.classloading.SubmoduleClassLoader
 
subSequence(int, int) - Method in class org.apache.flink.types.StringValue
 
substring(int) - Method in class org.apache.flink.types.StringValue
Returns a new StringValuestring that is a substring of this string.
substring(int, int) - Method in class org.apache.flink.types.StringValue
Returns a new StringValuestring that is a substring of this string.
substring(StringValue, int) - Method in class org.apache.flink.types.StringValue
Copies a substring of this string into the given target StringValue.
substring(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
Copies a substring of this string into the given target StringValue.
subtract(ResourceSpec) - Method in class org.apache.flink.api.common.operators.ResourceSpec
Subtracts another resource spec from this one.
subtract(T) - Method in class org.apache.flink.api.common.resources.Resource
 
subtract(MemorySize) - Method in class org.apache.flink.configuration.MemorySize
 
suffix(String) - Method in class org.apache.flink.core.fs.Path
Adds a suffix to the final name in the path.
SupplierFromSerializableTimestampAssigner(SerializableTimestampAssigner<T>) - Constructor for class org.apache.flink.api.common.eventtime.TimestampAssignerSupplier.SupplierFromSerializableTimestampAssigner
 
SupplierWithException<R,E extends Throwable> - Interface in org.apache.flink.util.function
A functional interface for a Supplier that may throw exceptions.
supplyAsync(SupplierWithException<T, ?>, Executor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Returns a future which is completed with the result of the SupplierWithException.
supportsCompareAgainstReference() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
 
supportsMultiPaths() - Method in class org.apache.flink.api.common.io.FileInputFormat
Deprecated.
Will be removed for Flink 2.0.
supportsMultiPaths() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.InstantComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Checks whether the data type supports the creation of a normalized key for comparison.
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.NullAwareComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
supportsResume() - Method in class org.apache.flink.core.fs.local.LocalRecoverableWriter
 
supportsResume() - Method in interface org.apache.flink.core.fs.RecoverableWriter
Checks whether the writer and its streams support resuming (appending to) files after recovery (via the RecoverableWriter.recover(ResumeRecoverable) method).
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Check whether this comparator supports to serialize the record in a format that replaces its keys by a normalized key.
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.NullAwareComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
suppressExceptions(RunnableWithException) - Static method in class org.apache.flink.util.ExceptionUtils
 
swap() - Method in class org.apache.flink.api.java.tuple.Tuple2
Returns a shallow copy of the tuple with swapped values.
swapBytes(byte[], MemorySegment, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Swaps bytes between two memory segments, using the given auxiliary buffer.
switchExecutor(CompletableFuture<? extends T>, Executor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Switches the execution context of the given source future.
sync() - Method in class org.apache.flink.core.fs.FSDataOutputStream
Flushes the data all the way to the persistent non-volatile storage (for example disks).
sync() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
sync() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
SYSTEM_RESOURCE_METRICS - Static variable in class org.apache.flink.configuration.MetricOptions
Whether Flink should report system resource metrics such as machine's CPU, memory or network usage.
SYSTEM_RESOURCE_METRICS_PROBING_INTERVAL - Static variable in class org.apache.flink.configuration.MetricOptions
Interval between probing of system resource metrics specified in milliseconds.
SystemClock - Class in org.apache.flink.util.clock
A clock that returns the time of the system / process.

T

TARGET - Static variable in class org.apache.flink.configuration.DeploymentOptions
 
TASK_CANCELLATION_INTERVAL - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Time interval in milliseconds between two successive task cancellation attempts.
TASK_CANCELLATION_INTERVAL_MILLIS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TASK_CANCELLATION_TIMEOUT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Timeout in milliseconds after which a task cancellation times out and leads to a fatal TaskManager error.
TASK_CANCELLATION_TIMEOUT_TIMERS - Static variable in class org.apache.flink.configuration.TaskManagerOptions
This configures how long we wait for the timers in milliseconds to finish all pending timer threads when the stream task is cancelled.
TASK_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Task Heap Memory size for TaskExecutors.
TASK_MANAGER_DATA_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_DATA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_DEBUG_MEMORY_USAGE_START_LOG_THREAD - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TASK_MANAGER_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Deprecated.
use TaskManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and TaskManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups.
TASK_MANAGER_HEAP_MEMORY_MB - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Deprecated.
use TaskManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and TaskManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups.
TASK_MANAGER_HOSTNAME_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TASK_MANAGER_INITIAL_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_IPC_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TASK_MANAGER_LOG_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the taskmanager log file location.
TASK_MANAGER_MAX_REGISTARTION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_MAX_REGISTRATION_DURATION - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_MEMORY_FRACTION_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
TASK_MANAGER_MEMORY_OFF_HEAP_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
TASK_MANAGER_MEMORY_PRE_ALLOCATE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
TASK_MANAGER_MEMORY_SEGMENT_SIZE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_MEMORY_SIZE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore
TASK_MANAGER_NETWORK_NUM_BUFFERS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_NUM_TASK_SLOTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TASK_MANAGER_REFUSED_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_REGISTRATION_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
Timeout for TaskManagers to register at the active resource managers.
TASK_MANAGER_RELEASE_WHEN_RESULT_CONSUMED - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
Deprecated.
The default value should be reasonable enough in all cases, this option is to fallback to older behaviour which will be removed or refactored in future.
TASK_MANAGER_RESOURCE_ID - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The TaskManager's ResourceID.
TASK_MANAGER_RESOURCE_ID_METADATA - Static variable in class org.apache.flink.configuration.TaskManagerOptionsInternal
 
TASK_MANAGER_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
The timeout for an idle task manager to be released, in milliseconds.
TASK_MANAGER_TMP_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TASK_OFF_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Task Off-Heap Memory size for TaskExecutors.
TaskInfo - Class in org.apache.flink.api.common
Encapsulates task-specific information: name, index of subtask, parallelism and attempt number.
TaskInfo(String, int, int, int, int) - Constructor for class org.apache.flink.api.common.TaskInfo
 
TaskInfo(String, int, int, int, int, String) - Constructor for class org.apache.flink.api.common.TaskInfo
 
TaskManagerExceptionUtils - Class in org.apache.flink.util
Exception utils to handle and enrich exceptions occurring in TaskManager.
TaskManagerOptions - Class in org.apache.flink.configuration
The set of configuration options relating to TaskManager and Task settings.
TaskManagerOptionsInternal - Class in org.apache.flink.configuration
TaskManager options that are not meant to be used by the user.
TaskManagerOptionsInternal() - Constructor for class org.apache.flink.configuration.TaskManagerOptionsInternal
 
TCP_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
The Akka tcp connection timeout.
TemporaryClassLoaderContext - Class in org.apache.flink.util
Sets a context class loader in a "try-with-resources" pattern.
TERMINATION_CRITERION_AGGREGATOR_NAME - Static variable in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
terminationCriterion - Variable in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
TerminationCriterionAggregationConvergence() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
 
TerminationCriterionAggregator() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
TerminationCriterionMapper() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
 
TernaryBoolean - Enum in org.apache.flink.util
A ternary boolean, which can have the values 'true', 'false', or 'undefined'.
testForUnsplittable(FileStatus) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
text(String, InlineElement...) - Method in class org.apache.flink.configuration.description.Description.DescriptionBuilder
Adds a block of text with placeholders ("%s") that will be replaced with proper string representation of given InlineElement.
text(String) - Method in class org.apache.flink.configuration.description.Description.DescriptionBuilder
Creates a simple block of text.
text(String, InlineElement...) - Static method in class org.apache.flink.configuration.description.TextElement
Creates a block of text with placeholders ("%s") that will be replaced with proper string representation of given InlineElement.
text(String) - Static method in class org.apache.flink.configuration.description.TextElement
Creates a simple block of text.
TextElement - Class in org.apache.flink.configuration.description
Represents a text block in the Description.
TextElement.TextStyle - Enum in org.apache.flink.configuration.description
Styles that can be applied to TextElement e.g.
thenAcceptAsyncIfNotDone(CompletableFuture<IN>, Executor, Consumer<? super IN>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a consumer to accept the result of this future.
thenApplyAsyncIfNotDone(CompletableFuture<IN>, Executor, Function<? super IN, ? extends OUT>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a function to apply to this future.
thenComposeAsyncIfNotDone(CompletableFuture<IN>, Executor, Function<? super IN, ? extends CompletionStage<OUT>>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a function to compose with this future.
ThrowableCatchingRunnable - Class in org.apache.flink.util
This class catches all the Throwables from the wrapped runnable.
ThrowableCatchingRunnable(Consumer<Throwable>, Runnable) - Constructor for class org.apache.flink.util.ThrowableCatchingRunnable
 
throwIfCompletedExceptionally(CompletableFuture<?>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Throws the causing exception if the given future is completed exceptionally, otherwise do nothing.
ThrowingConsumer<T,E extends Throwable> - Interface in org.apache.flink.util.function
This interface is basically Java's Consumer interface enhanced with the ability to throw an exception.
ThrowingRunnable<E extends Throwable> - Interface in org.apache.flink.util.function
Similar to a Runnable, this interface is used to capture a block of code to be executed.
Time - Class in org.apache.flink.api.common.time
The definition of a time interval.
TIME - Static variable in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
timeComparator - Variable in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
timeLeft() - Method in class org.apache.flink.api.common.time.Deadline
Returns the time left between the deadline and now.
timeLeftIfAny() - Method in class org.apache.flink.api.common.time.Deadline
Returns the time left between the deadline and now.
TIMEOUT - Static variable in class org.apache.flink.configuration.WebOptions
Timeout for asynchronous operations by the web monitor in milliseconds.
TIMESTAMP - Static variable in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
timestamp() - Method in interface org.apache.flink.api.connector.sink.SinkWriter.Context
Returns the timestamp of the current input record or null if the element does not have an assigned timestamp.
TimestampAssigner<T> - Interface in org.apache.flink.api.common.eventtime
A TimestampAssigner assigns event time timestamps to elements.
TimestampAssignerSupplier<T> - Interface in org.apache.flink.api.common.eventtime
A supplier for TimestampAssigners.
TimestampAssignerSupplier.Context - Interface in org.apache.flink.api.common.eventtime
TimestampAssignerSupplier.SupplierFromSerializableTimestampAssigner<T> - Class in org.apache.flink.api.common.eventtime
We need an actual class.
TimeUtils - Class in org.apache.flink.util
Collection of utilities about time intervals.
TimeUtils() - Constructor for class org.apache.flink.util.TimeUtils
 
TMP_DIR - Static variable in class org.apache.flink.configuration.WebOptions
The config parameter defining the flink web directory to be used by the webmonitor.
TMP_DIRS - Static variable in class org.apache.flink.configuration.CoreOptions
The config parameter defining the directories for temporary files, separated by ",", "|", or the system's File.pathSeparator.
to() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
toArray() - Method in class org.apache.flink.api.common.operators.util.FieldSet
Transforms the field set into an array of field IDs.
toArray() - Method in class org.apache.flink.types.ListValue
 
toArray(T[]) - Method in class org.apache.flink.types.ListValue
 
toByteArray() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
toByteValue() - Method in enum org.apache.flink.types.RowKind
Returns the byte value representation of this RowKind.
toDuration(Time) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Converts Flink time into a Duration.
toDuration(Time) - Static method in class org.apache.flink.util.TimeUtils
Translates Time to Duration.
toFieldList() - Method in class org.apache.flink.api.common.operators.util.FieldList
 
toFieldList() - Method in class org.apache.flink.api.common.operators.util.FieldSet
Turns the FieldSet into an ordered FieldList.
toHexString() - Method in class org.apache.flink.util.AbstractID
Returns pure String representation of the ID in hexadecimal.
toHumanReadableString() - Method in class org.apache.flink.api.common.resources.CPUResource
 
toHumanReadableString() - Method in class org.apache.flink.configuration.MemorySize
 
toLowerCase(StringValue) - Static method in class org.apache.flink.util.StringValueUtils
Converts the given StringValue into a lower case variant.
toMap() - Method in class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
Convert UserConfig into a Map<String, String> representation.
toMap() - Method in class org.apache.flink.configuration.Configuration
 
toMap() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
toMilliseconds() - Method in class org.apache.flink.api.common.time.Time
Converts the time interval to milliseconds.
toOptional() - Method in class org.apache.flink.types.SerializableOptional
 
toQuotedListString(Object[]) - Static method in class org.apache.flink.util.StringUtils
Generates a string containing a comma-separated list of values in double-quotes.
toResultMap(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
Transform the Map with accumulators into a Map containing only the results.
toStream(Iterable<E>) - Static method in class org.apache.flink.util.IterableUtils
Convert the given Iterable to a Stream.
toString() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
toString() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
toString() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
toString() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
toString() - Method in class org.apache.flink.api.common.accumulators.Histogram
 
toString() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
toString() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
toString() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
toString() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
toString() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
toString() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
toString() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
toString() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
toString() - Method in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
toString() - Method in class org.apache.flink.api.common.eventtime.Watermark
 
toString() - Method in class org.apache.flink.api.common.ExecutionConfig
 
toString() - Method in class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
toString() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
toString() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
toString() - Method in class org.apache.flink.api.common.JobExecutionResult
 
toString() - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
toString() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
 
toString() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
 
toString() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
toString() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
toString() - Method in class org.apache.flink.api.common.operators.Operator
 
toString() - Method in class org.apache.flink.api.common.operators.OperatorInformation
 
toString() - Method in class org.apache.flink.api.common.operators.Ordering
 
toString() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
toString() - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
toString() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
toString() - Method in class org.apache.flink.api.common.resources.Resource
 
toString() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration
 
toString() - Method in class org.apache.flink.api.common.state.StateDescriptor
 
toString() - Method in class org.apache.flink.api.common.state.StateTtlConfig
 
toString() - Method in class org.apache.flink.api.common.time.Deadline
 
toString() - Method in class org.apache.flink.api.common.time.Time
 
toString() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
 
toString() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
 
toString() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
toString() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
toString() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
toString() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
toString() - Method in class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
toString() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility
 
toString() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
 
toString() - Method in class org.apache.flink.api.connector.source.SplitsAssignment
 
toString() - Method in class org.apache.flink.api.dag.Transformation
 
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.EitherTypeInfo
 
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.ListTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.MultisetTypeInfo
 
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.RowTypeInfo
 
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.configuration.ConfigOption
 
toString() - Method in class org.apache.flink.configuration.Configuration
 
toString() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
toString() - Method in class org.apache.flink.configuration.FallbackKey
 
toString() - Method in class org.apache.flink.configuration.MemorySize
 
toString() - Method in class org.apache.flink.core.execution.DetachedJobExecutionResult
 
toString() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
toString() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
toString() - Method in class org.apache.flink.core.fs.FileInputSplit
 
toString() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
toString() - Method in class org.apache.flink.core.fs.Path
 
toString() - Method in class org.apache.flink.core.fs.PluginFileSystemFactory
 
toString() - Method in class org.apache.flink.core.io.GenericInputSplit
 
toString() - Method in class org.apache.flink.core.io.LocatableInputSplit
 
toString() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
toString() - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
toString() - Method in class org.apache.flink.core.plugin.DefaultPluginManager
 
toString() - Method in class org.apache.flink.core.plugin.PluginDescriptor
 
toString() - Method in class org.apache.flink.types.BooleanValue
 
toString() - Method in class org.apache.flink.types.ByteValue
 
toString() - Method in class org.apache.flink.types.CharValue
 
toString() - Method in class org.apache.flink.types.DoubleValue
 
toString() - Method in class org.apache.flink.types.Either.Left
 
toString() - Method in class org.apache.flink.types.Either.Right
 
toString() - Method in class org.apache.flink.types.FloatValue
 
toString() - Method in class org.apache.flink.types.IntValue
 
toString() - Method in class org.apache.flink.types.ListValue
 
toString() - Method in class org.apache.flink.types.LongValue
 
toString() - Method in class org.apache.flink.types.MapValue
 
toString() - Method in class org.apache.flink.types.NullValue
 
toString() - Method in class org.apache.flink.types.Row
 
toString() - Method in class org.apache.flink.types.ShortValue
 
toString() - Method in class org.apache.flink.types.StringValue
 
toString() - Method in class org.apache.flink.util.AbstractID
 
toString() - Method in class org.apache.flink.util.CompressedSerializedValue
 
toString() - Method in class org.apache.flink.util.OptionalFailure
 
toString() - Method in class org.apache.flink.util.OutputTag
 
toString() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
toString() - Method in exception org.apache.flink.util.SerializedThrowable
 
toString() - Method in class org.apache.flink.util.SerializedValue
 
toString() - Method in class org.apache.flink.util.StringBasedID
 
TOTAL_FLINK_MEMORY - Static variable in class org.apache.flink.configuration.JobManagerOptions
Total Flink Memory size for the JobManager.
TOTAL_FLINK_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Total Flink Memory size for the TaskExecutors.
TOTAL_PROCESS_MEMORY - Static variable in class org.apache.flink.configuration.JobManagerOptions
Total Process Memory size for the JobManager.
TOTAL_PROCESS_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Total Process Memory size for the TaskExecutors.
toUri() - Method in class org.apache.flink.core.fs.Path
Converts the path object to a URI.
toURL(Path) - Static method in class org.apache.flink.util.FileUtils
Converts the given Path into a file URL.
Transformation<T> - Class in org.apache.flink.api.dag
A Transformation represents the operation that creates a DataStream.
Transformation(String, TypeInformation<T>, int) - Constructor for class org.apache.flink.api.dag.Transformation
Creates a new Transformation with the given name, output type and parallelism.
transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - Method in interface org.apache.flink.api.common.typeutils.LegacySerializerSnapshotTransformer
Transform a TypeSerializerSnapshot that was previously associated with this TypeSerializer.
TRANSPORT_TYPE - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
 
TraversableOnceException - Exception in org.apache.flink.util
An exception, indicating that an Iterable can only be traversed once, but has been attempted to traverse an additional time.
TraversableOnceException() - Constructor for exception org.apache.flink.util.TraversableOnceException
Creates a new exception with a default message.
TriConsumer<S,T,U> - Interface in org.apache.flink.util.function
Operation which is performed on three given arguments.
TriConsumerWithException<S,T,U,E extends Throwable> - Interface in org.apache.flink.util.function
A checked extension of the TriConsumer interface.
TriFunction<S,T,U,R> - Interface in org.apache.flink.util.function
Function which takes three arguments.
TriFunctionWithException<S,T,U,R,E extends Throwable> - Interface in org.apache.flink.util.function
Function which takes three arguments.
triggerSavepoint(String) - Method in interface org.apache.flink.core.execution.JobClient
Triggers a savepoint for the associated job.
TRUE - Static variable in class org.apache.flink.types.BooleanValue
 
tryCleanupOnError() - Method in interface org.apache.flink.api.common.io.CleanupWhenUnsuccessful
Hook that is called upon an unsuccessful execution.
tryCleanupOnError() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
tryDeserializeAndThrow(Throwable, ClassLoader) - Static method in class org.apache.flink.util.ExceptionUtils
Tries to find a SerializedThrowable as the cause of the given throwable and throws its deserialized value.
tryEnrichOutOfMemoryError(Throwable, String, String, String) - Static method in class org.apache.flink.util.ExceptionUtils
Tries to enrich OutOfMemoryErrors being part of the passed root Throwable's cause tree.
tryEnrichTaskManagerError(Throwable) - Static method in class org.apache.flink.util.TaskManagerExceptionUtils
Tries to enrich the passed exception or its causes with additional information.
tryReadFully(InputStream, byte[]) - Static method in class org.apache.flink.util.IOUtils
tryReadSerializer(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Deprecated.
Reads from a data input view a TypeSerializer that was previously written using TypeSerializerSerializationUtil.writeSerializer(DataOutputView, TypeSerializer).
tryReadSerializer(DataInputView, ClassLoader, boolean) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Deprecated.
Reads from a data input view a TypeSerializer that was previously written using TypeSerializerSerializationUtil.writeSerializer(DataOutputView, TypeSerializer).
tryRethrowException(Exception) - Static method in class org.apache.flink.util.ExceptionUtils
Tries to throw the given exception if not null.
tryRethrowIOException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Tries to throw the given Throwable in scenarios where the signatures allows only IOExceptions (and RuntimeException and Error).
tryYield() - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
This methods attempts to run the command at the head of the mailbox.
TUPLE(TypeInformation<?>...) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for subclasses of Flink's Tuple (namely Tuple0 till Tuple25) with fields of the given types.
TUPLE(Class<T>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for typed subclasses of Flink's Tuple.
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
A builder class for Tuple0.
Tuple0Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
Tuple0Serializer - Class in org.apache.flink.api.java.typeutils.runtime
 
Tuple0SerializerSnapshot - Class in org.apache.flink.api.java.typeutils.runtime
Tuple0SerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.Tuple0SerializerSnapshot
 
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
A builder class for Tuple10.
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
A builder class for Tuple11.
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
A builder class for Tuple12.
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
A builder class for Tuple13.
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
A builder class for Tuple14.
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
A builder class for Tuple15.
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
A builder class for Tuple16.
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
A builder class for Tuple17.
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
A builder class for Tuple18.
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
A builder class for Tuple19.
Tuple19Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
Tuple1Builder<T0> - Class in org.apache.flink.api.java.tuple.builder
A builder class for Tuple1.
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
A builder class for Tuple20.
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
A builder class for Tuple21.
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
A builder class for Tuple22.
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
A builder class for Tuple23.
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
A builder class for Tuple24.
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
A builder class for Tuple25.
Tuple25Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
Tuple2Builder<T0,T1> - Class in org.apache.flink.api.java.tuple.builder
A builder class for Tuple2.
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
A builder class for Tuple3.
Tuple3Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
Tuple4<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple
A tuple with 4 fields.
Tuple4() - Constructor for class org.apache.flink.api.java.tuple.Tuple4
Creates a new tuple where all fields are null.
Tuple4(T0, T1, T2, T3) - Constructor for class org.apache.flink.api.java.tuple.Tuple4
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple4Builder<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple.builder
A builder class for Tuple4.
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
A builder class for Tuple5.
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
A builder class for Tuple6.
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
A builder class for Tuple7.
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
A builder class for Tuple8.
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
A builder class for Tuple9.
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
 
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
 
TupleSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
Snapshot of a tuple serializer's configuration.
TupleSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
TupleSerializerConfigSnapshot(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
TupleSerializerSnapshot<T extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
Snapshot of a tuple serializer's configuration.
TupleSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
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
 
TypeComparable<T> - Class in org.apache.flink.api.common.operators.util
Wrapper that is used to store elements for which we have a TypeComparator in a Hash Map.
TypeComparable(T, TypeComparator<T>) - Constructor for class org.apache.flink.api.common.operators.util.TypeComparable
 
TypeComparator<T> - Class in org.apache.flink.api.common.typeutils
This interface describes the methods that are required for a data type to be handled by the pact runtime.
TypeComparator() - Constructor for class org.apache.flink.api.common.typeutils.TypeComparator
 
TypeComparatorFactory<T> - Interface in org.apache.flink.api.common.typeutils
 
TypeExtractionException - Exception in org.apache.flink.api.java.typeutils
Type extraction always contains some uncertainty due to unpredictable JVM differences between vendors or versions.
TypeExtractionException() - Constructor for exception org.apache.flink.api.java.typeutils.TypeExtractionException
Creates a new exception with no message.
TypeExtractionException(String) - Constructor for exception org.apache.flink.api.java.typeutils.TypeExtractionException
Creates a new exception with the given message.
TypeExtractionException(String, Throwable) - Constructor for exception org.apache.flink.api.java.typeutils.TypeExtractionException
Creates a new exception with the given message and cause.
TypeExtractionUtils - Class in org.apache.flink.api.java.typeutils
 
TypeExtractionUtils.LambdaExecutable - Class in org.apache.flink.api.java.typeutils
Similar to a Java 8 Executable but with a return type.
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
 
TypeHint<T> - Class in org.apache.flink.api.common.typeinfo
A utility class for describing generic types.
TypeHint() - Constructor for class org.apache.flink.api.common.typeinfo.TypeHint
Creates a hint for the generic type in the class signature.
TypeInfo - Annotation Type in org.apache.flink.api.common.typeinfo
Annotation for specifying a corresponding TypeInfoFactory that can produce TypeInformation for the annotated type.
TypeInfoFactory<T> - Class in org.apache.flink.api.common.typeinfo
Base class for implementing a type information factory.
TypeInfoFactory() - Constructor for class org.apache.flink.api.common.typeinfo.TypeInfoFactory
 
TypeInformation<T> - Class in org.apache.flink.api.common.typeinfo
TypeInformation is the core class of Flink's type system.
TypeInformation() - Constructor for class org.apache.flink.api.common.typeinfo.TypeInformation
 
TypeInformationSerializationSchema<T> - Class in org.apache.flink.api.common.serialization
A serialization and deserialization schema that uses Flink's serialization stack to transform typed from and to byte arrays.
TypeInformationSerializationSchema(TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
Creates a new de-/serialization schema for the given type.
TypeInformationSerializationSchema(TypeInformation<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
Creates a new de-/serialization schema for the given type.
TypePairComparator<T1,T2> - Class in org.apache.flink.api.common.typeutils
This interface defines the method required by the runtime to use data types in join-like operations.
TypePairComparator() - Constructor for class org.apache.flink.api.common.typeutils.TypePairComparator
 
TypePairComparatorFactory<T1,T2> - Interface in org.apache.flink.api.common.typeutils
 
types - Variable in class org.apache.flink.api.common.operators.Ordering
 
Types - Class in org.apache.flink.api.common.typeinfo
This class gives access to the type information of the most common types for which Flink has built-in serializers and comparators.
Types() - Constructor for class org.apache.flink.api.common.typeinfo.Types
 
types - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
TypeSerializer<T> - Class in org.apache.flink.api.common.typeutils
This interface describes the methods that are required for a data type to be handled by the Flink runtime.
TypeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializer
 
TypeSerializerConfigSnapshot<T> - Class in org.apache.flink.api.common.typeutils
Deprecated.
TypeSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Deprecated.
 
TypeSerializerConfigSnapshot.SelfResolvingTypeSerializer<E> - Interface in org.apache.flink.api.common.typeutils
Deprecated.
This interface assists with the migration path to the new serialization abstraction.
TypeSerializerFactory<T> - Interface in org.apache.flink.api.common.typeutils
 
TypeSerializerSchemaCompatibility<T> - Class in org.apache.flink.api.common.typeutils
A TypeSerializerSchemaCompatibility represents information about whether or not a TypeSerializer can be safely used to read data written by a previous type serializer.
TypeSerializerSerializationProxy(ClassLoader) - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
Deprecated.
 
TypeSerializerSerializationProxy(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
Deprecated.
 
TypeSerializerSerializationUtil - Class in org.apache.flink.api.common.typeutils
Deprecated.
This utility class was used to write serializers into checkpoints. Starting from Flink 1.6.x, this should no longer happen, and therefore this class is deprecated. It remains here for backwards compatibility paths.
TypeSerializerSerializationUtil() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Deprecated.
 
TypeSerializerSerializationUtil.TypeSerializerSerializationProxy<T> - Class in org.apache.flink.api.common.typeutils
Deprecated.
Utility serialization proxy for a TypeSerializer.
TypeSerializerSingleton<T> - Class in org.apache.flink.api.common.typeutils.base
 
TypeSerializerSingleton() - Constructor for class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
TypeSerializerSnapshot<T> - Interface in org.apache.flink.api.common.typeutils
A TypeSerializerSnapshot is a point-in-time view of a TypeSerializer's configuration.
TypeSerializerSnapshotSerializationUtil - Class in org.apache.flink.api.common.typeutils
Utility methods for serialization of TypeSerializerSnapshot.
TypeSerializerSnapshotSerializationUtil() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
 
TypeSerializerUtils - Class in org.apache.flink.api.common.typeutils
Utilities for dealing with the TypeSerializer and the TypeSerializerSnapshot.
typeToClass(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Convert ParameterizedType or Class to a Class.
typeUsed - Variable in class org.apache.flink.api.dag.Transformation
 

U

UnaryOperatorInformation<IN,OUT> - Class in org.apache.flink.api.common.operators
A class for holding information about a single input operator, such as input/output TypeInformation.
UnaryOperatorInformation(TypeInformation<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.UnaryOperatorInformation
 
UNCAUGHT_EXCEPTION_HANDLING - Static variable in class org.apache.flink.configuration.ClusterOptions
 
uncaughtException(Thread, Throwable) - Method in class org.apache.flink.util.FatalExitExceptionHandler
 
unchecked(BiConsumerWithException<A, B, ?>) - Static method in interface org.apache.flink.util.function.BiConsumerWithException
unchecked(BiFunctionWithException<A, B, C, ?>) - Static method in interface org.apache.flink.util.function.BiFunctionWithException
unchecked(CheckedSupplier<R>) - Static method in interface org.apache.flink.util.function.CheckedSupplier
 
unchecked(ThrowingRunnable<?>) - Static method in interface org.apache.flink.util.function.ThrowingRunnable
Converts a ThrowingRunnable into a Runnable which throws all checked exceptions as unchecked.
unchecked(TriConsumerWithException<A, B, C, ?>) - Static method in interface org.apache.flink.util.function.TriConsumerWithException
unchecked(TriFunctionWithException<A, B, C, D, ?>) - Static method in interface org.apache.flink.util.function.TriFunctionWithException
uncheckedConsumer(ThrowingConsumer<A, ?>) - Static method in class org.apache.flink.util.function.FunctionUtils
Converts a ThrowingConsumer into a Consumer which throws checked exceptions as unchecked.
uncheckedFunction(FunctionWithException<A, B, ?>) - Static method in class org.apache.flink.util.function.FunctionUtils
Convert at FunctionWithException into a Function.
uncheckedSupplier(SupplierWithException<T, ?>) - Static method in class org.apache.flink.util.function.FunctionUtils
Converts a SupplierWithException into a Supplier which throws all checked exceptions as unchecked.
Union<T> - Class in org.apache.flink.api.common.operators
This operator represents a Union between two inputs.
Union(BinaryOperatorInformation<T, T, T>, String) - Constructor for class org.apache.flink.api.common.operators.Union
Creates a new Union operator.
Union(Operator<T>, Operator<T>, String) - Constructor for class org.apache.flink.api.common.operators.Union
 
unionFields(Record) - Method in class org.apache.flink.types.Record
Unions the other record's fields with this records fields.
UnionIterator<T> - Class in org.apache.flink.util
An iterator that concatenates a collection of iterators.
UnionIterator() - Constructor for class org.apache.flink.util.UnionIterator
 
UNKNOWN - Static variable in class org.apache.flink.api.common.operators.ResourceSpec
A ResourceSpec that indicates an unknown set of resources.
UnloadableDummyTypeSerializer<T> - Class in org.apache.flink.api.common.typeutils
Dummy TypeSerializer to avoid that data is lost when checkpointing again a serializer for which we encountered a ClassNotFoundException or InvalidClassException.
UnloadableDummyTypeSerializer(byte[]) - Constructor for class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
UnloadableDummyTypeSerializer(byte[], Throwable) - Constructor for class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
UnmodifiableConfiguration - Class in org.apache.flink.configuration
Unmodifiable version of the Configuration class.
UnmodifiableConfiguration(Configuration) - Constructor for class org.apache.flink.configuration.UnmodifiableConfiguration
Creates a new UnmodifiableConfiguration, which holds a copy of the given configuration that cannot be altered.
unmonitorUserSystemExitForCurrentThread() - Static method in class org.apache.flink.core.security.FlinkSecurityManager
 
unregisterCloseable(C) - Method in class org.apache.flink.util.AbstractCloseableRegistry
Removes a Closeable from the registry.
unregisterOutput(String) - Method in class org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
 
unresolvedHostAndPortToNormalizedString(String, int) - Static method in class org.apache.flink.util.NetUtils
Returns a valid address for Akka.
unresolvedHostToNormalizedString(String) - Static method in class org.apache.flink.util.NetUtils
Returns an address in a normalized format for Akka.
UNSAFE - Static variable in class org.apache.flink.core.memory.MemoryUtils
The "unsafe", which can be used to perform native memory accesses.
unsplittable - Variable in class org.apache.flink.api.common.io.FileInputFormat
Some file input formats are not splittable on a block level (deflate) Therefore, the FileInputFormat can only read whole files.
UnsupportedFileSystemSchemeException - Exception in org.apache.flink.core.fs
An exception to indicate that a specific file system scheme is not supported.
UnsupportedFileSystemSchemeException(String) - Constructor for exception org.apache.flink.core.fs.UnsupportedFileSystemSchemeException
Creates a new exception with the given message.
UnsupportedFileSystemSchemeException(String, Throwable) - Constructor for exception org.apache.flink.core.fs.UnsupportedFileSystemSchemeException
Creates a new exception with the given message and cause.
unsupportedOperationFuture() - Static method in class org.apache.flink.util.concurrent.FutureUtils
Returns an exceptionally completed future with an UnsupportedOperationException.
unwrap() - Method in exception org.apache.flink.util.WrappingRuntimeException
Recursively unwraps this WrappingRuntimeException and its causes, getting the first non wrapping exception.
unwrapOptionals() - Method in class org.apache.flink.util.LinkedOptionalMap
Assuming all the entries of this map are present (keys and values) this method would return a map with these key and values, stripped from their Optional wrappers.
update(List<T>) - Method in interface org.apache.flink.api.common.state.ListState
Updates the operator state accessible by AppendingState.get() by updating existing values to to the given list of values.
update(T) - Method in interface org.apache.flink.api.common.state.ValueState
Updates the operator state accessible by ValueState.value() to the given value.
updateBinaryRepresenation() - Method in class org.apache.flink.types.Record
Updates the binary representation of the data, such that it reflects the state of the currently stored fields.
updateDetailMessage(Throwable, Function<Throwable, String>) - Static method in class org.apache.flink.util.ExceptionUtils
Updates error messages of Throwables appearing in the cause tree of the passed root Throwable.
updateManagedMemoryStateBackendUseCase(boolean) - Method in class org.apache.flink.api.dag.Transformation
 
updateStatus(int, boolean) - Method in class org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
Updates the idleness for the given partial watermark.
updateTtlOnCreateAndWrite() - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
 
updateTtlOnReadAndWrite() - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
 
updateWatermark(int, long) - Method in class org.apache.flink.api.common.eventtime.IndexedCombinedWatermarkStatus
Updates the value for the given partial watermark.
UPLOAD_DIR - Static variable in class org.apache.flink.configuration.WebOptions
The config parameter defining the directory for uploading the job jars.
UPPER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.api.dag.Transformation
 
upperPart - Variable in class org.apache.flink.util.AbstractID
The upper part of the actual ID.
USE_BATCH_STATE_BACKEND - Static variable in class org.apache.flink.configuration.ExecutionOptions
 
USE_LARGE_RECORD_HANDLER_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
USE_LARGE_RECORDS_HANDLER - Static variable in class org.apache.flink.configuration.AlgorithmOptions
 
USE_LEGACY_TO_STRING - Static variable in class org.apache.flink.types.RowUtils
Internal flag to enable the legacy Row.toString() implementation for tests.
useProcessingTime() - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
 
UserCodeClassLoader - Interface in org.apache.flink.util
UserCodeClassLoader allows to register release hooks for a user code class loader.
UserCodeClassWrapper<T> - Class in org.apache.flink.api.common.operators.util
This holds a class containing user defined code.
UserCodeClassWrapper(Class<? extends T>) - Constructor for class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
UserCodeObjectWrapper<T> - Class in org.apache.flink.api.common.operators.util
This holds an actual object containing user defined code.
UserCodeObjectWrapper(T) - Constructor for class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
UserCodeWrapper<T> - Interface in org.apache.flink.api.common.operators.util
UDf operators can have either a class or an object containing the user code, this is the common interface to access them.
userFunction - Variable in class org.apache.flink.api.common.operators.AbstractUdfOperator
The object or class containing the user function.
UserSystemExitException - Exception in org.apache.flink.core.security
Indicates that user tried to exit JVM.
UserSystemExitException() - Constructor for exception org.apache.flink.core.security.UserSystemExitException
 
UserSystemExitException(String) - Constructor for exception org.apache.flink.core.security.UserSystemExitException
 
UserSystemExitException(String, Throwable) - Constructor for exception org.apache.flink.core.security.UserSystemExitException
 

V

validate() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.common.operators.Keys
 
validateLambdaType(Class<?>, Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks whether the given type has the generic parameters declared in the class definition.
validateMaxParallelism(int) - Static method in class org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateMaxParallelism(int, int) - Static method in class org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateMaxParallelism(int, boolean) - Static method in class org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateMaxParallelism(int, int, boolean) - Static method in class org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateMinAndPreferredResources(ResourceSpec, ResourceSpec) - Static method in class org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateParallelism(int) - Static method in class org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateParallelism(int, boolean) - Static method in class org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
validateResources(ResourceSpec) - Static method in class org.apache.flink.api.common.operators.util.OperatorValidationUtils
 
value() - Method in interface org.apache.flink.api.common.state.ValueState
Returns the current value for the state.
VALUE(Class<V>) - Static method in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Flink value types (classes that implement Value).
Value - Interface in org.apache.flink.types
Basic value interface for types that act as serializable values.
ValueComparator<T extends 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.common.BatchShuffleMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.CodeAnalysisMode
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.ExecutionConfig.ClosureCleanerLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.ExecutionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.InputDependencyConstraint
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.JobStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.RuntimeExecutionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.state.StateDescriptor.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.state.StateTtlConfig.StateVisibility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.state.StateTtlConfig.TtlTimeCharacteristic
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.state.StateTtlConfig.UpdateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot.OuterSchemaCompatibility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.connector.source.Boundedness
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.configuration.ClusterOptions.UncaughtExceptionHandleMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.configuration.ClusterOptions.UserSystemExitMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.configuration.description.TextElement.TextStyle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.configuration.JobManagerOptions.SchedulerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.configuration.MemorySize.MemoryUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.configuration.SchedulerExecutionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.core.fs.FileSystem.WriteMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.core.fs.FileSystemKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.core.io.InputStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.core.memory.ManagedMemoryUseCase.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.core.memory.ManagedMemoryUseCase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.types.parser.FieldParser.ParseErrorState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.types.RowKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.util.OperatingSystem
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.util.ProcessorArchitecture.MemoryAddressSize
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.util.ProcessorArchitecture
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.util.TernaryBoolean
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.flink.api.common.BatchShuffleMode
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.common.CodeAnalysisMode
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.ExecutionConfig.ClosureCleanerLevel
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.common.ExecutionMode
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.common.InputDependencyConstraint
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
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.common.JobStatus
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.common.operators.base.CrossOperatorBase.CrossHint
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.common.operators.base.JoinOperatorBase.JoinHint
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.common.operators.base.OuterJoinOperatorBase.OuterJoinType
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.common.operators.base.PartitionOperatorBase.PartitionMethod
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.common.operators.base.ReduceOperatorBase.CombineHint
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.common.operators.Order
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.common.RuntimeExecutionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.apache.flink.api.common.state.MapState
Returns all the values in the state.
values() - Static method in enum org.apache.flink.api.common.state.StateDescriptor.Type
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.common.state.StateTtlConfig.StateVisibility
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.common.state.StateTtlConfig.TtlTimeCharacteristic
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.common.state.StateTtlConfig.UpdateType
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.common.typeutils.CompositeTypeSerializerSnapshot.OuterSchemaCompatibility
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.connector.source.Boundedness
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.typeutils.runtime.KryoRegistration.SerializerDefinitionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.configuration.ClusterOptions.UncaughtExceptionHandleMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.configuration.ClusterOptions.UserSystemExitMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.configuration.description.TextElement.TextStyle
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.configuration.JobManagerOptions.SchedulerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.configuration.MemorySize.MemoryUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.configuration.SchedulerExecutionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.core.fs.FileSystem.WriteMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.core.fs.FileSystemKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.core.io.InputStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.core.memory.ManagedMemoryUseCase.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.core.memory.ManagedMemoryUseCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.flink.types.MapValue
 
values() - Static method in enum org.apache.flink.types.parser.FieldParser.ParseErrorState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.types.RowKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.util.OperatingSystem
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.util.ProcessorArchitecture.MemoryAddressSize
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.util.ProcessorArchitecture
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.util.TernaryBoolean
Returns an array containing the constants of this enum type, in the order they are declared.
ValueSerializer<T extends 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
 
ValueSerializer.ValueSerializerConfigSnapshot<T extends Value> - Class in org.apache.flink.api.java.typeutils.runtime
Deprecated.
ValueSerializer.ValueSerializerSnapshot<T extends Value> - Class in org.apache.flink.api.java.typeutils.runtime
ValueSerializer snapshot class.
ValueSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
Deprecated.
This empty nullary constructor is required for deserializing the configuration.
ValueSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
Deprecated.
 
ValueSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerSnapshot
 
ValueState<T> - Interface in org.apache.flink.api.common.state
State interface for partitioned single-value state.
ValueStateDescriptor<T> - Class in org.apache.flink.api.common.state
ValueStateDescriptor(String, Class<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Deprecated.
Use ValueStateDescriptor(String, Class) instead and manually manage the default value by checking whether the contents of the state is null.
ValueStateDescriptor(String, TypeInformation<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Deprecated.
Use ValueStateDescriptor(String, TypeInformation) instead and manually manage the default value by checking whether the contents of the state is null.
ValueStateDescriptor(String, TypeSerializer<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Deprecated.
Use ValueStateDescriptor(String, TypeSerializer) instead and manually manage the default value by checking whether the contents of the state is null.
ValueStateDescriptor(String, Class<T>) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and type
ValueStateDescriptor(String, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and type.
ValueStateDescriptor(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and the specific serializer.
ValueTypeInfo<T extends 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
 
Versioned - Interface in org.apache.flink.core.io
This interface is implemented by classes that provide a version number.
VersionedIOReadableWritable - Class in org.apache.flink.core.io
This is the abstract base class for IOReadableWritable which allows to differentiate between serialization versions.
VersionedIOReadableWritable() - Constructor for class org.apache.flink.core.io.VersionedIOReadableWritable
 
VersionMismatchException - Exception in org.apache.flink.core.io
This exception signals that incompatible versions have been found during serialization.
VersionMismatchException() - Constructor for exception org.apache.flink.core.io.VersionMismatchException
 
VersionMismatchException(String) - Constructor for exception org.apache.flink.core.io.VersionMismatchException
 
VersionMismatchException(String, Throwable) - Constructor for exception org.apache.flink.core.io.VersionMismatchException
 
VersionMismatchException(Throwable) - Constructor for exception org.apache.flink.core.io.VersionMismatchException
 
Visitable<T extends Visitable<T>> - Interface in org.apache.flink.util
This interface marks types as visitable during a traversal.
Visitor<T extends Visitable<T>> - Interface in org.apache.flink.util
A visitor encapsulates functionality that is applied to each node in the process of a traversal of a tree or DAG.
VOID - Static variable in class org.apache.flink.api.common.typeinfo.Types
Returns type information for Void.
VOID_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
VoidSerializer - Class in org.apache.flink.api.common.typeutils.base
Serializer for Void.
VoidSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
VoidSerializer.VoidSerializerSnapshot - Class in org.apache.flink.api.common.typeutils.base
Serializer configuration snapshot for compatibility and format evolution.
VoidSerializerSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.VoidSerializer.VoidSerializerSnapshot
 

W

waitForAll(Collection<? extends CompletableFuture<?>>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
Creates a future that is complete once all of the given futures have completed.
waitForCompletion() - Method in class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
 
WATCH_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.AkkaOptions
Deprecated.
Don't use this option anymore. It has no effect on Flink.
WATCH_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.AkkaOptions
Deprecated.
Don't use this option anymore. It has no effect on Flink.
WATCH_THRESHOLD - Static variable in class org.apache.flink.configuration.AkkaOptions
Deprecated.
Don't use this option anymore. It has no effect on Flink.
Watermark - Class in org.apache.flink.api.common.eventtime
Watermarks are the progress indicators in the data streams.
Watermark(long) - Constructor for class org.apache.flink.api.common.eventtime.Watermark
Creates a new watermark with the given timestamp in milliseconds.
WatermarkGenerator<T> - Interface in org.apache.flink.api.common.eventtime
The WatermarkGenerator generates watermarks either based on events or periodically (in a fixed interval).
WatermarkGeneratorSupplier<T> - Interface in org.apache.flink.api.common.eventtime
A supplier for WatermarkGenerators.
WatermarkGeneratorSupplier.Context - Interface in org.apache.flink.api.common.eventtime
WatermarkOutput - Interface in org.apache.flink.api.common.eventtime
An output for watermarks.
WatermarkOutputMultiplexer - Class in org.apache.flink.api.common.eventtime
A WatermarkOutputMultiplexer combines the watermark (and idleness) updates of multiple partitions/shards/splits into one combined watermark update and forwards it to an underlying WatermarkOutput.
WatermarkOutputMultiplexer(WatermarkOutput) - Constructor for class org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
Creates a new WatermarkOutputMultiplexer that emits combined updates to the given WatermarkOutput.
WatermarkStrategy<T> - Interface in org.apache.flink.api.common.eventtime
The WatermarkStrategy defines how to generate Watermarks in the stream sources.
WatermarksWithIdleness<T> - Class in org.apache.flink.api.common.eventtime
A WatermarkGenerator that adds idleness detection to another WatermarkGenerator.
WatermarksWithIdleness(WatermarkGenerator<T>, Duration) - Constructor for class org.apache.flink.api.common.eventtime.WatermarksWithIdleness
Creates a new WatermarksWithIdleness generator to the given generator idleness detection with the given timeout.
WebOptions - Class in org.apache.flink.configuration
Configuration options for the WebMonitorEndpoint.
whenCompleteAsyncIfNotDone(CompletableFuture<IN>, Executor, BiConsumer<? super IN, ? super Throwable>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
This function takes a CompletableFuture and a bi-consumer to call on completion of this future.
WhitespaceTokenizer() - Constructor for class org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
Creates a new tokenizer with an undefined internal state.
withContextClassLoader(ClassLoader, ThrowingRunnable<E>) - Static method in class org.apache.flink.util.LambdaUtil
Runs the given runnable with the given ClassLoader as the thread's context class loader.
withContextClassLoader(ClassLoader, SupplierWithException<R, E>) - Static method in class org.apache.flink.util.LambdaUtil
Runs the given runnable with the given ClassLoader as the thread's context class loader.
withDeprecatedKeys(String...) - Method in class org.apache.flink.configuration.ConfigOption
Creates a new config option, using this option's key and default value, and adding the given deprecated keys.
withDescription(String) - Method in class org.apache.flink.configuration.ConfigOption
Creates a new config option, using this option's key and default value, and adding the given description.
withDescription(Description) - Method in class org.apache.flink.configuration.ConfigOption
Creates a new config option, using this option's key and default value, and adding the given description.
withFallbackKeys(String...) - Method in class org.apache.flink.configuration.ConfigOption
Creates a new config option, using this option's key and default value, and adding the given fallback keys.
withIdleness(Duration) - Method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a new enriched WatermarkStrategy that also does idleness detection in the created WatermarkGenerator.
withNames(RowKind) - Static method in class org.apache.flink.types.Row
Creates a variable-length row in name-based field mode.
withNames() - Static method in class org.apache.flink.types.Row
Creates a variable-length row in name-based field mode.
withPositions(RowKind, int) - Static method in class org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode.
withPositions(int) - Static method in class org.apache.flink.types.Row
Creates a fixed-length row in position-based field mode.
withTimestampAssigner(TimestampAssignerSupplier<T>) - Method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a new WatermarkStrategy that wraps this strategy but instead uses the given TimestampAssigner (via a TimestampAssignerSupplier).
withTimestampAssigner(SerializableTimestampAssigner<T>) - Method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
Creates a new WatermarkStrategy that wraps this strategy but instead uses the given SerializableTimestampAssigner.
WorksetPlaceHolder(DeltaIterationBase<?, WT>, OperatorInformation<WT>) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
wrap(TypeSerializer<T>, boolean) - Static method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
This method wraps the originalSerializer with the NullableSerializer if not already wrapped.
wrap(InlineElement...) - Static method in class org.apache.flink.configuration.description.TextElement
Wraps a list of InlineElements into a single TextElement.
wrap(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Wraps the chunk of the underlying memory located between offset and offset + length in a NIO ByteBuffer.
wrap(byte[]) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Creates a new memory segment that targets the given heap memory region.
wrapAsByteBuffer() - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
wrapCopy(byte[], int, int) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Copies the given heap memory region and creates a new memory segment wrapping it.
wrapIfNecessary(Throwable) - Static method in exception org.apache.flink.util.WrappingRuntimeException
Ensures that any throwable can be thrown as a checked exception by potentially wrapping it.
wrapIfNullIsNotSupported(TypeSerializer<T>, boolean) - Static method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
This method tries to serialize null value with the originalSerializer and wraps it in case of NullPointerException, otherwise it returns the originalSerializer.
wrapInt(int) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Wraps the four bytes representing the given number with a MemorySegment.
wrapOffHeapMemory(ByteBuffer) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Creates a memory segment that wraps the off-heap memory backing the given ByteBuffer.
WrappingProxy<T> - Interface in org.apache.flink.util
Interface for objects that wrap another object and proxy (possibly a subset) of the methods of that object.
WrappingProxyCloseable<T extends Closeable> - Interface in org.apache.flink.core.fs
WrappingProxy for Closeable that is also closeable.
WrappingProxyUtil - Class in org.apache.flink.util
Utilities for working with WrappingProxy.
WrappingRuntimeException - Exception in org.apache.flink.util
A runtime exception that is explicitly used to wrap non-runtime exceptions.
WrappingRuntimeException(Throwable) - Constructor for exception org.apache.flink.util.WrappingRuntimeException
 
WrappingRuntimeException(String, Throwable) - Constructor for exception org.apache.flink.util.WrappingRuntimeException
 
wrapSafe(FSDataInputStream, SafetyNetCloseableRegistry) - Static method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
wrapSafe(FSDataInputStream, SafetyNetCloseableRegistry, String) - Static method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
wrapSafe(FSDataOutputStream, SafetyNetCloseableRegistry) - Static method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
wrapSafe(FSDataOutputStream, SafetyNetCloseableRegistry, String) - Static method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
WritableConfig - Interface in org.apache.flink.configuration
Write access to a configuration object.
write(IN) - Method in class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
 
write(byte[]) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
write(byte[], int, int) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
write(int) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
write(DataOutputView) - Method in class org.apache.flink.api.common.io.BlockInfo
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
Deprecated.
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
Deprecated.
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
Deprecated.
 
write(InputT, SinkWriter.Context) - Method in interface org.apache.flink.api.connector.sink.SinkWriter
Add an element to the writer.
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, T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
 
write(Kryo, Output, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroKryoSerializerClass
 
write(Kryo, Output, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
 
write(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
Deprecated.
 
write(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.configuration.Configuration
 
write(DataOutputView) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
write(int) - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
write(byte[]) - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
write(byte[], int, int) - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
write(int) - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
write(DataOutputView) - Method in class org.apache.flink.core.fs.Path
 
write(DataOutputView) - Method in interface org.apache.flink.core.io.IOReadableWritable
Writes the object's internal data to the given data output view.
write(DataOutputView) - Method in class org.apache.flink.core.io.PostVersionedIOReadableWritable
 
write(DataOutputView) - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
 
write(int) - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
write(byte[], int, int) - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
write(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
write(byte[]) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
write(byte[], int, int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
write(MemorySegment, int, int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
write(DataInputView, int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
write(DataInputView, int) - Method in interface org.apache.flink.core.memory.DataOutputView
Copies numBytes bytes from the source to this view.
write(DataInputView, int) - Method in class org.apache.flink.core.memory.DataOutputViewStreamWrapper
 
write(MemorySegment, int, int) - Method in interface org.apache.flink.core.memory.MemorySegmentWritable
Writes len bytes from memory segment segment starting at offset off, in order, to the output.
write(DataOutputView) - Method in class org.apache.flink.types.BooleanValue
 
write(DataOutputView) - Method in class org.apache.flink.types.ByteValue
 
write(DataOutputView) - Method in class org.apache.flink.types.CharValue
 
write(DataOutputView) - Method in class org.apache.flink.types.DoubleValue
 
write(DataOutputView) - Method in class org.apache.flink.types.FloatValue
 
write(DataOutputView) - Method in class org.apache.flink.types.IntValue
 
write(DataOutputView) - Method in class org.apache.flink.types.ListValue
 
write(DataOutputView) - Method in class org.apache.flink.types.LongValue
 
write(DataOutputView) - Method in class org.apache.flink.types.MapValue
 
write(DataOutputView) - Method in class org.apache.flink.types.NullValue
 
write(DataOutputView) - Method in class org.apache.flink.types.Record
 
write(DataOutputView) - Method in class org.apache.flink.types.ShortValue
 
write(DataOutputView) - Method in class org.apache.flink.types.StringValue
 
writeBigInteger(BigInteger, DataOutputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
writeBoolean(boolean) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeByte(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeBytes(String) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeChar(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeChars(String) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeCompletely(WritableByteChannel, ByteBuffer) - Static method in class org.apache.flink.util.FileUtils
 
writeDouble(double) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeFile(File, String, String) - Static method in class org.apache.flink.util.FileUtils
 
writeFileInfoToConfig(String, DistributedCache.DistributedCacheEntry, Configuration) - Static method in class org.apache.flink.api.common.cache.DistributedCache
 
writeFileUtf8(File, String) - Static method in class org.apache.flink.util.FileUtils
 
writeFloat(float) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeInt(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeIntUnsafe(int, int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeLong(long) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeMask(boolean[], DataOutputView) - Static method in class org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
writeMask(boolean[], int, DataOutputView) - Static method in class org.apache.flink.api.java.typeutils.runtime.MaskUtils
 
writeNestedSerializerSnapshots(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.NestedSerializersSnapshotDelegate
Writes the composite snapshot of all the contained serializers.
writeNullableString(String, DataOutputView) - Static method in class org.apache.flink.util.StringUtils
Writes a String to the given output.
writeObjectToConfig(Object, Configuration, String) - Static method in class org.apache.flink.util.InstantiationUtil
 
writeOptionalMap(DataOutputView, LinkedOptionalMap<K, V>, BiConsumerWithException<DataOutputView, K, IOException>, BiConsumerWithException<DataOutputView, V, IOException>) - Static method in class org.apache.flink.util.LinkedOptionalMapSerializer
 
writeOuterSnapshot(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
 
writeOuterSnapshot(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
Writes the outer snapshot, i.e.
writeOuterSnapshot(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
 
writeOuterSnapshot(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerSnapshot
 
writeParametersToConfig(Configuration) - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
 
writeParametersToConfig(Configuration) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
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(T) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
writeRecord(IT) - Method in interface org.apache.flink.api.common.io.OutputFormat
Adds a record to the output.
writeSerializer(DataOutputView, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Deprecated.
Writes a TypeSerializer to the provided data output view.
writeSerializersAndConfigsWithResilience(DataOutputView, List<Tuple2<TypeSerializer<?>, TypeSerializerSnapshot<?>>>) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Deprecated.
Write a list of serializers and their corresponding config snapshots to the provided data output view.
writeSerializerSnapshot(DataOutputView, TypeSerializerSnapshot<T>, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
Writes a TypeSerializerSnapshot to the provided data output view.
writeShort(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.BackwardsCompatibleSerializerSnapshot
 
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
 
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
Deprecated.
 
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
 
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
 
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
 
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Deprecated.
 
writeSnapshot(DataOutputView) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Writes the serializer snapshot to the provided DataOutputView.
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializerSnapshot
Deprecated.
 
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
 
writeSnapshot(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
 
writeString(CharSequence, DataOutput) - Static method in class org.apache.flink.types.StringValue
 
writeString(String, DataOutputView) - Static method in class org.apache.flink.util.StringUtils
Writes a String to the given output.
writeUTF(String) - Method in class org.apache.flink.core.memory.DataOutputSerializer
 
writeVersionAndSerialize(SimpleVersionedSerializer<T>, T, DataOutputView) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
Serializes the version and datum into a stream.
writeVersionAndSerialize(SimpleVersionedSerializer<T>, T) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
Serializes the version and datum into a byte array.
writeVersionedSnapshot(DataOutputView, TypeSerializerSnapshot<?>) - Static method in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
Writes the given snapshot to the out stream.
writeWatermark(Watermark) - Method in interface org.apache.flink.api.connector.sink.SinkWriter
Add a watermark to the writer.
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
writeWithKeyNormalization(BooleanValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
writeWithKeyNormalization(ByteValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
writeWithKeyNormalization(CharValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
writeWithKeyNormalization(DoubleValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
writeWithKeyNormalization(FloatValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
writeWithKeyNormalization(IntValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
writeWithKeyNormalization(LocalDate, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateComparator
 
writeWithKeyNormalization(LocalDateTime, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
 
writeWithKeyNormalization(LongValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
writeWithKeyNormalization(NullValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
writeWithKeyNormalization(ShortValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
writeWithKeyNormalization(StringValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Writes the record in such a fashion that all keys are normalizing and at the beginning of the serialized data.
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.NullAwareComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
writeWithKeyNormalization(Row, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
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
 

X

XORShiftRandom - Class in org.apache.flink.util
Implement a random number generator based on the XORShift algorithm discovered by George Marsaglia.
XORShiftRandom() - Constructor for class org.apache.flink.util.XORShiftRandom
 
XORShiftRandom(long) - Constructor for class org.apache.flink.util.XORShiftRandom
 
XZInputStreamFactory - Class in org.apache.flink.api.common.io.compression
Factory for XZ decompressors.
XZInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.XZInputStreamFactory
 

Y

YARN_APPLICATION_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of YarnConfigOptions#APPLICATION_ATTEMPTS.
YARN_APPLICATION_MASTER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Please use CONTAINERIZED_MASTER_ENV_PREFIX.
YARN_APPLICATION_MASTER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of YarnConfigOptions#APPLICATION_MASTER_PORT.
YARN_APPLICATION_TAGS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of YarnConfigOptions#APPLICATION_TAGS.
YARN_CONTAINER_START_COMMAND_TEMPLATE - Static variable in class org.apache.flink.configuration.ConfigConstants
Template for the YARN container start invocation.
YARN_HEAP_CUTOFF_MIN - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
YARN_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
YARN_HEARTBEAT_DELAY_SECONDS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of YarnConfigOptions#HEARTBEAT_DELAY_SECONDS.
YARN_MAX_FAILED_CONTAINERS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of YarnConfigOptions#MAX_FAILED_CONTAINERS.
YARN_PROPERTIES_FILE_LOCATION - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of YarnConfigOptions#PROPERTIES_FILE_LOCATION.
YARN_REALLOCATE_FAILED_CONTAINERS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore
YARN_TASK_MANAGER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Please use CONTAINERIZED_TASK_MANAGER_ENV_PREFIX.
YARN_VCORES - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of YarnConfigOptions#VCORES.
yield() - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
This methods starts running the command at the head of the mailbox and is intended to be used by the mailbox thread to yield from a currently ongoing action to another command.

Z

ZERO - Static variable in class org.apache.flink.api.common.operators.ResourceSpec
A ResourceSpec that indicates zero amount of resources.
ZERO - Static variable in class org.apache.flink.configuration.MemorySize
 
ZOOKEEPER_CHECKPOINT_COUNTER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_CHECKPOINTS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_CLIENT_ACL - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of ConfigConstants.HA_ZOOKEEPER_DIR_KEY.
ZOOKEEPER_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_LATCH_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_LEADER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_MESOS_WORKERS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
has no effect
ZOOKEEPER_NAMESPACE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_QUORUM_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_RECOVERY_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_RUNNING_JOB_REGISTRY_PATH - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_SASL_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_SASL_DISABLE - Static variable in class org.apache.flink.configuration.SecurityOptions
 
ZOOKEEPER_SASL_LOGIN_CONTEXT_NAME - Static variable in class org.apache.flink.configuration.SecurityOptions
 
ZOOKEEPER_SASL_SERVICE_NAME - Static variable in class org.apache.flink.configuration.ConfigConstants
ZOOKEEPER_SASL_SERVICE_NAME - Static variable in class org.apache.flink.configuration.SecurityOptions
 
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_TOLERATE_SUSPENDED_CONNECTIONS - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZStandardInputStreamFactory - Class in org.apache.flink.api.common.io.compression
Factory for ZStandard decompressors.
ZStandardInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.ZStandardInputStreamFactory
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
Skip navigation links

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