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 _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AARCH64 - org.apache.flink.util.ProcessorArchitecture
-
The 64 bit ARM processor architecture.
- 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.
- AbstractAutoCloseableRegistry<R extends AutoCloseable,C extends R,T,E extends Exception> - 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. - AbstractAutoCloseableRegistry(Map<R, T>) - Constructor for class org.apache.flink.util.AbstractAutoCloseableRegistry
- 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() - Constructor for class org.apache.flink.util.AbstractID
-
Constructs a new random ID from a uniform distribution.
- 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.
- AbstractParameterTool - Class in org.apache.flink.util
-
This class provides common utility methods of
ParameterTool
andMultipleParameterTool
. - AbstractParameterTool() - Constructor for class org.apache.flink.util.AbstractParameterTool
- 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(JobInfo, 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 org.apache.flink.api.common.functions.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(String, K, V) - Method in interface org.apache.flink.util.LinkedOptionalMap.ConsumerWithException
- 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(Visitor<T>) - Method in interface org.apache.flink.util.Visitable
-
Contains the logic to invoke the visitor and continue the traversal.
- accept(T) - Method in interface org.apache.flink.util.concurrent.FutureConsumerWithException
- 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
- acceptWithoutTimeout(ServerSocket) - Static method in class org.apache.flink.util.NetUtils
-
Calls
ServerSocket.accept()
on the provided server socket, suppressing any thrownSocketTimeoutException
s. - 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() - Method in class org.apache.flink.api.connector.source.util.ratelimit.GatedRateLimiter
- acquire() - Method in class org.apache.flink.api.connector.source.util.ratelimit.GuavaRateLimiter
- acquire() - Method in class org.apache.flink.api.connector.source.util.ratelimit.NoOpRateLimiter
- acquire() - Method in interface org.apache.flink.api.connector.source.util.ratelimit.RateLimiter
-
Returns a future that is completed once another event would not exceed the rate limit.
- 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
- Adaptive - org.apache.flink.configuration.JobManagerOptions.SchedulerType
- ADAPTIVE_AUTO_PARALLELISM_AVG_DATA_VOLUME_PER_TASK - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- ADAPTIVE_AUTO_PARALLELISM_DEFAULT_SOURCE_PARALLELISM - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- ADAPTIVE_AUTO_PARALLELISM_ENABLED - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- ADAPTIVE_AUTO_PARALLELISM_MAX_PARALLELISM - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- ADAPTIVE_AUTO_PARALLELISM_MIN_PARALLELISM - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- AdaptiveBatch - org.apache.flink.configuration.JobManagerOptions.SchedulerType
- add(double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
- add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
- add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
- add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
- add(int) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
- add(int) - Method in class org.apache.flink.api.common.accumulators.IntCounter
- add(int) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
- add(int) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
- add(int, V) - Method in class org.apache.flink.types.ListValue
- add(long) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
- add(long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
- add(long) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
- add(long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
- add(IN, ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
- add(Double) - 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.DoubleMaximum
-
Consider using
DoubleMaximum.add(double)
instead for primitive double values - add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
-
Consider using
DoubleMinimum.add(double)
instead for primitive double values - 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(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
-
Consider using
IntMaximum.add(int)
instead for primitive integer values - add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
-
Consider using
IntMinimum.add(int)
instead for primitive integer values - 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.LongMaximum
-
Consider using
LongMaximum.add(long)
instead for primitive long values - add(Long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
-
Consider using
LongMinimum.add(long)
instead for primitive long values - add(Iterator<T>) - Method in class org.apache.flink.util.UnionIterator
- add(BlockElement) - Method in class org.apache.flink.configuration.description.Description.DescriptionBuilder
-
Block of description add.
- add(Utils.ChecksumHashCode) - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- add(T) - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
- 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(V) - Method in interface org.apache.flink.api.common.accumulators.Accumulator
- add(V) - Method in class org.apache.flink.types.ListValue
- 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(int, Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
- addAll(Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
- addAll(AggregatorRegistry) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
- addAll(Configuration) - Method in class org.apache.flink.configuration.Configuration
- addAll(Configuration) - 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.Configuration
-
Adds all entries from the given configuration into this configuration.
- addAll(Configuration, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
- addAll(Configuration, String) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
- addAllToProperties(Properties) - Method in class org.apache.flink.configuration.Configuration
-
Adds all entries in this
Configuration
to the givenProperties
. - 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(SerializerConfig, Class<?>) - Method in class org.apache.flink.api.java.typeutils.AvroUtils
-
Loads the utility class from
flink-avro
and adds Avro-specific serializers. - 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<?>, Class<? extends Serializer<?>>) - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, T) - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Adds a new Kryo default serializer to the Runtime.
- addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
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.
- addEntropy(FileSystem, Path) - Static method in class org.apache.flink.core.fs.EntropyInjector
-
Handles entropy injection across regular and entropy-aware file systems.
- 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(int...) - Method in class org.apache.flink.api.common.operators.util.FieldSet
- addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
- addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
- 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
- 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).
- 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.
- 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.IteratorSourceReaderBase
- addSplits(List<SplitT>) - Method in interface org.apache.flink.api.connector.source.SourceReader
-
Adds a list of splits for this reader to read.
- addSplits(List<SplitT>) - Method in class org.apache.flink.api.connector.source.util.ratelimit.RateLimitedSourceReader
- 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 splits back to the split enumerator.
- addToDefaults(String, String) - Method in class org.apache.flink.util.AbstractParameterTool
- addUniqueField(int) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Adds a field as having only unique values.
- addUniqueField(FieldSet) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Adds a FieldSet to be unique
- addUniqueFields(Set<FieldSet>) - Method in class org.apache.flink.api.common.operators.CompilerHints
-
Adds multiple FieldSets to be unique
- addURL(URL) - Method in class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- addURL(URL) - Method in class org.apache.flink.util.MutableURLClassLoader
- 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(double) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
-
Adds the given value to the current aggregate.
- 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(DoubleValue) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
- aggregate(LongValue) - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
- aggregate(LongValue) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
- aggregate(T) - Method in interface org.apache.flink.api.common.aggregators.Aggregator
-
Aggregates the given element.
- AGGREGATING - org.apache.flink.api.common.state.StateDescriptor.Type
- 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
Aggregator
s. - 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.
- AlgorithmOptions - Class in org.apache.flink.configuration
-
Configuration parameters for join/sort algorithms.
- AlgorithmOptions() - Constructor for class org.apache.flink.configuration.AlgorithmOptions
- ALIGNED_CHECKPOINT_TIMEOUT - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- ALL_EXCHANGES_BLOCKING - org.apache.flink.api.common.BatchShuffleMode
-
Upstream and downstream tasks run subsequently.
- ALL_EXCHANGES_HYBRID_FULL - org.apache.flink.api.common.BatchShuffleMode
-
Downstream can start running anytime, as long as the upstream has started.
- ALL_EXCHANGES_HYBRID_SELECTIVE - org.apache.flink.api.common.BatchShuffleMode
-
Downstream can start running anytime, as long as the upstream has started.
- ALL_EXCHANGES_PIPELINED - org.apache.flink.api.common.BatchShuffleMode
-
Upstream and downstream tasks run simultaneously.
- ALL_PRODUCERS_FINISHED - org.apache.flink.configuration.JobManagerOptions.HybridPartitionDataConsumeConstraint
- 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.
- ALLOW_UNALIGNED_SOURCE_SPLITS - Static variable in class org.apache.flink.configuration.PipelineOptions
-
Will be removed in future Flink releases.
- ALLOWED_FALLBACK_FILESYSTEMS - Static variable in class org.apache.flink.configuration.CoreOptions
- ALWAYS - org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
-
A directory is always created, regardless of number of write tasks.
- 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
- AMD64 - org.apache.flink.util.ProcessorArchitecture
-
The AMD 64 bit processor architecture.
- analyzePojo(Type, List<Type>, TypeInformation<IN1>, TypeInformation<IN2>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractor
- ANY - org.apache.flink.api.common.operators.Order
-
Indicates an order without a direction.
- 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
- 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(File) - Method in class org.apache.flink.core.fs.RefCountedTmpFileCreator
-
Gets the next temp file and stream to temp file.
- applyRegistrations(Kryo, Collection<KryoRegistration>, int) - 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.
- APPROXIMATE_LOCAL_RECOVERY - Static variable in class org.apache.flink.configuration.StateRecoveryOptions
-
Access to this option is officially only supported via
org.apache.flink.runtime.jobgraph.CheckpointConfig#enableApproximateLocalRecovery(boolean)
, but there is no good reason behind this. - 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(String, int, int, boolean, long, Map<String, String>) - Constructor for class org.apache.flink.api.common.ArchivedExecutionConfig
- ArchivedExecutionConfig(ExecutionConfig) - 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
- ARMv7 - org.apache.flink.util.ProcessorArchitecture
-
The ARM 32 bit processor architecture.
- 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 andnull
. - 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
- ascending - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
- ASCENDING - org.apache.flink.api.common.operators.Order
-
Indicates an ascending order.
- 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.
- asContextData(JobID) - Static method in class org.apache.flink.util.MdcUtils
- ASK_TIMEOUT_DURATION - Static variable in class org.apache.flink.configuration.RpcOptions
-
Timeout for Pekko 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. - asSerializationSchemaInitializationContext() - Method in interface org.apache.flink.api.connector.sink2.WriterInitContext
-
Provides a view on this context as a
SerializationSchema.InitializationContext
. - 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_INFLIGHT_RECORDS_LIMIT - Static variable in class org.apache.flink.configuration.ExecutionOptions
-
The max limit of in-flight records number in async state execution, 'in-flight' refers to the records that have entered the operator but have not yet been processed and emitted to the downstream.
- ASYNC_OPERATION_STORE_DURATION - Static variable in class org.apache.flink.configuration.RestOptions
- ASYNC_STATE_BUFFER_SIZE - Static variable in class org.apache.flink.configuration.ExecutionOptions
-
The size of buffer under async state execution.
- ASYNC_STATE_BUFFER_TIMEOUT - Static variable in class org.apache.flink.configuration.ExecutionOptions
-
The timeout of buffer triggering in milliseconds.
- AT_LEAST_ONCE - org.apache.flink.core.execution.CheckpointingMode
-
Sets the checkpointing mode to "at least once".
- 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
- Attribute - Class in org.apache.flink.api.common.attribute
-
Attribute
contains the information about the process logic of a process function. - Attribute.Builder - Class in org.apache.flink.api.common.attribute
- AUTO_GENERATE_UIDS - 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.
- AutoCloseableRegistry - Class in org.apache.flink.core.fs
-
This class allows to register instances of
AutoCloseable
, which are all closed if this registry is closed. - AutoCloseableRegistry() - Constructor for class org.apache.flink.core.fs.AutoCloseableRegistry
- availability - Variable in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
-
The availability future.
- 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
- AVRO_SPECIFIC_RECORD_BASE_CLASS - Static variable in class org.apache.flink.api.java.typeutils.AvroUtils
- 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
- BackPressuringExecutor - Class in org.apache.flink.core.fs
-
An executor decorator that allows only a certain number of concurrent executions.
- BackPressuringExecutor(Executor, int) - Constructor for class org.apache.flink.core.fs.BackPressuringExecutor
- 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
- BasicTypeDescriptorImpl<T> - Class in org.apache.flink.api.common.typeinfo.descriptor
-
Implementation of
TypeDescriptor
to createBasicTypeInfo
. - BasicTypeDescriptorImpl(TypeDescriptor<T>) - Constructor for class org.apache.flink.api.common.typeinfo.descriptor.BasicTypeDescriptorImpl
- 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
- BatchExecutionOptions - Class in org.apache.flink.configuration
-
Configuration options for the batch job execution.
- 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. - 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).
- 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_SLOW_NODE_DURATION - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- 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. some text, linebreak or a list.
- 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
- 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
andBoolean
. - BOOLEAN_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
- BOOLEAN_INVALID - org.apache.flink.types.parser.FieldParser.ParseErrorState
-
Invalid Boolean value *
- 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
- borrowed(V) - Static method in class org.apache.flink.util.Reference
- BOUNDED - org.apache.flink.api.connector.source.Boundedness
-
A BOUNDED stream is a stream with finite records.
- 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.
- BROADCAST_HASH_FIRST - org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
-
Hint that the first join input is much smaller than the second.
- BROADCAST_HASH_SECOND - org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
-
Hint that the second join input is much smaller than the first.
- broadcastInputs - Variable in class org.apache.flink.api.common.operators.AbstractUdfOperator
-
The extra inputs which parameterize the user function.
- 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_SIZE - Static variable in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- BUFFER_TIMEOUT - Static variable in class org.apache.flink.configuration.ExecutionOptions
- BUFFER_TIMEOUT_ENABLED - 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.attribute.Attribute.Builder
- 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.configuration.description.Description.DescriptionBuilder
-
Creates description representation.
- build() - Method in class org.apache.flink.util.concurrent.ExecutorThreadFactory.Builder
- builder() - Static method in class org.apache.flink.configuration.description.Description
- Builder() - Constructor for class org.apache.flink.api.common.attribute.Attribute.Builder
- 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
andByte
. - 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
- ByteBufferReadable - Interface in org.apache.flink.core.fs
-
An interface mark that a filesystem supports to read bytes from a
ByteBuffer
and its given position. - ByteBufferReadableClosingFSDataInputStream - Class in org.apache.flink.core.fs
-
A
ClosingFSDataInputStream
which isByteBufferReadable
. - ByteBufferReadableClosingFSDataInputStream(FSDataInputStream, SafetyNetCloseableRegistry, String) - Constructor for class org.apache.flink.core.fs.ByteBufferReadableClosingFSDataInputStream
- 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[]) - 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[], 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.
- 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
- CACHE_CHECKPOINT_STATISTICS_SIZE - Static variable in class org.apache.flink.configuration.RestOptions
-
Maximum number of entries in the checkpoint statistics cache.
- CACHE_CHECKPOINT_STATISTICS_TIMEOUT - Static variable in class org.apache.flink.configuration.RestOptions
-
Duration from write, after which cached checkpoints statistics are cleaned up.
- 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.
- CacheSupportedPipelineExecutor - Interface in org.apache.flink.core.execution
-
The pipeline executor that support caching intermediate dataset.
- 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.
- callbackFinished() - Method in class org.apache.flink.core.state.StateFutureImpl
-
Will be triggered when a callback finishes processing.
- callbackRegistered() - Method in class org.apache.flink.core.state.StateFutureImpl
-
Will be triggered when a callback is registered.
- callbackRunner - Variable in class org.apache.flink.core.state.StateFutureImpl
-
The callback runner.
- 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 canceled from the web-frontend.
- CANCELED - org.apache.flink.api.common.JobStatus
-
Job has been cancelled.
- CANCELLING - org.apache.flink.api.common.JobStatus
-
Job is being cancelled.
- canCopyPaths(Path, Path) - Method in interface org.apache.flink.core.fs.IFileSystem
-
Tells if this
FileSystem
supports an optimised way to directly copy between given paths. - canCopyPaths(Path, Path) - Method in interface org.apache.flink.core.fs.PathsCopyingFileSystem
- canCopyPaths(Path, Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
- 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
- CANONICAL - org.apache.flink.core.execution.SavepointFormatType
-
A canonical, common for all state backends format.
- 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.RpcOptions
-
Flag whether to capture call stacks for RPC ask calls.
- CASCADING - org.apache.flink.configuration.PipelineOptions.VertexDescriptionMode
-
Organizes the description in a single line cascading mode, which is similar to name.
- CHAR - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for both a primitive
char
andCharacter
. - 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_INTERVAL - Static variable in class org.apache.flink.configuration.SlowTaskDetectorOptions
- 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 tofalse
). - 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 tofalse
). - 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 tofalse
). - checkCompletedNormally(CompletableFuture<?>) - Static method in class org.apache.flink.util.Preconditions
-
Ensures that future has completed normally.
- 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.
- checkedSubTypeCast(Collection<? super T>, Class<T>) - Static method in class org.apache.flink.util.CollectionUtil
-
Casts the given collection to a subtype.
- 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
supportsnull
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_ID_OF_IGNORED_IN_FLIGHT_DATA - Static variable in class org.apache.flink.configuration.StateRecoveryOptions
- 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
InputFormat
s that allow checkpointing/restoring their state. - CHECKPOINTING_CONSISTENCY_MODE - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- CHECKPOINTING_INTERVAL - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- CHECKPOINTING_INTERVAL_DURING_BACKLOG - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- CHECKPOINTING_TIMEOUT - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- CheckpointingMode - Enum in org.apache.flink.core.execution
-
The checkpointing mode defines what consistency guarantees the system gives in the presence of failures.
- 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_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.WebOptions
-
Config parameter defining the number of checkpoints to remember for recent history.
- CheckpointType - Enum in org.apache.flink.core.execution
-
Describes the type in which a checkpoint should be taken.
- 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 tofalse
). - 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 tofalse
). - 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 tofalse
). - 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.
- ChecksumHashCode() - Constructor for class org.apache.flink.util.Utils.ChecksumHashCode
- ChecksumHashCode(long, long) - Constructor for class org.apache.flink.util.Utils.ChecksumHashCode
- ChecksumHashCodeHelper(String) - Constructor for class org.apache.flink.util.Utils.ChecksumHashCodeHelper
- CHILD_FIRST - org.apache.flink.util.FlinkUserCodeClassLoaders.ResolveOrder
- childFirst(URL[], ClassLoader, String[], Consumer<Throwable>, boolean) - Static method in class org.apache.flink.util.FlinkUserCodeClassLoaders
- 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
- ChillSerializerRegistrar - Interface in org.apache.flink.api.java.typeutils.runtime.kryo
-
Interface for flink-core to interact with the FlinkChillPackageRegistrar in flink-streaming-java.
- CLAIM - org.apache.flink.core.execution.RecoveryClaimMode
- CLASS - org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
- 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
- ClassLoaderUtil - Class in org.apache.flink.util
-
Utilities for information with respect to class loaders, specifically class loaders for the dynamic loading of user defined classes.
- classLoadingExceptionHandler - Variable in class org.apache.flink.util.FlinkUserCodeClassLoader
- 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.
- CLEANER_PARALLEL_MODE - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- 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).
- CLEANUP_STRATEGY - Static variable in class org.apache.flink.configuration.CleanupOptions
- CLEANUP_STRATEGY_EXPONENTIAL_DELAY_INITIAL_BACKOFF - Static variable in class org.apache.flink.configuration.CleanupOptions
- CLEANUP_STRATEGY_EXPONENTIAL_DELAY_MAX_ATTEMPTS - Static variable in class org.apache.flink.configuration.CleanupOptions
- CLEANUP_STRATEGY_EXPONENTIAL_DELAY_MAX_BACKOFF - Static variable in class org.apache.flink.configuration.CleanupOptions
- CLEANUP_STRATEGY_FIXED_DELAY_ATTEMPTS - Static variable in class org.apache.flink.configuration.CleanupOptions
- CLEANUP_STRATEGY_FIXED_DELAY_DELAY - Static variable in class org.apache.flink.configuration.CleanupOptions
- 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.
- cleanupInRocksdbCompactFilter(long, Duration) - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
-
Cleanup expired state while Rocksdb compaction is running.
- CleanupOptions - Class in org.apache.flink.configuration
-
ConfigOption
collection for the configuration of repeatable cleanup of resource cleanup after a job reached a globally-terminated state. - CleanupOptions() - Constructor for class org.apache.flink.configuration.CleanupOptions
- 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
-
OutputFormat
s may implement this interface to run a cleanup hook when the execution is not successful. - 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
-
Deprecated.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.RpcOptions
- CLIENT_SOCKET_WORKER_POOL_SIZE_MAX - Static variable in class org.apache.flink.configuration.RpcOptions
- CLIENT_SOCKET_WORKER_POOL_SIZE_MIN - Static variable in class org.apache.flink.configuration.RpcOptions
- CLIENT_TCP_KEEP_COUNT - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
- CLIENT_TCP_KEEP_IDLE_SECONDS - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
- CLIENT_TCP_KEEP_INTERVAL_SECONDS - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
- 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() - Method in class org.apache.flink.util.AbstractParameterTool
- clone() - Method in class org.apache.flink.util.MultipleParameterTool
- clone() - Method in class org.apache.flink.util.ParameterTool
- clone() - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- 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.
- cloneUnchecked(T) - Static method in class org.apache.flink.util.InstantiationUtil
-
Unchecked equivalent of
InstantiationUtil.clone(Serializable)
. - 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.functions.util.PrintSinkOutputWriter
- close() - Method in class org.apache.flink.api.common.functions.WrappingFunction
- 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 class org.apache.flink.api.common.io.OutputFormatBase
-
Close the format waiting for pending writes and reports errors.
- 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.IteratorSourceReaderBase
- 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.api.connector.source.util.ratelimit.RateLimitedSourceReader
- 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.local.LocalRecoverableFsDataOutputStream
- close() - Method in class org.apache.flink.core.fs.OffsetAwareOutputStream
- close() - Method in class org.apache.flink.core.fs.RecoverableFsDataOutputStream
-
Closes this stream.
- close() - Method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- 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.AbstractAutoCloseableRegistry
- 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 class org.apache.flink.util.CloseShieldOutputStream
- close() - Method in interface org.apache.flink.util.Collector
-
Closes the collector.
- close() - Method in class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- close() - Method in interface org.apache.flink.util.MdcUtils.MdcCloseable
- close() - Method in class org.apache.flink.util.NetUtils.Port
- 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
- close() - Method in class org.apache.flink.util.Utils.ChecksumHashCodeHelper
- close() - Method in class org.apache.flink.util.Utils.CollectHelper
- close() - Method in class org.apache.flink.util.Utils.CountHelper
- 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 alsoAutoCloseable
. - CloseableIterator.IteratorAdapter<E> - Class in org.apache.flink.util
-
Adapter from
Iterator
toCloseableIterator
. - CloseableRegistry - Class in org.apache.flink.core.fs
-
ICloseableRegistry
implementation. - CloseableRegistry() - Constructor for class org.apache.flink.core.fs.CloseableRegistry
- closeableToRef - Variable in class org.apache.flink.util.AbstractAutoCloseableRegistry
-
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. - closeAll(Iterable<? extends AutoCloseable>, Class<T>) - 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.CommitterFromPersistRecoverableFsDataOutputStream
- 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.
- CloseShieldOutputStream - Class in org.apache.flink.util
-
A proxy output stream that prevents the underlying output stream from being closed.
- CloseShieldOutputStream(OutputStream) - Constructor for class org.apache.flink.util.CloseShieldOutputStream
- 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
forFSDataInputStream
that is used to implement a safety net against unclosed streams. - ClosingFSDataInputStream(FSDataInputStream, SafetyNetCloseableRegistry, String) - Constructor for class org.apache.flink.core.fs.ClosingFSDataInputStream
- ClosingFSDataOutputStream - Class in org.apache.flink.core.fs
-
This class is a
WrappingProxy
forFSDataOutputStream
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.
- CODE - org.apache.flink.configuration.description.TextElement.TextStyle
- 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(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
- CoGroupOperatorBase(UserCodeWrapper<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(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(UserCodeWrapper<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) - Method in interface org.apache.flink.api.connector.source.SourceOutput
-
Emit a record without a timestamp.
- collect(T) - Method in interface org.apache.flink.util.Collector
-
Emits a record.
- collect(T, long) - Method in interface org.apache.flink.api.connector.source.ReaderOutput
-
Emit a record with a timestamp.
- collect(T, long) - Method in interface org.apache.flink.api.connector.source.SourceOutput
-
Emit a record with a timestamp.
- COLLECT_PORT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
The default port that
CollectSinkFunction$ServerThread
is using. - CollectHelper(String, TypeSerializer<T>) - Constructor for class org.apache.flink.util.Utils.CollectHelper
- 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
- 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
- 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.
- combineAll(Collection<? extends StateFuture<? extends T>>) - Static method in class org.apache.flink.core.state.StateFutureUtils
-
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() - Method in interface org.apache.flink.core.fs.RecoverableFsDataOutputStream.Committer
-
Commits the file, making it visible.
- commit(Collection<Committer.CommitRequest<CommT>>) - Method in interface org.apache.flink.api.connector.sink2.Committer
-
Commit the given list of
Committer
. - 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.sink2
-
The
Committer
is responsible for committing the data staged by theCommittingSinkWriter
in the second step of a two-phase commit protocol. - Committer.CommitRequest<CommT> - Interface in org.apache.flink.api.connector.sink2
-
A request to commit a specific committable.
- CommitterFromPersistRecoverableFsDataOutputStream<RESUME_RECOVERABLE extends RecoverableWriter.ResumeRecoverable> - Class in org.apache.flink.core.fs
-
RecoverableFsDataOutputStream
with fixed implementation ofCommitterFromPersistRecoverableFsDataOutputStream.closeForCommit()
that is based on usingCommitterFromPersistRecoverableFsDataOutputStream.persist()
to ensure durability and creates theRecoverableFsDataOutputStream.Committer
from the correspondingRecoverableWriter.ResumeRecoverable
. - CommitterFromPersistRecoverableFsDataOutputStream() - Constructor for class org.apache.flink.core.fs.CommitterFromPersistRecoverableFsDataOutputStream
- CommitterInitContext - Interface in org.apache.flink.api.connector.sink2
-
The interface exposes some runtime info for creating a
Committer
. - CommittingSinkWriter<InputT,CommittableT> - Interface in org.apache.flink.api.connector.sink2
-
A
SinkWriter
that performs the first part of a two-phase commit protocol. - 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(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(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.
- 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(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(Row, Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
- 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.base.BasicTypeComparator
- 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(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
- 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
- compareRows(List<Row>, List<Row>, boolean) - Static method in class org.apache.flink.types.RowUtils
- 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(Object) - Method in class org.apache.flink.core.fs.Path
- compareTo(Delayed) - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
- compareTo(Resource) - Method in class org.apache.flink.api.common.resources.Resource
- compareTo(BlockLocation) - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
- 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
- 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<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<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<Row>) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
- 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(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<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(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<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
- compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
- compareToReference(T) - Method in class org.apache.flink.api.common.typeutils.SameTypePairComparator
- compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
- compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
- COMPATIBLE_AFTER_MIGRATION - org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot.OuterSchemaCompatibility
- COMPATIBLE_AS_IS - org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot.OuterSchemaCompatibility
- 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. reading it with the old serializer and then writing it again with the new serializer.
- 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 - Variable in class org.apache.flink.api.common.operators.Operator
- 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
- complementBlockInfo(BlockInfo) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
- complete(T) - Method in class org.apache.flink.core.state.CompletedStateFuture
- complete(T) - Method in interface org.apache.flink.core.state.InternalStateFuture
-
Complete this future.
- complete(T) - Method in class org.apache.flink.core.state.StateFutureImpl
- 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
. - completedFuture(V) - Static method in class org.apache.flink.core.state.StateFutureUtils
-
Returns a completed future that does nothing and return provided result.
- CompletedStateFuture<T> - Class in org.apache.flink.core.state
-
A
StateFuture
that has already been completed when it is created. - completedVoidFuture() - Static method in class org.apache.flink.core.state.StateFutureUtils
-
Returns a completed future that does nothing and return null.
- completedVoidFuture() - Static method in class org.apache.flink.util.concurrent.FutureUtils
-
Returns a completed future of type
Void
. - completeExceptionally(String, Throwable) - Method in class org.apache.flink.core.state.CompletedStateFuture
- completeExceptionally(String, Throwable) - Method in interface org.apache.flink.core.state.InternalStateFuture
-
Fail this future and pass the given exception to the runtime.
- completeExceptionally(String, Throwable) - Method in class org.apache.flink.core.state.StateFutureImpl
- 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[], Map<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.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
- 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() - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
-
Constructor to be used for read instantiation.
- CompositeTypeSerializerSnapshot(Class<? extends TypeSerializer>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
-
Deprecated.correspondingSerializerClass is not used to resolve and cast after FLIP-263, please use
CompositeTypeSerializerSnapshot()
instead. - 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
-
Utilities for the
CompositeTypeSerializerSnapshot
. - 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. - CompressionUtils - Class in org.apache.flink.util
-
Utils used to extract compressed files.
- CompressionUtils() - Constructor for class org.apache.flink.util.CompressionUtils
- 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.
- CONFIG_PREFIX - Static variable in interface org.apache.flink.core.security.token.DelegationTokenProvider
-
Config prefix of providers.
- CONFIG_PREFIX - Static variable in interface org.apache.flink.core.security.token.DelegationTokenReceiver
-
Config prefix of receivers.
- 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 aConfigOption
. - ConfigOptions.ListConfigOptionBuilder<E> - Class in org.apache.flink.configuration
-
Builder for
ConfigOption
of list of typeConfigOptions.ListConfigOptionBuilder
. - 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. - 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
- ConfigurationFileMigrationUtils - Class in org.apache.flink.configuration
-
Utility class for migrating legacy Flink configuration file
flink-conf.yaml
to the new format starting from Flink 2.0. - ConfigurationFileMigrationUtils() - Constructor for class org.apache.flink.configuration.ConfigurationFileMigrationUtils
- ConfigurationUtils - Class in org.apache.flink.configuration
-
Utility class for
Configuration
related helper functions. - 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.
- configure(Configuration) - Method in class org.apache.flink.util.Utils.ChecksumHashCodeHelper
- configure(Configuration) - Method in class org.apache.flink.util.Utils.CollectHelper
- configure(Configuration) - Method in class org.apache.flink.util.Utils.CountHelper
- 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(ReadableConfig, ClassLoader) - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Sets all relevant options contained in the
ReadableConfig
such as e.g. - configure(ReadableConfig, ClassLoader) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Sets all relevant options contained in the
ReadableConfig
such as e.g. - CONFIGURED - org.apache.flink.core.execution.CheckpointType
- 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_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(TypeSerializerSnapshot<?>[], 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_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.ResourceManagerOptions
-
Similar to the {@see 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(Object) - Method in class org.apache.flink.types.ListValue
- 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
- containsAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
- containsKey(Object) - Method in class org.apache.flink.types.MapValue
- 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
- containsValue(Object) - Method in class org.apache.flink.types.MapValue
- CONTINUOUS_UNBOUNDED - org.apache.flink.api.connector.source.Boundedness
-
A CONTINUOUS_UNBOUNDED stream is a stream with infinite records.
- ConvergenceCriterion<T extends Value> - Interface in org.apache.flink.api.common.aggregators
-
Used to check for convergence.
- convert(E) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
- convert(E) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
- convertAndDumpYamlFromFlatMap(Map<String, Object>) - Static method in class org.apache.flink.configuration.YamlParserUtils
-
Converts a flat map into a nested map structure and outputs the result as a list of YAML-formatted strings.
- convertBoxedJavaType(Object) - Static method in class org.apache.flink.types.JavaToValueConverter
- convertConfigToWritableLines(Configuration, boolean) - Static method in class org.apache.flink.configuration.ConfigurationUtils
-
Converts the provided configuration data into a format suitable for writing to a file, based on the
flattenYaml
flag and thestandardYaml
attribute of the configuration object. - convertToEnum(Object, Class<E>) - Static method in class org.apache.flink.configuration.ConfigurationUtils
- convertToList(Object, Class<?>) - Static method in class org.apache.flink.configuration.ConfigurationUtils
- convertToObject(String, Class<T>) - Static method in class org.apache.flink.configuration.YamlParserUtils
- 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() - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
- copy() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
- copy() - Method in class org.apache.flink.types.BooleanValue
- copy() - Method in class org.apache.flink.types.ByteValue
- copy() - 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() - Method in class org.apache.flink.types.DoubleValue
- copy() - Method in class org.apache.flink.types.FloatValue
- copy() - Method in class org.apache.flink.types.IntValue
- copy() - Method in class org.apache.flink.types.LongValue
- copy() - Method in class org.apache.flink.types.NullValue
- copy() - Method in class org.apache.flink.types.Record
- copy() - Method in class org.apache.flink.types.ShortValue
- copy() - Method in class org.apache.flink.types.StringValue
- copy() - Method in class org.apache.flink.util.ChildFirstClassLoader
- copy() - Method in class org.apache.flink.util.FlinkUserCodeClassLoaders.ParentFirstClassLoader
- copy() - Method in class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- copy() - Method in class org.apache.flink.util.MutableURLClassLoader
-
Copy the classloader for each job and these jobs can add their jar files to the classloader independently.
- 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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
- 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(String, String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
- 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(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(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(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(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(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(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(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(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(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(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(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(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
- 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(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(Path, Path, boolean) - Static method in class org.apache.flink.util.FileUtils
-
Copies all files from source to target and sets executable flag.
- copy(DataInputView, DataOutputView) - 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.BytePrimitiveArraySerializer
- copy(DataInputView, DataOutputView) - 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.DoublePrimitiveArraySerializer
- copy(DataInputView, DataOutputView) - 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.IntPrimitiveArraySerializer
- copy(DataInputView, DataOutputView) - 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.ShortPrimitiveArraySerializer
- copy(DataInputView, DataOutputView) - 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.BigDecSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
- 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(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
- copy(DataInputView, DataOutputView) - 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.NullableSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.BooleanValue
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ByteValue
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.CharValue
- copy(DataInputView, DataOutputView) - Method in interface org.apache.flink.types.CopyableValue
-
Copies the next serialized instance from
source
totarget
. - copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.DoubleValue
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.FloatValue
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.IntValue
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.LongValue
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.NullValue
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.Record
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ShortValue
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.StringValue
- 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(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(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(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(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(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(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(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(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(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
- 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(Row, Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
- 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(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(T) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
- copy(T) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
- copy(T) - 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) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
- copy(T) - 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) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
- copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
- copy(T) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
- 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) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
-
Creates a copy from the given element.
- copy(T, T) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
- copy(T, 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.kryo.KryoSerializer
- copy(T, 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.PojoSerializer
- copy(T, 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.ValueSerializer
- copy(T, T) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
- 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.
- 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.CopyableValueSerializerSnapshot<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
-
TypeSerializerSnapshot
for theCopyableValueSerializer
. - 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) - 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.
- copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.flink.util.IOUtils
-
Copies from one stream to another.
- copyFiles(List<PathsCopyingFileSystem.CopyRequest>, ICloseableRegistry) - Method in interface org.apache.flink.core.fs.PathsCopyingFileSystem
-
List of
PathsCopyingFileSystem.CopyRequest
to copy in batch by thisPathsCopyingFileSystem
. - copyFiles(List<PathsCopyingFileSystem.CopyRequest>, ICloseableRegistry) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
- 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(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
- copyTo(T) - Method in interface org.apache.flink.types.CopyableValue
-
Performs a deep copy of this object into the
target
instance. - 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
- CountHelper(String) - Constructor for class org.apache.flink.util.Utils.CountHelper
- 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(Kryo, Input, Class<Collection>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
- 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(ClassLoader) - Static method in class org.apache.flink.util.SimpleUserCodeClassLoader
- 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(URI) - Method in class org.apache.flink.core.fs.ConnectionLimitingFactory
- create(URI) - Method in interface org.apache.flink.core.fs.FileSystemFactory
-
Creates a new file system for the given file system URI.
- create(URI) - Method in class org.apache.flink.core.fs.local.LocalFileSystemFactory
- create(URI) - Method in class org.apache.flink.core.fs.PluginFileSystemFactory
- create(URL[], ClassLoader, ReadableConfig) - Static method in class org.apache.flink.util.FlinkUserCodeClassLoaders
- create(FSDataOutputStream) - Method in interface org.apache.flink.api.common.serialization.BulkWriter.Factory
-
Creates a writer that writes to the given stream.
- create(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
-
Deprecated.Use
FileSystem.create(Path, FileSystem.WriteMode)
instead. - 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, int, short, long) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Deprecated.
- 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.FileSystem
- create(Path, FileSystem.WriteMode) - Method in interface org.apache.flink.core.fs.IFileSystem
-
Opens an FSDataOutputStream to a new file at the given path.
- create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
- create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
- 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(FlinkUserCodeClassLoaders.ResolveOrder, URL[], ClassLoader, String[], Consumer<Throwable>, boolean) - Static method in class org.apache.flink.util.FlinkUserCodeClassLoaders
- CREATE_CHECKPOINT_SUB_DIR - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
Whether to create sub-directories named by job id to store the data files and meta data of checkpoints.
- 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(CommitterInitContext) - Method in interface org.apache.flink.api.connector.sink2.SupportsCommitter
-
Creates a
Committer
that permanently makes the previously written data visible throughCommitter.commit(Collection)
. - createCommitterFromResumeRecoverable(LocalRecoverable) - Method in class org.apache.flink.core.fs.local.LocalRecoverableFsDataOutputStream
- createCommitterFromResumeRecoverable(RESUME_RECOVERABLE) - Method in class org.apache.flink.core.fs.CommitterFromPersistRecoverableFsDataOutputStream
- createComparator() - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
- createComparator() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
- 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(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(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
- createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.common.typeutils.CompositeType
-
Generic implementation of the comparator creation.
- createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
- 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 givenProperties
. - createCopy() - Method in class org.apache.flink.types.Record
-
Creates an exact copy of this record.
- createCopy(Kryo, Collection) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
- createCopyWritable(T) - Static method in class org.apache.flink.util.InstantiationUtil
-
Clones the given writable using the
serialization
. - createCsvMapper() - Static method in class org.apache.flink.util.jackson.JacksonMapperFactory
- CREATED - org.apache.flink.api.common.JobStatus
-
Job is newly created, no task has started to run.
- 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.
- createFailureEnricher(Configuration) - Method in interface org.apache.flink.core.failure.FailureEnricherFactory
-
Construct a FailureEnricher.
- createFrom(CheckedSupplier<T>) - Static method in class org.apache.flink.util.OptionalFailure
- createHadoopWritableTypeInfo(Class<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
- createInputSerializer() - Method in interface org.apache.flink.api.connector.sink2.WriterInitContext
-
Creates a serializer for the type of sink's input.
- 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() - 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() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
- createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
- createInstance() - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
- createInstance(Object...) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
-
Create new instance from its fields.
- createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
- 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
- createJobStatusChangedListeners(ClassLoader, Configuration, Executor) - Static method in class org.apache.flink.core.execution.JobStatusChangedListenerUtils
-
Create job status changed listeners from configuration for job.
- createListener(JobStatusChangedListenerFactory.Context) - Method in interface org.apache.flink.core.execution.JobStatusChangedListenerFactory
- 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.
- createObjectMapper() - Static method in class org.apache.flink.util.jackson.JacksonMapperFactory
- createObjectMapper(JsonFactory) - Static method in class org.apache.flink.util.jackson.JacksonMapperFactory
- 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(SerializerConfig) - 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
- createPropertiesFile(String) - Method in class org.apache.flink.util.ParameterTool
-
Create a properties file with all the known parameters (call after the last get*() call).
- createPropertiesFile(String, boolean) - Method in class org.apache.flink.util.ParameterTool
-
Create a properties file with all the known parameters (call after the last get*() call).
- createRateLimiter(int) - Method in interface org.apache.flink.api.connector.source.util.ratelimit.RateLimiterStrategy
-
Creates a
RateLimiter
that lets records through with rate proportional to the parallelism. - createReader(SourceReaderContext) - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource
- createReader(SourceReaderContext) - Method in interface org.apache.flink.api.connector.source.SourceReaderFactory
-
Creates a new reader to read data from the splits it gets assigned.
- createRecoverableWriter() - Method in class org.apache.flink.core.fs.FileSystem
- createRecoverableWriter() - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- createRecoverableWriter(Map<String, String>) - Method in class org.apache.flink.core.fs.FileSystem
- createRecoverableWriter(Map<String, String>) - Method in interface org.apache.flink.core.fs.IFileSystem
-
Creates a new
RecoverableWriter
. - 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(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(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(SerializerConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
-
Creates a serializer for the type.
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
- createSerializer(TypeInformation<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Create a serializer for a given type.
- createSerializer(TypeInformation<T>) - Method in interface org.apache.flink.api.common.functions.SerializerFactory
-
Creates a serializer for the specified type of data.
- createSerializer(TypeInformation<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
- 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(Class<?>, Class<?>, int, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
- createTypeInfo(Class<T>) - 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(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
- 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
- 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(WriterInitContext) - Method in interface org.apache.flink.api.connector.sink2.Sink
-
Creates 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(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(UserCodeWrapper<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
- CURRENT_TIME - org.apache.flink.configuration.MetricOptions.JobStatusMetrics
- currentParallelism() - Method in interface org.apache.flink.api.connector.source.SourceReaderContext
-
Get the current parallelism of this Source.
- 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.
- currentSplit - Variable in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
-
The split whose data we return.
- currentWatermark() - Method in interface org.apache.flink.api.connector.sink2.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
- CUSTOM - org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
D
- data - Variable in class org.apache.flink.util.MultipleParameterTool
- data - Variable in class org.apache.flink.util.ParameterTool
- 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 aDataInputView
. - 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 aDataOutputView
. - DataOutputViewStreamWrapper(OutputStream) - Constructor for class org.apache.flink.core.memory.DataOutputViewStreamWrapper
- DataStreamV2SinkUtils - Class in org.apache.flink.api.connector.dsv2
-
Utils to create the DataStream V2 supported
Sink
. - DataStreamV2SinkUtils() - Constructor for class org.apache.flink.api.connector.dsv2.DataStreamV2SinkUtils
- DataStreamV2SourceUtils - Class in org.apache.flink.api.connector.dsv2
-
Utils to create the DataStream V2 supported
Source
. - DataStreamV2SourceUtils() - Constructor for class org.apache.flink.api.connector.dsv2.DataStreamV2SourceUtils
- 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 - Variable in class org.apache.flink.api.common.typeutils.base.LocalDateTimeComparator
- DateComparator - Class in org.apache.flink.api.common.typeutils.base
- DateComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.DateComparator
- 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
- Deadline - Class in org.apache.flink.api.common.time
-
This class stores a deadline, as obtained via
Deadline.now()
or fromDeadline.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
- DECLARE_NEEDED_RESOURCE_DELAY - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
- 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 typeIN
from aReadableConfig
and transforms it to aList
of typeOUT
based on the providedmapper
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 - org.apache.flink.configuration.JobManagerOptions.SchedulerType
- DEFAULT - org.apache.flink.configuration.TaskManagerOptions.SystemOutMode
-
Don't change the
System.out
andSystem.err
, it's the default value. - DEFAULT - Static variable in class org.apache.flink.api.common.operators.ResourceSpec
-
The default ResourceSpec used for operators and transformation functions.
- DEFAULT - Static variable in enum org.apache.flink.core.execution.CheckpointType
- DEFAULT - Static variable in enum org.apache.flink.core.execution.RecoveryClaimMode
- DEFAULT - Static variable in enum org.apache.flink.core.execution.SavepointFormatType
- DEFAULT_CHARSET - Static variable in class org.apache.flink.configuration.ConfigConstants
- 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_LIB_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default Flink lib directory if none has been specified via
ConfigConstants.ENV_FLINK_LIB_DIR
. - DEFAULT_FLINK_OPT_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The default Flink opt directory if none has been specified via
ConfigConstants.ENV_FLINK_OPT_DIR
. - 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_LOCAL_NUMBER_TASK_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
- DEFAULT_PARALLELISM - Static variable in class org.apache.flink.configuration.CoreOptions
- DEFAULT_UNDEFINED - Static variable in class org.apache.flink.util.AbstractParameterTool
- DEFAULT_YARN_CONTAINER_START_COMMAND_TEMPLATE - Static variable in class org.apache.flink.configuration.ConfigConstants
-
Start command template for Flink on YARN containers.
- defaultData - Variable in class org.apache.flink.util.AbstractParameterTool
- 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(Collection<? extends InputSplit>) - Constructor for class org.apache.flink.api.common.io.DefaultInputSplitAssigner
- DefaultInputSplitAssigner(InputSplit[]) - Constructor for class org.apache.flink.api.common.io.DefaultInputSplitAssigner
- DefaultJobExecutionStatusEvent - Class in org.apache.flink.core.execution
-
Default implementation for
JobExecutionStatusEvent
. - DefaultJobExecutionStatusEvent(JobID, String, JobStatus, JobStatus, Throwable) - Constructor for class org.apache.flink.core.execution.DefaultJobExecutionStatusEvent
- DefaultOpenContext - Class in org.apache.flink.api.common.functions
-
The default implementation of
OpenContext
. - DefaultOpenContext() - Constructor for class org.apache.flink.api.common.functions.DefaultOpenContext
- 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>, ClassLoader, String[]) - Constructor for class org.apache.flink.core.plugin.DefaultPluginManager
- DefaultPluginManager(Collection<PluginDescriptor>, String[]) - Constructor for class org.apache.flink.core.plugin.DefaultPluginManager
- defaultValue - Variable in class org.apache.flink.api.common.state.StateDescriptor
-
Deprecated.To make the semantics more clear, user should manually manage the default value if the contents of the state is
null
- 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.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.
- deferrable() - Static method in interface org.apache.flink.api.common.operators.MailboxExecutor.MailOptions
-
Mark this mail as deferrable.
- 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(TypeSerializerSnapshot<T>, CompositeTypeSerializerSnapshot<T, ? extends TypeSerializer<T>>, 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.
- DELEGATION_TOKEN_PROVIDER_ENABLED - Static variable in class org.apache.flink.configuration.SecurityOptions
- DELEGATION_TOKEN_PROVIDER_PREFIX - Static variable in class org.apache.flink.configuration.SecurityOptions
- DELEGATION_TOKENS_ENABLED - Static variable in class org.apache.flink.configuration.SecurityOptions
- DELEGATION_TOKENS_RENEWAL_RETRY_BACKOFF - Static variable in class org.apache.flink.configuration.SecurityOptions
- DELEGATION_TOKENS_RENEWAL_TIME_RATIO - Static variable in class org.apache.flink.configuration.SecurityOptions
- DelegationTokenProvider - Interface in org.apache.flink.core.security.token
-
Delegation token provider API.
- DelegationTokenProvider.ObtainedDelegationTokens - Class in org.apache.flink.core.security.token
-
Container for obtained delegation tokens.
- DelegationTokenReceiver - Interface in org.apache.flink.core.security.token
-
Delegation token receiver API.
- delegationTokensRequired() - Method in interface org.apache.flink.core.security.token.DelegationTokenProvider
-
Return whether delegation tokens are required for this service.
- delete(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
- delete(Path, boolean) - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- DELETE - org.apache.flink.types.RowKind
-
Deletion operation.
- DELETE_ON_CANCELLATION - org.apache.flink.configuration.ExternalizedCheckpointRetention
-
Delete externalized checkpoints on job cancellation.
- 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.
- deleteFilesRecursively(Path) - Static method in class org.apache.flink.util.IOUtils
-
Delete the given directory or file recursively.
- deleteOnCancellation() - Method in enum org.apache.flink.configuration.ExternalizedCheckpointRetention
-
Returns whether persistent checkpoints shall be discarded on cancellation of the job.
- 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_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_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.
- 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
- depth() - Method in class org.apache.flink.core.fs.Path
-
Returns the number of elements in this path.
- deref() - Method in class org.apache.flink.util.Reference
- DESCENDING - org.apache.flink.api.common.operators.Order
-
Indicates a descending order.
- DescribedEnum - Interface in org.apache.flink.configuration
-
Describe enum constants used in
ConfigOption
s. - description - Variable in class org.apache.flink.api.dag.Transformation
- 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
withnull
as its error detail message. - DeserializationException(String) - Constructor for exception org.apache.flink.types.DeserializationException
-
Constructs an
DeserializationException
with the specified detail message. - DeserializationException(String, Throwable) - Constructor for exception org.apache.flink.types.DeserializationException
-
Constructs an
DeserializationException
with the specified detail message and cause. - 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(boolean[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
- 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[]) - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
- deserialize(byte[]) - Method in class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
- deserialize(byte[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
- deserialize(byte[], Collector<T>) - Method in interface org.apache.flink.api.common.serialization.DeserializationSchema
-
Deserializes the byte message.
- deserialize(char[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
- deserialize(double[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
- deserialize(float[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
- deserialize(int[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
- 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(int, byte[]) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerAdapter
- deserialize(long[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
- deserialize(short[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
- deserialize(C[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
- deserialize(Boolean, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
- deserialize(Byte, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
- deserialize(Character, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
- deserialize(Double, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
- deserialize(Float, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
- deserialize(Integer, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
- deserialize(Long, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
- deserialize(Short, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
- deserialize(String[], 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.StringSerializer
- deserialize(Void, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
- deserialize(BigDecimal, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
- deserialize(BigInteger, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
- deserialize(Date, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
- deserialize(Time, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
- deserialize(Timestamp, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
- deserialize(Instant, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
- deserialize(LocalDate, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateSerializer
- deserialize(LocalDateTime, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalDateTimeSerializer
- deserialize(LocalTime, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LocalTimeSerializer
- deserialize(Date, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
- deserialize(List<T>, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
- deserialize(Map<K, V>, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
- deserialize(Tuple0, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
- deserialize(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(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(DataInputView) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
- deserialize(DataInputView) - Method in class org.apache.flink.types.Record
- deserialize(BooleanValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
- deserialize(ByteValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
- deserialize(CharValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
- deserialize(DoubleValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
- deserialize(Either<L, R>, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
- deserialize(FloatValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
- deserialize(IntValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
- deserialize(LongValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
- deserialize(NullValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
- deserialize(Row, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
- deserialize(ShortValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
- deserialize(StringValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
- 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(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
- deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.SingleThreadAccessCheckingTypeSerializer
- 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(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
- deserialize(T, 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.kryo.KryoSerializer
- deserialize(T, 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.PojoSerializer
- deserialize(T, 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.ValueSerializer
- deserialize(T, DataInputView) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
- 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
- deserializeFromDataInputView(DataInputView) - Static method in class org.apache.flink.core.fs.Path
-
Deserialize the Path from
DataInputView
. - 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(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.
- 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 - org.apache.flink.api.common.state.StateTtlConfig.UpdateType
-
TTL is disabled.
- DISABLED - org.apache.flink.configuration.ClusterOptions.UserSystemExitMode
- DISABLED - Static variable in class org.apache.flink.api.common.state.StateTtlConfig
- DISABLED_NETWORK_BUFFER_TIMEOUT - Static variable in class org.apache.flink.configuration.ExecutionOptions
-
A special marker value for disabling buffer timeout.
- 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.RpcOptions
-
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. that have a dedicated lifecycle step to "destroy" the object.
- 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, 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) - Constructor for class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
Client-side constructor used by the API for initial registration.
- DistributedCacheEntry(String, Boolean, byte[]) - Constructor for class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
-
Server-side constructor used during job-submission for files.
- 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.
- divide(int) - Method in class org.apache.flink.api.common.resources.Resource
- divide(BigDecimal) - Method in class org.apache.flink.api.common.resources.Resource
- divideRoundUp(int, int) - Static method in class org.apache.flink.util.MathUtils
-
Divide and rounding up to integer.
- doClose(List<Closeable>) - Method in class org.apache.flink.core.fs.CloseableRegistry
-
This implementation doesn't imply any exception during closing due to backward compatibility.
- doClose(List<Closeable>) - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
-
This implementation doesn't imply any exception during closing due to backward compatibility.
- doClose(List<AutoCloseable>) - Method in class org.apache.flink.core.fs.AutoCloseableRegistry
-
This implementation implies that any exception is possible during closing.
- doClose(List<R>) - Method in class org.apache.flink.util.AbstractAutoCloseableRegistry
- 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(C, Map<R, T>) - Method in class org.apache.flink.util.AbstractAutoCloseableRegistry
-
Does the actual registration of the closeable with the registry map.
- doRegister(Closeable, Map<Closeable, Object>) - Method in class org.apache.flink.core.fs.CloseableRegistry
- doRegister(AutoCloseable, Map<AutoCloseable, Object>) - Method in class org.apache.flink.core.fs.AutoCloseableRegistry
- doRegister(WrappingProxyCloseable<? extends Closeable>, Map<Closeable, SafetyNetCloseableRegistry.PhantomDelegatingCloseableRef>) - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
- DOUBLE - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for both a primitive
double
andDouble
. - 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 upDoubleValue
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 anAggregator
that defines convergence as reached once the aggregator holds the value zero. - DoubleZeroConvergence() - Constructor for class org.apache.flink.api.common.aggregators.DoubleZeroConvergence
- doUnRegister(C, Map<R, T>) - Method in class org.apache.flink.util.AbstractAutoCloseableRegistry
-
Does the actual un-registration of the closeable from the registry map.
- doUnRegister(Closeable, Map<Closeable, Object>) - Method in class org.apache.flink.core.fs.CloseableRegistry
- doUnRegister(AutoCloseable, Map<AutoCloseable, Object>) - Method in class org.apache.flink.core.fs.AutoCloseableRegistry
- doUnRegister(WrappingProxyCloseable<? extends Closeable>, Map<Closeable, SafetyNetCloseableRegistry.PhantomDelegatingCloseableRef>) - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
- DualInputOperator<IN1,IN2,OUT,FT extends org.apache.flink.api.common.functions.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>, 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.
- 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.
- 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
- 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. if it is stateful.
- 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(String, Throwable) - Constructor for exception org.apache.flink.util.DynamicCodeLoadingException
-
Creates a new exception with the given message and cause.
- DynamicCodeLoadingException(Throwable) - Constructor for exception org.apache.flink.util.DynamicCodeLoadingException
-
Creates a new exception with the given cause.
- DynamicFilteringInfo - Interface in org.apache.flink.api.connector.source
-
A decorative interface that indicates it holds the dynamic partition filtering data.
- DynamicParallelismInference - Interface in org.apache.flink.api.connector.source
-
Sources that implement this interface will dynamically infer the source’s parallelism when it is unspecified.
- DynamicParallelismInference.Context - Interface in org.apache.flink.api.connector.source
-
A context that provides dynamic parallelism decision infos.
E
- EAGER_FUNCTION_MESSAGE - Static variable in class org.apache.flink.core.execution.DetachedJobExecutionResult
- 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(TypeInformation<L>, TypeInformation<R>) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for Flink's
Either
type. - 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 theEither
type of the Java class. - EitherSerializer(TypeSerializer<L>, TypeSerializer<R>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
- EitherTypeInfo<L,R> - Class in org.apache.flink.api.java.typeutils
-
A
TypeInformation
for theEither
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_COLUMN - org.apache.flink.types.parser.FieldParser.ParseErrorState
-
The column is empty.
- 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_CHECKPOINTS_AFTER_TASKS_FINISH - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- ENABLE_FLAMEGRAPH - Static variable in class org.apache.flink.configuration.RestOptions
-
Enables the experimental flame graph feature.
- ENABLE_PROFILER - Static variable in class org.apache.flink.configuration.RestOptions
-
Enables the experimental profiler feature.
- ENABLE_QUERYABLE_STATE_PROXY_SERVER - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
Deprecated.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.StateChangelogOptions
-
Whether to enable state change log.
- ENABLE_UNALIGNED - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- ENABLE_UNALIGNED_INTERRUPTIBLE_TIMERS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- 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.
- 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.
- enablePeriodicMaterialize(boolean) - Method in class org.apache.flink.api.common.ExecutionConfig
- enableQuotedStringParsing(byte) - Method in class org.apache.flink.types.parser.StringParser
- enableQuotedStringParsing(byte) - Method in class org.apache.flink.types.parser.StringValueParser
- enableQuotedStringParsing(char) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
- 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
- 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 typeIN
in aWritableConfig
as aConfigOption
of typeList
of typeOUT
. - 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. - END_OF_INPUT - org.apache.flink.core.io.InputStatus
-
Indicator that the input has reached the end of data.
- 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
- 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
. - entry(K, V) - Static method in class org.apache.flink.util.CollectionUtil
-
Returns an immutable
Map.Entry
. - 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
- 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.EnumSerializerSnapshot<T extends Enum<T>> - Class in org.apache.flink.api.common.typeutils.base
- 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_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.serialization.SerializerConfigImpl
- equals(Object) - Method in class org.apache.flink.api.common.state.StateDescriptor
- 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.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.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.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.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.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.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.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.FileSystem.FSKey
- 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.MultipleParameterTool
- 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.ParameterTool
- 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
- equals(Object) - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- 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(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(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(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(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
- 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(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(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(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(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
- equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
- equalToReference(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
- 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.
- ERROR_REGISTRATION_DELAY - Static variable in class org.apache.flink.configuration.ClusterOptions
- errorLogThreadDump(Logger) - Static method in class org.apache.flink.util.concurrent.ThreadUtils
- EXACTLY_ONCE - org.apache.flink.core.execution.CheckpointingMode
-
Sets the checkpointing mode to "exactly once".
- exception() - Method in class org.apache.flink.core.execution.DefaultJobExecutionStatusEvent
- exception() - Method in interface org.apache.flink.core.execution.JobExecutionStatusEvent
-
Exception for job.
- exceptionHandler - Variable in class org.apache.flink.core.state.StateFutureImpl
-
The exception handler that handles callback framework's error.
- ExceptionUtils - Class in org.apache.flink.util
-
A collection of utility functions for dealing with exceptions and exception workflows.
- executablesEquals(Constructor<?>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
- executablesEquals(Method) - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
- execute(Runnable) - Method in class org.apache.flink.core.fs.BackPressuringExecutor
- execute(Runnable) - Method in class org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
- execute(Runnable) - Method in class org.apache.flink.util.concurrent.SeparateThreadExecutor
- execute(MailboxExecutor.MailOptions, 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(MailboxExecutor.MailOptions, 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(Plan) - Method in class org.apache.flink.api.common.operators.CollectionExecutor
- execute(Pipeline, Configuration, ClassLoader) - Method in interface org.apache.flink.core.execution.PipelineExecutor
- 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.
- 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<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<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
- executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
- executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
- executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
- 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<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
- executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
- executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.DualInputOperator
- executeOnCollections(List<ST>, List<WT>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
- executeOnCollections(List<T>, List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.Union
- executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
- executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.FilterOperatorBase
- executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
- executeOnCollections(RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
- EXECUTION_FAILOVER_STRATEGY - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
This option specifies the failover strategy, i.e. how the job computation recovers from task failures.
- EXECUTION_TIME_BASELINE_LOWER_BOUND - Static variable in class org.apache.flink.configuration.SlowTaskDetectorOptions
- EXECUTION_TIME_BASELINE_MULTIPLIER - Static variable in class org.apache.flink.configuration.SlowTaskDetectorOptions
- EXECUTION_TIME_BASELINE_RATIO - Static variable in class org.apache.flink.configuration.SlowTaskDetectorOptions
- executionConfig - Variable in class org.apache.flink.api.common.Plan
-
Config object for runtime execution parameters.
- 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(Configuration) - Constructor for class org.apache.flink.api.common.ExecutionConfig
- 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.
- ExecutionOptions - Class in org.apache.flink.configuration
-
ConfigOption
s 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
andExecutorService
implementations. - 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
-
Builder for
ExecutorThreadFactory
. - 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
- exists(Path) - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- expandDirectory(Path, Path) - Static method in class org.apache.flink.util.FileUtils
-
Un-archives files inside the target directory.
- EXPONENTIAL_DELAY - org.apache.flink.configuration.RestartStrategyOptions.RestartStrategyType
- EXPONENTIAL_DELAY_LABEL - Static variable in class org.apache.flink.configuration.CleanupOptions
- 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
- 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(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(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.
- ExpressionKeys(TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
-
ExpressionKeys that is defined by the full data 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.
- EXTERNALIZED_CHECKPOINT_RETENTION - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- ExternalizedCheckpointRetention - Enum in org.apache.flink.configuration
-
Cleanup behaviour for externalized checkpoints when the job is cancelled.
- ExternallyInducedSourceReader<T,SplitT extends SourceSplit> - Interface in org.apache.flink.api.connector.source
-
Sources that implement this interface delay checkpoints when receiving a trigger message from the checkpoint coordinator to the point 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
-
Factory for
ExternalResourceDriver
. - 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
- extractAlphaNumericCharacters(String) - Static method in class org.apache.flink.configuration.CleanupOptions
- extractFile(String, String, String) - Static method in class org.apache.flink.util.CompressionUtils
- extractFileExtension(String) - Static method in class org.apache.flink.api.common.io.FileInputFormat
-
Returns the extension of a file name (!
- 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
- extractTarFile(String, String) - Static method in class org.apache.flink.util.CompressionUtils
- extractTimestamp(E, long) - Method in class org.apache.flink.api.common.eventtime.RecordTimestampAssigner
- extractTimestamp(T, long) - Method in class org.apache.flink.api.common.eventtime.IngestionTimeAssigner
- 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.
- extractZipFileWithPermissions(String, String) - Static method in class org.apache.flink.util.CompressionUtils
F
- FAIL - org.apache.flink.configuration.ClusterOptions.UncaughtExceptionHandleMode
- FAIL_ON_USER_CLASS_LOADING_METASPACE_OOM - Static variable in class org.apache.flink.configuration.CoreOptions
- FAILED - org.apache.flink.api.common.JobStatus
-
The job has failed with a non-recoverable task failure.
- FAILED_RPC_DETECTION_DISABLED - Static variable in class org.apache.flink.configuration.HeartbeatManagerOptions
- FAILING - org.apache.flink.api.common.JobStatus
-
The job has failed and is currently waiting for the cleanup to complete.
- FAILURE_ENRICHERS_LIST - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
Flag indicating whether JobManager should load available Failure Enricher plugins at startup.
- FAILURE_RATE - org.apache.flink.configuration.RestartStrategyOptions.RestartStrategyType
- FailureEnricher - Interface in org.apache.flink.core.failure
-
Failure Enricher enabling custom logic and attaching metadata in the form of labels to each type of failure as tracked in the JobMaster.
- FailureEnricher.Context - Interface in org.apache.flink.core.failure
-
An interface used by the
FailureEnricher
. - FailureEnricher.Context.FailureType - Enum in org.apache.flink.core.failure
-
Type of failure.
- FailureEnricherFactory - Interface in org.apache.flink.core.failure
-
Factory class for creating
FailureEnricher
. - 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.
- FALSE - org.apache.flink.util.TernaryBoolean
-
The value for 'false'.
- 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(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
- 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(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(Integer) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
-
Creates a set with one field.
- FieldSet(Collection<Integer>) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
- File - org.apache.flink.configuration.JobManagerOptions.JobStoreType
- FILE_MERGING_ACROSS_BOUNDARY - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
Whether to allow merging data of multiple checkpoints into one physical file.
- FILE_MERGING_ENABLED - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
Whether to enable merging multiple checkpoint files into one, which will greatly reduce the number of small checkpoint files.
- FILE_MERGING_MAX_FILE_SIZE - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
The max size of a physical file for merged checkpoints.
- FILE_MERGING_MAX_SPACE_AMPLIFICATION - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
Space amplification stands for the magnification of the occupied space compared to the amount of valid data.
- FILE_MERGING_MAX_SUBTASKS_PER_FILE - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
The upper limit of the file pool size based on the number of subtasks within each TM (only for merging private state at Task Manager level).
- FILE_MERGING_POOL_BLOCKING - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
Whether to use Blocking or Non-Blocking pool for merging physical files.
- FILE_SYSTEM - org.apache.flink.core.fs.FileSystemKind
-
An actual file system, with files and directories.
- 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
RichInputFormat
s 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.
- FileLock - Class in org.apache.flink.util
-
A file lock used for avoiding race condition among multiple threads/processes.
- FileLock(String) - Constructor for class org.apache.flink.util.FileLock
-
Initialize a FileLock using a file located at fullPath.
- FileLock(String, String) - Constructor for class org.apache.flink.util.FileLock
-
Initialize a FileLock using a file located at parentDir/fileName.
- 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
- 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_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.FSKey - Class in org.apache.flink.core.fs
-
An identifier of a file system, via its scheme and its authority.
- FileSystem.WriteMode - Enum in org.apache.flink.core.fs
-
The possible write modes.
- 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(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
- FilterOperatorBase(UserCodeWrapper<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 thefilePath
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.
- finalizeGlobal(FinalizeOnMaster.FinalizationContext) - 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
OutputFormat
s to have the master finalize them globally. - FinalizeOnMaster.FinalizationContext - Interface in org.apache.flink.api.common.io
-
A context that provides parallelism and finished attempts infos.
- 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.
- finish() - Method in interface org.apache.flink.api.common.serialization.BulkWriter
-
Finishes the writing.
- FINISHED - org.apache.flink.api.common.JobStatus
-
All of the job's tasks have successfully finished.
- finishSplit() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
- FIRST_IS_SMALL - org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
- FirstAttemptInitializationContext - Class in org.apache.flink.api.common.io
-
Special
OutputFormat.InitializationContext
, whose attempt number always zero. - 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. - firstPresent(Optional<T>...) - Static method in class org.apache.flink.util.OptionalUtils
-
Returns the first
Optional
which is present. - FIXED_DELAY - org.apache.flink.configuration.RestartStrategyOptions.RestartStrategyType
- FIXED_DELAY_LABEL - Static variable in class org.apache.flink.configuration.CleanupOptions
- 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(IN, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichFlatMapFunction
- flatMap(Iterable<G>, Function<K, V>) - Static method in class org.apache.flink.util.IterableUtils
- flatMap(T, Collector<O>) - Method in interface org.apache.flink.api.common.functions.FlatMapFunction
-
The core method of the FlatMapFunction.
- flatMap(X, Collector<X>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
- 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(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
- FlatMapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
- flatten(Properties) - Static method in class org.apache.flink.util.PropertiesUtil
-
Flatten a recursive
Properties
to a first level property map. - flatten(CloseableIterator<T>...) - Static method in interface org.apache.flink.util.CloseableIterator
- 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_DEFAULT_JM_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
- FLINK_DEFAULT_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
- FLINK_DEFAULT_TM_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
- FLINK_HADOOP_CONF_DIR - Static variable in class org.apache.flink.configuration.CoreOptions
-
This option 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 option 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.CoreOptions
- FLINK_LOG_DIR - Static variable in class org.apache.flink.configuration.CoreOptions
-
This option is here only for documentation generation, it is only evaluated in the shell scripts.
- FLINK_LOG_LEVEL - Static variable in class org.apache.flink.configuration.CoreOptions
-
This option 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 option 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. see:
bin/config.sh#KEY_ENV_PID_DIR
andbin/config.sh#DEFAULT_ENV_PID_DIR
- FLINK_REST_CLIENT_HEADERS - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The environment variable name which contains a list of newline-separated HTTP headers for Flink's REST client.
- FLINK_SQL_GATEWAY_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
- FLINK_SSH_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
-
This option is here only for documentation generation, it is only evaluated in the shell scripts.
- FLINK_STD_REDIRECT_TO_FILE - Static variable in class org.apache.flink.configuration.CoreOptions
-
This option 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 option 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(String, Throwable) - Constructor for exception org.apache.flink.util.FlinkException
-
Creates a new exception with the given message and cause.
- FlinkException(Throwable) - Constructor for exception org.apache.flink.util.FlinkException
-
Creates a new exception with a null message and the given cause.
- FlinkExpectedException - Exception in org.apache.flink.util
-
This class is just used to pass diagnostic message of some excepted procedure.
- FlinkExpectedException(String) - Constructor for exception org.apache.flink.util.FlinkExpectedException
- FlinkExpectedException(String, Throwable) - Constructor for exception org.apache.flink.util.FlinkExpectedException
- FlinkExpectedException(Throwable) - Constructor for exception org.apache.flink.util.FlinkExpectedException
- 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(String, Throwable) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
-
Creates a new exception with the given message and cause.
- FlinkRuntimeException(Throwable) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
-
Creates a new exception with a null message and the given 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
- FlinkUserCodeClassLoaders - Class in org.apache.flink.util
-
Gives the URLClassLoader a nicer name for debugging purposes.
- FlinkUserCodeClassLoaders.ParentFirstClassLoader - Class in org.apache.flink.util
-
Regular URLClassLoader that first loads from the parent and only after that from the URLs.
- FlinkUserCodeClassLoaders.ResolveOrder - Enum in org.apache.flink.util
-
Class resolution order for Flink URL
ClassLoader
. - FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader - Class in org.apache.flink.util
-
Ensures that holding a reference on the context class loader outliving the scope of user code does not prevent the user classloader to be garbage collected (FLINK-16245).
- 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
andFloat
. - 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
- flush() - Method in class org.apache.flink.core.fs.local.LocalRecoverableFsDataOutputStream
- flush() - Method in class org.apache.flink.core.fs.OffsetAwareOutputStream
- flush() - Method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- flush() - Method in class org.apache.flink.util.CloseShieldOutputStream
- flush(boolean) - Method in class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
- flush(boolean) - Method in interface org.apache.flink.api.connector.sink2.SinkWriter
-
Called on checkpoint or end of input so that the writer to flush all pending data for at-least-once.
- FLUSH_AFTER_EVERY_RECORD - Static variable in class org.apache.flink.configuration.ExecutionOptions
-
A special marker value for flushing network buffers after each record.
- FLUSH_INTERVAL - Static variable in class org.apache.flink.configuration.JobEventStoreOptions
- FOLDING - org.apache.flink.api.common.state.StateDescriptor.Type
- 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
- FORCE_KRYO_AVRO - Static variable in class org.apache.flink.configuration.PipelineOptions
- FORCE_RPC_INVOCATION_SERIALIZATION - Static variable in class org.apache.flink.configuration.RpcOptions
- FORCE_UNALIGNED - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- 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.RpcOptions
- FORK_JOIN_EXECUTOR_PARALLELISM_MAX - Static variable in class org.apache.flink.configuration.RpcOptions
- FORK_JOIN_EXECUTOR_PARALLELISM_MIN - Static variable in class org.apache.flink.configuration.RpcOptions
- format(Description) - Method in class org.apache.flink.configuration.description.Formatter
-
Formats the description into a String using format specific tags.
- 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
- format(LineBreakElement) - Method in class org.apache.flink.configuration.description.Formatter
- format(LinkElement) - Method in class org.apache.flink.configuration.description.Formatter
- format(ListElement) - Method in class org.apache.flink.configuration.description.Formatter
- format(TextElement) - Method in class org.apache.flink.configuration.description.Formatter
- 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
- formatURL(URL) - Static method in class org.apache.flink.util.ClassLoaderUtil
-
Returns the interpretation of URL in string format.
- 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.
- forProvider(Configuration, String) - Static method in class org.apache.flink.configuration.SecurityOptions
-
Returns a view over the given configuration via which options can be set/retrieved for the given provider.
- forReporter(Configuration, String) - Static method in class org.apache.flink.configuration.MetricOptions
-
Returns a view over the given configuration via which options can be set/retrieved for the given reporter.
- forTraceReporter(Configuration, String) - Static method in class org.apache.flink.configuration.TraceOptions
-
Returns a view over the given configuration via which options can be set/retrieved for the given reporter.
- 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.RpcOptions
-
Maximum framesize of Pekko 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.
- FREE_BSD - org.apache.flink.util.OperatingSystem
- from() - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
- from(SlotSharingGroup) - Static method in class org.apache.flink.api.common.operators.SlotSharingGroup
-
Convert a
SlotSharingGroup
toSlotSharingGroup
. - fromArgs(String[]) - Static method in class org.apache.flink.util.MultipleParameterTool
-
Returns
MultipleParameterTool
for the given arguments. - fromArgs(String[]) - Static method in class org.apache.flink.util.ParameterTool
-
Returns
ParameterTool
for the given arguments. - fromBoolean(boolean) - Static method in enum org.apache.flink.util.TernaryBoolean
-
Converts the given boolean to a TernaryBoolean,
TernaryBoolean.TRUE
orTernaryBoolean.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(Configuration) - Static method in class org.apache.flink.configuration.MetricOptions.JobStatusMetricsSettings
- fromConfiguration(Configuration) - Static method in class org.apache.flink.core.plugin.PluginConfig
- fromData(Collection<T>) - Static method in class org.apache.flink.api.connector.dsv2.DataStreamV2SourceUtils
-
Creates a source that contains the given elements.The type of the data stream is that of the elements in the collection.
- FromDataSource<T> - Class in org.apache.flink.api.connector.dsv2
-
DataStream v2 source that emit data from pre-provided data.
- FromDataSource(Collection<T>) - Constructor for class org.apache.flink.api.connector.dsv2.FromDataSource
- fromHexString(String) - Static method in class org.apache.flink.api.common.JobID
-
Parses a JobID from the given string.
- 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.
- fromMap(Map<String, String>) - Static method in class org.apache.flink.util.ParameterTool
-
Returns
ParameterTool
for the given map. - fromMultiMap(Map<String, Collection<String>>) - Static method in class org.apache.flink.util.MultipleParameterTool
-
Returns
MultipleParameterTool
for the given multi 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.
- fromPropertiesFile(File) - Static method in class org.apache.flink.util.ParameterTool
-
Returns
ParameterTool
for the givenProperties
file. - fromPropertiesFile(InputStream) - Static method in class org.apache.flink.util.ParameterTool
-
Returns
ParameterTool
for the given InputStream fromProperties
file. - fromPropertiesFile(String) - Static method in class org.apache.flink.util.ParameterTool
-
Returns
ParameterTool
for the givenProperties
file. - fromString(String) - Static method in enum org.apache.flink.util.FlinkUserCodeClassLoaders.ResolveOrder
- fromSystemProperties() - Static method in class org.apache.flink.util.ParameterTool
-
Returns
ParameterTool
from the system properties. - FS_SMALL_FILE_THRESHOLD - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
The minimum size of state data files.
- FS_STREAM_OPENING_TIME_OUT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
- 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
- FSKey(String, String) - Constructor for class org.apache.flink.core.fs.FileSystem.FSKey
-
Creates a file system key from a given scheme and an authority.
- FSKey(URI) - Constructor for class org.apache.flink.core.fs.FileSystem.FSKey
- FULL - org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
- FULL - org.apache.flink.core.execution.CheckpointType
- FullTypeInfo(Class<?>, ReflectionUtil.FullTypeInfo[]) - Constructor for class org.apache.flink.util.ReflectionUtil.FullTypeInfo
- 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.
- FutureConsumerWithException<T,E extends Throwable> - Interface in org.apache.flink.util.concurrent
-
A checked extension of the
Consumer
interface which rethrows exceptions wrapped in aCompletionException
. - FutureTaskWithException<V> - Class in org.apache.flink.util.function
-
FutureTask
that also implementsRunnableWithException
. - 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
- GatedRateLimiter - Class in org.apache.flink.api.connector.source.util.ratelimit
-
An implementation of
RateLimiter
that completes defined number of futures in-between the external notification events. - GatedRateLimiter(int) - Constructor for class org.apache.flink.api.connector.source.util.ratelimit.GatedRateLimiter
-
Instantiates a new GatedRateLimiter.
- 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.
- generateStagingTempFilePath(File) - Static method in class org.apache.flink.core.fs.local.LocalRecoverableWriter
- 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
- 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(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(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(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(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.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
- 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() - Method in class org.apache.flink.core.state.CompletedStateFuture
- get() - Method in interface org.apache.flink.core.state.InternalStateFuture
-
Waits if necessary for the computation to complete, and then retrieves its result.
- get() - Method in class org.apache.flink.core.state.StateFutureImpl
- get() - Method in class org.apache.flink.types.BooleanValue
- get() - Method in class org.apache.flink.types.SerializableOptional
- get() - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
- get() - Method in class org.apache.flink.util.OptionalFailure
- get(int) - Method in class org.apache.flink.api.common.operators.util.FieldList
- get(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads the byte at the given position.
- get(int) - Method in class org.apache.flink.types.ListValue
- 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(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Bulk get method.
- get(long, TimeUnit) - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
- get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
- get(Object) - Method in class org.apache.flink.types.MapValue
- get(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the String value for the given key.
- get(String) - Method in class org.apache.flink.util.MultipleParameterTool
-
Returns the String value for the given key.
- get(String) - Method in class org.apache.flink.util.ParameterTool
-
Returns the String value for the given key.
- get(String, String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the String value for the given key.
- get(Throwable, ClassLoader) - Static method in exception org.apache.flink.util.SerializedThrowable
- 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 givenURI
. - get(ConfigOption<T>) - Method in class org.apache.flink.configuration.Configuration
-
Please check the java doc of
Configuration.getRawValueFromOption(ConfigOption)
. - 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(ConfigOption<T>, T) - Method in class org.apache.flink.configuration.Configuration
-
Returns the value associated with the given config option as a T.
- get(ConfigOption<T>, T) - Method in class org.apache.flink.configuration.DelegatingConfiguration
- 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
- getAdditionalDetailsForIncompatibleVersion(int) - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
- 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
- getAlignmentParameters() - Method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
-
Provides configuration for watermark alignment of a maximum watermark of multiple sources/tasks/partitions in the same watermark group.
- 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
- getAllAvailableValues() - Method in enum org.apache.flink.configuration.RestartStrategyOptions.RestartStrategyType
- getAllConfigOptions(Class<?>) - Static method in class org.apache.flink.configuration.ConfigUtils
- 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 interface org.apache.flink.api.common.TaskInfo
-
Returns the allocation id for where this task is executed.
- getAllocationIDAsString() - Method in class org.apache.flink.api.common.TaskInfoImpl
- getAllRegisteredAggregators() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
- getAllTextElement() - Method in enum org.apache.flink.configuration.RestartStrategyOptions.RestartStrategyType
- 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.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.
- getAsyncInflightRecordsLimit() - Method in class org.apache.flink.api.common.ExecutionConfig
- getAsyncStateBufferSize() - Method in class org.apache.flink.api.common.ExecutionConfig
- getAsyncStateBufferTimeout() - Method in class org.apache.flink.api.common.ExecutionConfig
- getAttemptNumber() - Method in class org.apache.flink.api.common.io.FirstAttemptInitializationContext
- getAttemptNumber() - Method in interface org.apache.flink.api.common.io.OutputFormat.InitializationContext
-
Gets the attempt number of this parallel subtask.
- getAttemptNumber() - Method in interface org.apache.flink.api.common.TaskInfo
-
Gets the attempt number of this parallel subtask.
- getAttemptNumber() - Method in class org.apache.flink.api.common.TaskInfoImpl
- getAttribute() - Method in class org.apache.flink.api.dag.Transformation
- 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. - 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
- getBasicTypeInfo() - Method in class org.apache.flink.api.common.typeinfo.descriptor.BasicTypeDescriptorImpl
- 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(int) - Method in class org.apache.flink.core.memory.MemorySegment
-
Reads one byte at the given position and returns its boolean representation.
- getBoolean(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Boolean value for the given key.
- getBoolean(String, boolean) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Boolean value for the given key.
- getBoolean(Properties, String, boolean) - Static method in class org.apache.flink.util.PropertiesUtil
-
Get boolean from properties.
- getBooleanConfigOption(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
- 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
- getByte(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Byte value for the given key.
- getByte(String, byte) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Byte value for the given key.
- getByteArray() - Method in class org.apache.flink.util.SerializedValue
-
Returns byte array for serialized data.
- getBytes() - Method in class org.apache.flink.util.AbstractID
-
Gets the bytes underlying this ID.
- 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
- getCachedFiles() - Method in class org.apache.flink.api.common.Plan
-
Return the registered cached files.
- getCallLocationName() - Static method in class org.apache.flink.util.Utils
- getCallLocationName(int) - Static method in class org.apache.flink.util.Utils
- 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.
- getChecksum() - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- 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.
- getCommittable() - Method in interface org.apache.flink.api.connector.sink2.Committer.CommitRequest
-
Returns the committable.
- getCommittableSerializer() - Method in interface org.apache.flink.api.connector.sink2.SupportsCommitter
-
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
- getCompatibleVersions() - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
-
Returns the compatible version values.
- getCompatibleWriterStateNames() - Method in interface org.apache.flink.api.connector.sink2.SupportsWriterState.WithCompatibleState
-
A collection of state names of sinks from which the state can be restored.
- 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.descriptor.ListTypeDescriptorImpl
- 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 class org.apache.flink.api.common.functions.WithConfigurationOpenContext
- getConfiguration() - Method in interface org.apache.flink.api.connector.source.SourceReaderContext
-
Gets the configuration with which Flink was started.
- getConfiguration() - Method in interface org.apache.flink.core.execution.JobStatusChangedListenerFactory.Context
- getConfiguration() - Method in class org.apache.flink.util.ParameterTool
-
Returns a
Configuration
object from thisParameterTool
. - 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
. - getCount() - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- 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. this method returns UNKNOWN, if the operating system was not successfully determined.
- 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.common.operators.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.base.EnumSerializer.EnumSerializerSnapshot
- 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 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.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
- getData() - Method in class org.apache.flink.api.connector.dsv2.FromDataSource
- 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
- getDataVolumePerTask() - Method in interface org.apache.flink.api.connector.source.DynamicParallelismInference.Context
-
Get the average size of data volume (in bytes) to expect each task instance to process.
- 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.
- getDefaultKryoSerializerClasses() - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Returns the registered default Kryo Serializer classes.
- getDefaultKryoSerializerClasses() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Returns the registered default Kryo Serializer classes.
- getDefaultKryoSerializers() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
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
- 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.dag.Transformation
-
Returns the description of this
Transformation
. - 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.
- getDescription() - Method in enum org.apache.flink.configuration.ExternalizedCheckpointRetention
- getDescription() - Method in enum org.apache.flink.configuration.JobManagerOptions.SchedulerType
- getDescription() - Method in enum org.apache.flink.configuration.MetricOptions.JobStatusMetrics
- getDescription() - Method in enum org.apache.flink.core.execution.CheckpointType
- getDescription() - Method in enum org.apache.flink.core.execution.RecoveryClaimMode
- getDescription() - Method in enum org.apache.flink.core.execution.SavepointFormatType
- 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
- getDestination() - Method in interface org.apache.flink.core.fs.PathsCopyingFileSystem.CopyRequest
-
The path where to duplicate the source file.
- getDirectoryFileName(int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
- getDirectoryFilesSize(Path, FileVisitOption...) - Static method in class org.apache.flink.util.FileUtils
-
Computes the sum of sizes of all files in the directory and it's subdirectories.
- 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(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.
- getDouble(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Double value for the given key.
- getDouble(String, double) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Double value for the given key.
- 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.
- getDoubleConfigOption(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
- 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.
- getDynamicFilteringInfo() - Method in interface org.apache.flink.api.connector.source.DynamicParallelismInference.Context
-
Get the dynamic filtering info of the source vertex.
- 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 class org.apache.flink.api.common.Plan
-
Gets the execution config object.
- 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
- getFailureType() - Method in interface org.apache.flink.core.failure.FailureEnricher.Context
-
Return the type of the failure e.g., global failure that happened in the scheduler context.
- getField() - Method in class org.apache.flink.api.java.typeutils.PojoField
- getField(int) - Method in class org.apache.flink.types.Row
-
Returns the field's content at the specified field position.
- 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(String) - Method in class org.apache.flink.types.Row
-
Returns the field's content using the specified field name.
- getField(T, int) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
-
Get field of existing instance.
- 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.
- 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.
- getFieldNumber(int) - Method in class org.apache.flink.api.common.operators.Ordering
- getFieldOrders() - Method in class org.apache.flink.api.common.operators.Ordering
- getFieldParsers() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
- 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
- getFieldTypes() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
-
Returns the field types.
- getFile() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
- getFile() - Method in class org.apache.flink.core.fs.RefCountedFile
- getFile(String) - Method in class org.apache.flink.api.common.cache.DistributedCache
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.FileSystem
- getFileBlockLocations(FileStatus, long, long) - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- 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
- getFileStatus(Path) - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- getFinishedAttempt(int) - Method in interface org.apache.flink.api.common.io.FinalizeOnMaster.FinalizationContext
-
Get the finished attempt number of subtask.
- 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
- getFlinkConfFilename() - Static method in class org.apache.flink.configuration.GlobalConfiguration
- 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.
- getFloat(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Float value for the given key.
- getFloat(String, float) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Float value for the given key.
- 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.
- getFloatConfigOption(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
- 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) - Static method in class org.apache.flink.util.ReflectionUtil
-
Extract the full type information from the given type.
- 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.
- 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
- getGlobalJobParameters() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
- getGlobalJobParameters() - Method in class org.apache.flink.api.common.ExecutionConfig
- getGlobalJobParameters() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Get global job parameters.
- getGlobalJobParameters() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
- 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() - 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.
- getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
-
Gets the value order for an input, i.e. the order of elements within a group.
- getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
-
Gets the value order for an input, i.e. the order of elements within a 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
- getHomeDirectory() - Method in interface org.apache.flink.core.fs.IFileSystem
-
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.TaskInfo
-
Gets the number of this parallel subtask.
- getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.TaskInfoImpl
- getInflaterInputStreamFactory(String) - Static method in class org.apache.flink.api.common.io.FileInputFormat
- getInfoFor(Class) - Static method in class org.apache.flink.api.common.typeinfo.LocalTimeTypeInfo
- getInfoFor(Class<T>, TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
- 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<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(TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
-
Creates a new
ObjectArrayTypeInfo
from aTypeInformation
for the component type. - getInfoSize() - Method in class org.apache.flink.api.common.io.BlockInfo
- 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.
- getInputActivityClock() - Method in interface org.apache.flink.api.common.eventtime.WatermarkGeneratorSupplier.Context
-
Returns a
RelativeClock
that hides periods when input was not active andWatermarkGenerator
could not have been executed due to execution being blocked by the runtime. - getInputFile() - Method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- getInputFile() - Method in class org.apache.flink.core.fs.RefCountedFSOutputStream
-
Gets the underlying
File
that allows to read the contents of the file. - 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(S[]) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
- getInputSplitAssigner(T[]) - Method in interface org.apache.flink.api.common.io.InputFormat
- 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(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Integer value for the given key.
- getInt(String, int) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Integer value for the given key.
- 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.
- getIntConfigOption(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
- 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
- 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
- getIOExecutor() - Method in interface org.apache.flink.core.execution.JobStatusChangedListenerFactory.Context
- getIOExecutor() - Method in interface org.apache.flink.core.failure.FailureEnricher.Context
-
Get an Executor pool for the Enrichers to run async operations that can potentially be IO-heavy.
- 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
- getJobConfiguration() - Method in class org.apache.flink.api.common.Plan
- 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.JobInfo
-
Get the ID of the job.
- getJobId() - Method in class org.apache.flink.api.common.JobInfoImpl
- 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.api.common.JobSubmissionResult
-
Returns the JobID assigned to the job by the Flink runtime.
- 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. - getJobInfo() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Get the meta information of current job.
- getJobInfo() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
- getJobInfo() - Method in interface org.apache.flink.api.connector.sink2.InitContext
-
Get the meta information of current job.
- getJobInfo() - Method in interface org.apache.flink.core.failure.FailureEnricher.Context
-
Get the meta information of current job.
- getJobName() - Method in interface org.apache.flink.api.common.JobInfo
-
Get the name of the job.
- getJobName() - Method in class org.apache.flink.api.common.JobInfoImpl
- 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() - Method in class org.apache.flink.configuration.FallbackKey
- getKey() - Method in class org.apache.flink.util.LinkedOptionalMap.KeyValue
- getKey(T) - Method in class org.apache.flink.api.java.functions.NullByteKeySelector
- 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
- getKeyFromArgs(String[], int) - Static method in class org.apache.flink.util.Utils
-
Get the key from the given args.
- 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
- getKeyTypeClass() - Method in class org.apache.flink.api.common.typeinfo.descriptor.MapTypeDescriptorImpl
- 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.
- getKeyValueClass() - Method in class org.apache.flink.api.common.typeinfo.descriptor.MapTypeDescriptorImpl
- 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
- getLastKey() - Method in class org.apache.flink.api.common.operators.util.TupleUnwrappingIterator
- 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.fs.OffsetAwareOutputStream
- getLength() - Method in class org.apache.flink.core.fs.RefCountedFileWithStream
- 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<S>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
-
Creates (or restores) a list state.
- 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.
- getListTypeInfo() - Method in class org.apache.flink.api.common.typeinfo.descriptor.ListTypeDescriptorImpl
- 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
- getLocalValue() - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- 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(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(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Long value for the given key.
- getLong(String, long) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Long value for the given key.
- 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.
- getLongConfigOption(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
- 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.sink2.WriterInitContext
-
Returns the mailbox executor that allows to execute
Runnable
s inside the task thread in between record processing. - getMainValue() - Method in enum org.apache.flink.configuration.RestartStrategyOptions.RestartStrategyType
- 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.
- getMapTypeInfo() - Method in class org.apache.flink.api.common.typeinfo.descriptor.MapTypeDescriptorImpl
- getMaterializationMaxAllowedFailures() - Method in class org.apache.flink.api.common.ExecutionConfig
- getMaxAllowedWatermarkDrift() - Method in class org.apache.flink.api.common.eventtime.WatermarkAlignmentParams
- 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.TaskInfo
-
Gets the max parallelism aka the max number of subtasks.
- getMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.TaskInfoImpl
- 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.
- 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 interface org.apache.flink.core.failure.FailureEnricher.Context
-
Get the metric group of the JobMaster.
- 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
- getMultiParameter(String) - Method in class org.apache.flink.util.MultipleParameterTool
-
Returns the Collection of String values for the given key.
- getMultiParameterRequired(String) - Method in class org.apache.flink.util.MultipleParameterTool
-
Returns the Collection of String values for the given key.
- 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() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerUtil.IntermediateCompatibilityResult
- 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(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
- getNestedSerializers(S) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
-
Gets the nested serializers from the outer serializer.
- 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() - Method in class org.apache.flink.core.execution.DetachedJobExecutionResult
- 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.
- 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
- getNextRegistrationId() - Method in interface org.apache.flink.api.java.typeutils.runtime.kryo.ChillSerializerRegistrar
-
Returns the registration ID that immediately follows the last registered serializer.
- getNextRetryStrategy() - Method in class org.apache.flink.util.concurrent.ExponentialBackoffRetryStrategy
- getNextRetryStrategy() - Method in class org.apache.flink.util.concurrent.FixedRetryStrategy
- getNextRetryStrategy() - Method in class org.apache.flink.util.concurrent.IncrementalDelayRetryStrategy
- 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.
- 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
- 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.TaskInfo
-
Gets the parallelism with which the parallel task runs.
- getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.TaskInfoImpl
- getNumberOfParameters() - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns number of parameters in
AbstractParameterTool
. - getNumberOfParameters() - Method in class org.apache.flink.util.MultipleParameterTool
-
Returns number of parameters in
ParameterTool
. - getNumberOfParameters() - Method in class org.apache.flink.util.ParameterTool
-
Returns number of parameters in
ParameterTool
. - 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.AbstractAutoCloseableRegistry
- getNumberOfRemoteAssignments() - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
- getNumberOfRetries() - Method in interface org.apache.flink.api.connector.sink2.Committer.CommitRequest
-
Returns how many times this particular committable has been retried.
- 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 class org.apache.flink.util.concurrent.IncrementalDelayRetryStrategy
- getNumRemainingRetries() - Method in interface org.apache.flink.util.concurrent.RetryStrategy
- getNumSplits() - Method in class org.apache.flink.api.common.io.FileInputFormat
- getNumTasks() - Method in class org.apache.flink.api.common.io.FirstAttemptInitializationContext
- getNumTasks() - Method in interface org.apache.flink.api.common.io.OutputFormat.InitializationContext
-
Gets the parallelism with which the parallel task runs.
- getObjectReuseEnabled() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
- getOffHeapBuffer() - Method in class org.apache.flink.core.memory.MemorySegment
-
Returns the off-heap buffer of memory segments.
- 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(boolean) - Method in enum org.apache.flink.util.TernaryBoolean
-
Gets the boolean value corresponding to this value.
- getOrDefault(CompletableFuture<T>, T) - Static method in class org.apache.flink.util.concurrent.FutureUtils
- 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
- getOutputKeys() - Method in interface org.apache.flink.core.failure.FailureEnricher
-
Method to list all the label Keys the enricher can associate with Values in case of a failure
processFailure
. - 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 aTypeInformation
. - 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 interface org.apache.flink.api.common.io.FinalizeOnMaster.FinalizationContext
-
Get the parallelism with which the format or functions was run.
- 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
. - getParallelismInferenceUpperBound() - Method in interface org.apache.flink.api.connector.source.DynamicParallelismInference.Context
-
Get the upper bound for the inferred parallelism.
- 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(ReadableConfig) - 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.
- getPeriodicCompactionTime() - Method in class org.apache.flink.api.common.state.StateTtlConfig.RocksdbCompactFilterCleanupStrategy
- getPeriodicMaterializeIntervalMillis() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
- getPeriodicMaterializeIntervalMillis() - Method in class org.apache.flink.api.common.ExecutionConfig
- 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
- getPort() - Method in class org.apache.flink.util.NetUtils.Port
- getPortRangeFromString(String) - Static method in class org.apache.flink.util.NetUtils
-
Returns an iterator over available ports defined by the range definition.
- getPortsIterator() - Method in class org.apache.flink.util.PortRange
- 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
- getPos() - Method in class org.apache.flink.core.fs.local.LocalRecoverableFsDataOutputStream
- getPos() - Method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- 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.sink2.WriterInitContext
-
Returns a
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. - getProperties() - Method in class org.apache.flink.util.ParameterTool
-
Returns a
Properties
object from thisParameterTool
. - 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
-
Deprecated.The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.
- 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.
- getRandomTempDirectory(Configuration) - Static method in class org.apache.flink.configuration.ConfigurationUtils
-
Picks a temporary directory randomly from the given configuration.
- 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.RefCountedBufferingFileStream
- getReferenceCounter() - Method in class org.apache.flink.core.fs.RefCountedFile
- 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 interface org.apache.flink.api.common.serialization.SerializerConfig
-
Returns the registered Kryo types.
- getRegisteredKryoTypes() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Returns the registered Kryo types.
- getRegisteredPojoTypes() - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Returns the registered POJO types.
- getRegisteredPojoTypes() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
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.
- getRegisteredTypeInfoFactories() - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Returns the registered type info factories.
- getRegisteredTypeInfoFactories() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Returns the registered type info factories.
- getRegisteredTypesWithKryoSerializerClasses() - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Returns the registered types with their Kryo Serializer classes.
- getRegisteredTypesWithKryoSerializerClasses() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Returns the registered types with their Kryo Serializer classes.
- getRegisteredTypesWithKryoSerializers() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
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
- getRequired(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the String value for the given key.
- getResource(String) - Method in class org.apache.flink.core.classloading.ComponentClassLoader
- getResource(String) - Method in class org.apache.flink.util.ChildFirstClassLoader
- getResource(String) - Method in class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- getResourceAsStream(String) - Method in class org.apache.flink.core.classloading.ComponentClassLoader
- getResources(String) - Method in class org.apache.flink.core.classloading.ComponentClassLoader
- getResources(String) - Method in class org.apache.flink.util.ChildFirstClassLoader
- getResources(String) - Method in class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- getRestartStrategyDescription() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
- getRestartStrategyDescription(Configuration) - Static method in class org.apache.flink.api.common.RestartStrategyDescriptionUtils
-
Returns a descriptive string of the restart strategy configured in the given Configuration object.
- getRestoredCheckpointId() - Method in interface org.apache.flink.api.connector.sink2.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 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 class org.apache.flink.util.concurrent.IncrementalDelayRetryStrategy
- 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() - Method in class org.apache.flink.api.common.ExecutionConfig
- 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
- getSerializedException() - Method in exception org.apache.flink.util.SerializedThrowable
- getSerializer() - Method in class org.apache.flink.api.common.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() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
- getSerializer(Kryo) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
- getSerializerClass() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
- getSerializerConfig() - Method in class org.apache.flink.api.common.ExecutionConfig
- getSerializerDefinitionType() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
- getSerializerTree(TypeInformation<T>) - Static method in class org.apache.flink.util.Utils
-
Debugging utility to understand the hierarchy of serializers created by the Java API.
- 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.
- getShort(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Short value for the given key.
- getShort(String, short) - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the Short value for the given key.
- 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.
- getSize() - Method in interface org.apache.flink.core.fs.PathsCopyingFileSystem.CopyRequest
-
The size in bytes of the requested file to copy.
- 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
- getSource() - Method in interface org.apache.flink.core.fs.PathsCopyingFileSystem.CopyRequest
-
The path of the source file to duplicate.
- 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.
- getStream() - Method in class org.apache.flink.core.fs.RefCountedFileWithStream
- 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
-
Returns the value associated with the given key as a string.
- getString(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 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
- getSupportedCompressionFormats() - Static method in class org.apache.flink.api.common.io.FileInputFormat
- getSynchronizationLock() - Method in class org.apache.flink.util.AbstractAutoCloseableRegistry
-
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
- getTargetPathIfContainsSymbolicPath(Path) - Static method in class org.apache.flink.util.FileUtils
-
Get a target path(the path that replaced symbolic links with linked path) if the original path contains symbolic path, return the original path otherwise.
- 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
- getTaskInfo() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Get the meta information of current task.
- getTaskInfo() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
- getTaskInfo() - Method in interface org.apache.flink.api.connector.sink2.InitContext
-
Get the meta information of current task.
- getTaskName() - Method in interface org.apache.flink.api.common.TaskInfo
-
Gets the task name.
- getTaskName() - Method in class org.apache.flink.api.common.TaskInfoImpl
- getTaskNameWithSubtasks() - Method in interface 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 beTaskInfo.getNumberOfParallelSubtasks()
, and 1 would beTaskInfo.getAttemptNumber()
. - getTaskNameWithSubtasks() - Method in class org.apache.flink.api.common.TaskInfoImpl
- getTaskNumber() - Method in class org.apache.flink.api.common.io.FirstAttemptInitializationContext
- getTaskNumber() - Method in interface org.apache.flink.api.common.io.OutputFormat.InitializationContext
-
Gets the number of this parallel subtask.
- getTaskOffHeapMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
- getTaskOffHeapMemory() - Method in class org.apache.flink.api.common.operators.SlotSharingGroup
- 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(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
- getTemplateTypes(ParameterizedType) - 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.
- getTimeToLive() - Method in class org.apache.flink.api.common.state.StateTtlConfig
- 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
- getTokens() - Method in class org.apache.flink.core.security.token.DelegationTokenProvider.ObtainedDelegationTokens
- 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
Transformation
s of thisTransformation
. - getTransitivePredecessorsInternal() - Method in class org.apache.flink.api.dag.Transformation
-
Returns all transitive predecessor
Transformation
s of thisTransformation
. - getTtlConfig() - Method in class org.apache.flink.api.common.state.StateDescriptor
- getTtlTimeCharacteristic() - Method in class org.apache.flink.api.common.state.StateTtlConfig
- getTupleClass() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
- 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
- getType(int) - Method in class org.apache.flink.api.common.operators.Ordering
- 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(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
- getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
- 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(String) - 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
- 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.descriptor.BasicTypeDescriptorImpl
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.descriptor.ListTypeDescriptorImpl
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.descriptor.MapTypeDescriptorImpl
- getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.descriptor.ValueTypeDescriptorImpl
- 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.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() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
- 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(S) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
-
Gets the type class from the corresponding serializer.
- 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(Field) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Returns the type information factory for an annotated field.
- 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.
- getTypeInformation() - Method in class org.apache.flink.api.java.typeutils.PojoField
- getTypes() - Method in class org.apache.flink.api.common.operators.Ordering
- 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
- getUnrequestedParameters() - Method in class org.apache.flink.util.AbstractParameterTool
-
Returns the set of parameter names which have not been requested with
AbstractParameterTool.has(String)
or one of theget
methods. - 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.
- getUpdatedSplitForIterator(NumberSequenceIterator) - Method in class org.apache.flink.api.connector.source.lib.NumberSequenceSource.NumberSequenceSplit
- getUpdateInterval() - Method in class org.apache.flink.api.common.eventtime.WatermarkAlignmentParams
- 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
- getUri() - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- getURLs() - Method in class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- getUserClassLoader() - Method in interface org.apache.flink.core.execution.JobStatusChangedListenerFactory.Context
-
User classloader for the flink application.
- getUserClassLoader() - Method in interface org.apache.flink.core.failure.FailureEnricher.Context
-
Get the user
ClassLoader
used for code generation, UDF loading and other operations requiring reflections on user code. - 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 interface org.apache.flink.api.connector.sink2.WriterInitContext
-
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. - getUserCodeClassLoaderInfo(ClassLoader) - Static method in class org.apache.flink.util.ClassLoaderUtil
-
Gets information about URL class loaders.
- getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
- getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
- getUserCodeObject() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
-
Gets the user code object.
- getUserCodeObject(Class<? super T>, ClassLoader) - 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(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.
- 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.
- getValidUntil() - Method in class org.apache.flink.core.security.token.DelegationTokenProvider.ObtainedDelegationTokens
- getValue() - Method in class org.apache.flink.api.common.resources.Resource
- 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
- 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
- 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.common.typeinfo.descriptor.ValueTypeDescriptorImpl
- getValueTypeInfo() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
-
Gets the type information for the values in the map
- getVersion() - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
-
Gets the version with which this serializer serializes.
- getVersion() - Method in class org.apache.flink.core.io.SimpleVersionedSerializerAdapter
- getVersion() - Method in interface org.apache.flink.core.io.Versioned
-
Returns the version number of the object.
- getWatermarkGroup() - Method in class org.apache.flink.api.common.eventtime.WatermarkAlignmentParams
- 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
- getWorkingDirectory() - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- getWrappedFunction() - Method in class org.apache.flink.api.common.functions.WrappingFunction
- getWrappedSink() - Method in class org.apache.flink.api.connector.dsv2.WrappedSink
- getWrappedSource() - Method in class org.apache.flink.api.connector.dsv2.WrappedSource
- getWriteMode() - Method in class org.apache.flink.api.common.io.FileOutputFormat
- getWriterStateSerializer() - Method in interface org.apache.flink.api.connector.sink2.SupportsWriterState
-
Any stateful sink needs to provide this state serializer and implement
snapshotState(long)
properly. - GLOBAL - org.apache.flink.core.failure.FailureEnricher.Context.FailureType
-
The failure has occurred in the scheduler context and can't be tracked back to a particular task.
- GLOBAL_JOB_PARAMETERS - Static variable in class org.apache.flink.configuration.PipelineOptions
- 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(FT, UnaryOperatorInformation<IN, OUT>, int[], 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>, int[], 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
- GroupReduceOperatorBase(UserCodeWrapper<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
- 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
- GuavaRateLimiter - Class in org.apache.flink.api.connector.source.util.ratelimit
-
An implementation of
RateLimiter
based on Guava's RateLimiter. - GuavaRateLimiter(double) - Constructor for class org.apache.flink.api.connector.source.util.ratelimit.GuavaRateLimiter
- 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_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.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_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
-
ZooKeeper root path (ZNode) for job graphs.
- 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_ROOT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
-
The root path under which Flink stores its entries in ZooKeeper.
- 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(String, Throwable) - Method in interface org.apache.flink.core.state.StateFutureImpl.AsyncFrameworkExceptionHandler
-
Handles an exception thrown by callback.
- 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, int, SourceEvent) - Method in interface org.apache.flink.api.connector.source.SupportsHandleExecutionAttemptSourceEvent
-
Handles a custom source event from the source reader.
- 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. - has(String) - Method in class org.apache.flink.util.AbstractParameterTool
-
Check if value is set.
- has(String) - Method in class org.apache.flink.util.MultipleParameterTool
-
Check if value is set.
- has(String) - Method in class org.apache.flink.util.ParameterTool
-
Check if value is set.
- 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.
- 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 interface org.apache.flink.api.common.serialization.SerializerConfig
-
Checks whether generic types are supported.
- hasGenericTypesDisabled() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
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(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(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(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(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
- 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.base.BasicTypeComparator
- 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(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 - org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
- HASH - org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
-
Use a hash-based strategy.
- 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.serialization.SerializerConfigImpl
- hashCode() - Method in class org.apache.flink.api.common.state.StateDescriptor
- 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.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.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.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.NullableSerializer
- hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
- 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.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.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.FileSystem.FSKey
- 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.MultipleParameterTool
- 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.ParameterTool
- hashCode() - Method in class org.apache.flink.util.SerializedValue
- hashCode() - Method in class org.apache.flink.util.StringBasedID
- hashCode() - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- 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.api.common.operators.util.TupleUnwrappingIterator
- 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.
- hasWindowsDrive() - Method in class org.apache.flink.core.fs.Path
-
Checks if the provided path string contains a windows drive letter.
- 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)
withGlobalConfiguration.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_JOBMANAGER_LOG_URL_PATTERN - Static variable in class org.apache.flink.configuration.HistoryServerOptions
-
Pattern of the log URL of JobManager.
- HISTORY_SERVER_RETAINED_JOBS - Static variable in class org.apache.flink.configuration.HistoryServerOptions
- HISTORY_SERVER_TASKMANAGER_LOG_URL_PATTERN - Static variable in class org.apache.flink.configuration.HistoryServerOptions
-
Pattern of the log URL of TaskManager.
- 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.
- 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
- HYBRID_PARTITION_DATA_CONSUME_CONSTRAINT - Static variable in class org.apache.flink.configuration.JobManagerOptions
I
- ICloseableRegistry - Interface in org.apache.flink.core.fs
-
This class allows to register instances of
Closeable
, which are all closed if this registry is closed. - id - 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.
- IFileSystem - Interface in org.apache.flink.core.fs
-
Interface of all file systems used by Flink.
- 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
- IGNORE - org.apache.flink.configuration.TaskManagerOptions.SystemOutMode
-
Ignore all
System.out
andSystem.err
directly. - ignoreFn() - Static method in class org.apache.flink.util.function.FunctionUtils
-
Consumer which ignores the input.
- IgnoreShutdownRejectedExecutionHandler - Class in org.apache.flink.util.concurrent
-
Rejected executions are ignored or logged in debug if the executor is
shutdown
. - IgnoreShutdownRejectedExecutionHandler() - Constructor for class org.apache.flink.util.concurrent.IgnoreShutdownRejectedExecutionHandler
- IgnoreShutdownRejectedExecutionHandler(Logger) - Constructor for class org.apache.flink.util.concurrent.IgnoreShutdownRejectedExecutionHandler
- IllegalConfigurationException - Exception in org.apache.flink.configuration
-
An
IllegalConfigurationException
is thrown when the values in a givenConfiguration
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.
- 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.
- INCOMPATIBLE - org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot.OuterSchemaCompatibility
- 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 - org.apache.flink.core.execution.CheckpointType
- INCREMENTAL_CHECKPOINTS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
Option whether to create incremental checkpoints, if possible.
- IncrementalDelayRetryStrategy - Class in org.apache.flink.util.concurrent
-
An implementation of
RetryStrategy
that retries at an incremental delay with a cap. - IncrementalDelayRetryStrategy(int, Duration, Duration, Duration) - Constructor for class org.apache.flink.util.concurrent.IncrementalDelayRetryStrategy
- 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
- inDirectories(File...) - Static method in class org.apache.flink.core.fs.RefCountedTmpFileCreator
- inferParallelism(DynamicParallelismInference.Context) - Method in interface org.apache.flink.api.connector.source.DynamicParallelismInference
-
The method is invoked on the master (JobManager) before the initialization of the source vertex.
- 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
- init(Configuration) - Method in interface org.apache.flink.core.security.token.DelegationTokenProvider
-
Called by DelegationTokenManager to initialize provider after construction.
- init(Configuration) - Method in interface org.apache.flink.core.security.token.DelegationTokenReceiver
-
Called to initialize receiver after construction.
- InitContext - Interface in org.apache.flink.api.connector.sink2
-
Common interface which exposes runtime info for creating
SinkWriter
andCommitter
objects. - initDefaultsFromConfiguration(Configuration) - Static method in class org.apache.flink.api.common.io.FileOutputFormat
-
Initialize defaults for output format.
- INITIAL_CHECKPOINT_ID - Static variable in interface org.apache.flink.api.connector.sink2.InitContext
-
The first checkpoint id when an application is started and not recovered from a previously taken checkpoint or savepoint.
- INITIAL_REGISTRATION_TIMEOUT - Static variable in class org.apache.flink.configuration.ClusterOptions
- initialize(Configuration) - Static method in class org.apache.flink.core.fs.FileSystem
-
Deprecated.use
FileSystem.initialize(Configuration, PluginManager)
instead. - 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
OutputFormat
s 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.
- initializeSerializerUnlessSet(SerializerFactory) - Method in class org.apache.flink.api.common.state.StateDescriptor
- 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
- INITIALIZING - org.apache.flink.api.common.JobStatus
-
The job has been received by the Dispatcher, and is waiting for the job manager to receive leadership and to be created.
- initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.FileSystem
- initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - Method in interface org.apache.flink.core.fs.IFileSystem
-
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. a link.
- inner - Variable in class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
- 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
- InnerJoinOperatorBase(UserCodeWrapper<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.
- 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
InputSplit
s 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
InputSplit
s that define portions of data to be produced byInputFormat
s. - 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 asFSDataInputStream
. - 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
-
OutputFormat
s 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
- INSERT - org.apache.flink.types.RowKind
-
Insertion operation.
- insertOrReplace(BT) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
- INSTANCE - org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
- INSTANCE - Static variable in class org.apache.flink.api.common.functions.DefaultOpenContext
- 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.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(Class<T>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Creates a new instance of the given class.
- instantiate(Class<T>, Class<? super T>) - Static method in class org.apache.flink.util.InstantiationUtil
-
Creates a new instance of the given class.
- 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
. - 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 certain serialVersionUID mismatches. - 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
andInteger
. - 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
- inTempFolder(String) - Static method in class org.apache.flink.util.FileLock
-
Initialize a FileLock using a file located inside temp folder.
- INTERCEPT_USER_SYSTEM_EXIT - Static variable in class org.apache.flink.configuration.ClusterOptions
- InternalCheckpointListener - Interface in org.apache.flink.api.common.state
-
The internal checkpoint listener add another
InternalCheckpointListener.notifyCheckpointSubsumed(long)
interface for internal usage. - InternalStateFuture<T> - Interface in org.apache.flink.core.state
-
The Internal definition of
StateFuture
, add some method that will be used by framework. - 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
(andint
, 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
- invalidateClusterDataset(AbstractID, Configuration, ClassLoader) - Method in interface org.apache.flink.core.execution.CacheSupportedPipelineExecutor
-
Invalidate the cluster dataset with the given id.
- 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. descending.
- 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. in particular, this method makes sure that IPv6 addresses have the proper formatting to be included in URLs.
- 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
- isAvailable() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
- isAvailable() - Method in interface org.apache.flink.api.connector.source.SourceReader
-
Returns a future that signals that data is available from the reader.
- isAvailable() - Method in class org.apache.flink.api.connector.source.util.ratelimit.RateLimitedSourceReader
- isAvroSpecificRecord(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.AvroUtils
- 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(R) - Method in class org.apache.flink.util.AbstractAutoCloseableRegistry
- isClosed() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
- isClosed() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
- isClosed() - Method in interface org.apache.flink.core.fs.ICloseableRegistry
- isClosed() - Method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- isClosed() - Method in class org.apache.flink.core.fs.RefCountedFSOutputStream
-
Checks if the file is closed for writes.
- isClosed() - Method in class org.apache.flink.util.AbstractAutoCloseableRegistry
- isClosed() - Method in class org.apache.flink.util.ResourceGuard
-
Returns true if the resource guard is closed, i.e. after
ResourceGuard.close()
was called. - 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
TypeSerializerSchemaCompatibility.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
TypeSerializerSchemaCompatibility.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
TypeSerializerSchemaCompatibility.Type.COMPATIBLE_WITH_RECONFIGURED_SERIALIZER
. - isCompletedNormally(CompletableFuture<?>) - Static method in class org.apache.flink.util.concurrent.FutureUtils
- 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
- isConverged(int, T) - Method in interface org.apache.flink.api.common.aggregators.ConvergenceCriterion
-
Decide whether the iterative algorithm has converged
- isCurrentTimeMetricsEnabled() - Method in class org.apache.flink.configuration.MetricOptions.JobStatusMetricsSettings
- isDeferrable() - Method in class org.apache.flink.api.common.operators.MailOptionsImpl
- 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
- isDistributedFS() - Method in interface org.apache.flink.core.fs.IFileSystem
-
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.core.state.CompletedStateFuture
- isDone() - Method in interface org.apache.flink.core.state.InternalStateFuture
-
Returns
true
if completed in any fashion: normally, exceptionally, or via cancellation. - isDone() - Method in class org.apache.flink.core.state.StateFutureImpl
- isDone() - Method in class org.apache.flink.util.concurrent.NeverCompleteFuture
- isEmpty() - Method in class org.apache.flink.api.common.operators.Keys
- isEmpty() - Method in class org.apache.flink.types.ListValue
- isEmpty() - Method in class org.apache.flink.types.MapValue
- isEmptyOrAllElementsNull(Collection<?>) - Static method in class org.apache.flink.util.CollectionUtil
-
Returns true if the given collection is empty or contains only null elements.
- isEnabled() - Method in class org.apache.flink.api.common.eventtime.WatermarkAlignmentParams
- isEnabled() - Method in class org.apache.flink.api.common.state.StateTtlConfig
- isEndOfStream(String) - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
- 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(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, Path) - 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
- isForceAvroEnabled() - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Returns whether the Apache Avro is the serializer for POJOs.
- isForceAvroEnabled() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Returns whether the Apache Avro is the serializer for POJOs.
- isForceKryoAvroEnabled() - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Returns whether forces Flink to register Apache Avro classes in Kryo serializer.
- isForceKryoAvroEnabled() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
- isForceKryoEnabled() - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Returns whether Kryo is the serializer for POJOs.
- isForceKryoEnabled() - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Returns whether Kryo is the serializer for POJOs.
- isForceRpcInvocationSerializationEnabled(Configuration) - Static method in class org.apache.flink.configuration.RpcOptions
- 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
TypeSerializerSchemaCompatibility.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.
- isNoOutputUntilEndOfInput() - Method in class org.apache.flink.api.common.attribute.Attribute
- 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
-
Returns true if the given collection is null or empty.
- 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.
- isObjectReuseEnabled() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
-
Check if object reuse is enabled.
- isObjectReuseEnabled() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
- isObjectReuseEnabled() - Method in interface org.apache.flink.api.connector.sink2.WriterInitContext
-
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.
- isOnlyConsumeFinishedPartition() - Method in enum org.apache.flink.configuration.JobManagerOptions.HybridPartitionDataConsumeConstraint
- 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(TypeSerializerSnapshot)
instead. - isOverdue() - Method in class org.apache.flink.api.common.time.Deadline
-
Determines whether the deadline is in the past, i.e. whether the time left is zero or negative.
- isOwned() - Method in class org.apache.flink.util.Reference
- isParallelismConfigured() - Method in class org.apache.flink.api.dag.Transformation
- isPeriodicMaterializeEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
- 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. not abstract or an interface, and not a primitive type.
- 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
-
Deprecated.The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.
- isReactiveModeEnabled(Configuration) - Static method in class org.apache.flink.configuration.ClusterOptions
- isRecord(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Determine whether the given class is a valid Java record.
- 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
- isStateMetricsEnabled() - Method in class org.apache.flink.configuration.MetricOptions.JobStatusMetricsSettings
- isTerminalState() - Method in enum org.apache.flink.api.common.JobStatus
-
Checks whether this state is locally terminal.
- isTotalTimeMetricsEnabled() - Method in class org.apache.flink.configuration.MetricOptions.JobStatusMetricsSettings
- 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
- isValid() - Method in class org.apache.flink.util.FileLock
-
Check whether a FileLock is actually holding the lock.
- 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(FieldList) - Method in class org.apache.flink.api.common.operators.util.FieldList
- isValidSubset(FieldSet) - 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
- 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 - Variable in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
-
The iterator producing data.
- 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 class org.apache.flink.api.common.operators.util.TupleUnwrappingIterator
- 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 anIteratorSourceSplit
. - IteratorSourceReader(SourceReaderContext) - Constructor for class org.apache.flink.api.connector.source.lib.util.IteratorSourceReader
- IteratorSourceReaderBase<E,O,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 anIteratorSourceSplit
. - IteratorSourceReaderBase(SourceReaderContext) - Constructor for class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
- 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
- JacksonMapperFactory - Class in org.apache.flink.util.jackson
-
Factory for Jackson mappers.
- 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 theObjectInputStream
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_ID - Static variable in class org.apache.flink.util.MdcUtils
- 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_IO_POOL_SIZE - Static variable in class org.apache.flink.configuration.JobManagerOptions
- JOB_MANAGER_PROCESS_WORKING_DIR_BASE - Static variable in class org.apache.flink.configuration.ClusterOptions
- JOB_MANAGER_RESOURCE_ID - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
The JobManager's ResourceID.
- JOB_RECOVERY_ENABLED - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- JOB_RECOVERY_PREVIOUS_WORKER_RECOVERY_TIMEOUT - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- JOB_RECOVERY_SNAPSHOT_MIN_PAUSE - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- JOB_RESULT_MESSAGE - Static variable in class org.apache.flink.core.execution.DetachedJobExecutionResult
- JOB_STATUS_CHANGED_LISTENERS - Static variable in class org.apache.flink.configuration.DeploymentOptions
- JOB_STATUS_METRICS - Static variable in class org.apache.flink.configuration.MetricOptions
-
Controls which job status metrics will be exposed.
- 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_STORE_TYPE - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
Config parameter determining the job store implementation in session cluster.
- 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.
- JobEventStoreOptions - Class in org.apache.flink.configuration
-
Configuration options for the job events.
- 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.
- JobExecutionStatusEvent - Interface in org.apache.flink.core.execution
-
Job execution status event.
- jobId() - Method in class org.apache.flink.core.execution.DefaultJobExecutionStatusEvent
- jobId() - Method in interface org.apache.flink.core.execution.JobStatusChangedEvent
- 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(byte[]) - Constructor for class org.apache.flink.api.common.JobID
-
Creates a new JobID from the given byte sequence.
- JobID(long, long) - Constructor for class org.apache.flink.api.common.JobID
-
Creates a new JobID, using the given lower and upper parts.
- JobInfo - Interface in org.apache.flink.api.common
-
The
JobInfo
represents the meta information of current job. - JobInfoImpl - Class in org.apache.flink.api.common
-
The default implementation of
JobInfo
. - JobInfoImpl(JobID, String) - Constructor for class org.apache.flink.api.common.JobInfoImpl
- 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.HybridPartitionDataConsumeConstraint - Enum in org.apache.flink.configuration
-
Constraints of upstream hybrid partition data consumption by downstream.
- JobManagerOptions.JobStoreType - Enum in org.apache.flink.configuration
-
Type of job store implementation.
- 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.
- jobName() - Method in class org.apache.flink.core.execution.DefaultJobExecutionStatusEvent
- jobName() - Method in interface org.apache.flink.core.execution.JobStatusChangedEvent
- JobStatus - Enum in org.apache.flink.api.common
-
Possible states of a job once it has been accepted by the dispatcher.
- JobStatusChangedEvent - Interface in org.apache.flink.core.execution
-
Basic job status event.
- JobStatusChangedListener - Interface in org.apache.flink.core.execution
-
When job is created or its status is changed, Flink will generate job event and notify job status changed listener.
- JobStatusChangedListenerFactory - Interface in org.apache.flink.core.execution
-
Factory for job status changed listener.
- JobStatusChangedListenerFactory.Context - Interface in org.apache.flink.core.execution
- JobStatusChangedListenerUtils - Class in org.apache.flink.core.execution
-
Util class for
JobStatusChangedListener
. - JobStatusChangedListenerUtils() - Constructor for class org.apache.flink.core.execution.JobStatusChangedListenerUtils
- JobStatusHook - Interface in org.apache.flink.core.execution
-
Hooks on job status changing.
- 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) - Method in interface org.apache.flink.api.common.functions.JoinFunction
-
The join method, called once per joined pair of elements.
- join(IN1, IN2) - Method in class org.apache.flink.api.common.functions.RichJoinFunction
- 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, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichFlatJoinFunction
- 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(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(UserCodeWrapper<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.RpcOptions
-
Exit JVM on fatal Pekko 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_HADOOP_FILESYSTEMS_TO_ACCESS - 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
- KERBEROS_RELOGIN_PERIOD - 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. was
null
. - KeyFieldOutOfBoundsException() - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
-
Constructs an
KeyFieldOutOfBoundsException
withnull
as its error 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
- KeyFieldOutOfBoundsException(String) - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
-
Constructs an
KeyFieldOutOfBoundsException
with the specified detail message. - 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.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
- 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.
- 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<?>, 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.
- 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>, SerializerConfig) - 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.
- 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.StateLatencyTrackOptions
- LATENCY_TRACK_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.StateLatencyTrackOptions
- LATENCY_TRACK_SAMPLE_INTERVAL - Static variable in class org.apache.flink.configuration.StateLatencyTrackOptions
- LATENCY_TRACK_STATE_NAME_AS_VARIABLE - Static variable in class org.apache.flink.configuration.StateLatencyTrackOptions
- left() - Method in class org.apache.flink.types.Either
-
Retrieve the Left value of Either.
- left() - Method in class org.apache.flink.types.Either.Left
- left() - Method in class org.apache.flink.types.Either.Right
- Left(L) - Constructor for class org.apache.flink.types.Either.Left
- Left(L) - Static method in class org.apache.flink.types.Either
-
Create a Left value of Either
- LEFT - org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
- LEGACY - org.apache.flink.core.execution.RecoveryClaimMode
-
Deprecated.
- LEGACY_FLINK_CONF_FILENAME - Static variable in class org.apache.flink.configuration.ConfigurationFileMigrationUtils
-
This file is only used to help users migrate their legacy configuration files to the new configuration file `config.yaml` starting from Flink 2.0.
- LegacySerializerSnapshotTransformer<T> - Interface in org.apache.flink.api.common.typeutils
-
This interface provides a way for
TypeSerializer
s to transform a legacyTypeSerializerSnapshot
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.
- 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, 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(FileSystem, int, long, long) - Constructor for class org.apache.flink.core.fs.LimitedConnectionsFileSystem
-
Creates a new output connection limiting file system.
- 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) - Static method in class org.apache.flink.configuration.description.LinkElement
-
Creates a link with a given url.
- link(String, String) - Static method in class org.apache.flink.configuration.description.LinkElement
-
Creates a link with a given url and description.
- 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
-
The result of merging two
LinkedOptionalMap
s usingLinkedOptionalMap.mergeRightIntoLeft(LinkedOptionalMap, LinkedOptionalMap)
. - 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
. - LINUX - org.apache.flink.util.OperatingSystem
- 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.
- LIST - org.apache.flink.api.common.state.StateDescriptor.Type
- LIST(TypeInformation<E>) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for a Java
List
. - 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
- listCompletedClusterDatasetIds(Configuration, ClassLoader) - Method in interface org.apache.flink.core.execution.CacheSupportedPipelineExecutor
-
Return a set of ids of the completed cluster dataset.
- 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 thefileFilter
. - 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.
- ListStateDescriptor<T> - Class in org.apache.flink.api.common.state
-
A
StateDescriptor
forListState
. - 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
- listStatus(Path) - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- ListTypeDescriptorImpl<T> - Class in org.apache.flink.api.common.typeinfo.descriptor
-
Implementation of
TypeDescriptor
to createListTypeInfo
. - ListTypeDescriptorImpl(Class<T>) - Constructor for class org.apache.flink.api.common.typeinfo.descriptor.ListTypeDescriptorImpl
- ListTypeDescriptorImpl(TypeDescriptor<T>) - Constructor for class org.apache.flink.api.common.typeinfo.descriptor.ListTypeDescriptorImpl
- 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) - Method in class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- loadClass(String, boolean) - Method in class org.apache.flink.core.classloading.ComponentClassLoader
- loadClass(String, boolean) - Method in class org.apache.flink.util.FlinkUserCodeClassLoader
- loadClass(String, boolean) - Method in class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- 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(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.
- loadConfiguration(Configuration) - Static method in class org.apache.flink.configuration.GlobalConfiguration
-
Loads the global configuration and adds the given dynamic properties configuration.
- loadLegacyYAMLResource(File) - Static method in class org.apache.flink.configuration.ConfigurationFileMigrationUtils
-
Loads a YAML-file of key-value pairs.
- loadYamlFile(File) - Static method in class org.apache.flink.configuration.YamlParserUtils
-
Loads the contents of the given YAML file into a map.
- LOCAL_BACKUP_ENABLED - Static variable in class org.apache.flink.configuration.CheckpointingOptions
-
This option configures local backup for the state backend, which indicates whether to make backup checkpoint on local disk.
- 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_RECOVERY - Static variable in class org.apache.flink.configuration.StateRecoveryOptions
-
This option configures local recovery for the state backend, which indicates whether to recovery from local snapshot.
- 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_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 givenFile
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 givenFile
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 theFileStatus
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 givenFile
object. - LocalFileSystem - Class in org.apache.flink.core.fs.local
-
The class
LocalFileSystem
is an implementation of theFileSystem
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
- LocalRecoverableFsDataOutputStream - Class in org.apache.flink.core.fs.local
-
A
RecoverableFsDataOutputStream
for theLocalFileSystem
. - LocalRecoverableFsDataOutputStream(File, File) - Constructor for class org.apache.flink.core.fs.local.LocalRecoverableFsDataOutputStream
- LocalRecoverableWriter - Class in org.apache.flink.core.fs.local
-
A
RecoverableWriter
for theLocalFileSystem
. - 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 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 single 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 multiple 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 aFileStatus
that contains additionally the location information of the file directly. - LOG - org.apache.flink.configuration.ClusterOptions.UncaughtExceptionHandleMode
- LOG - org.apache.flink.configuration.ClusterOptions.UserSystemExitMode
- LOG - org.apache.flink.configuration.TaskManagerOptions.SystemOutMode
-
Redirect all
System.out
andSystem.err
to LOG. - LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.RpcOptions
-
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).
- 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.
- logExceptionIfExcepted(Throwable, Logger) - Static method in class org.apache.flink.util.ExceptionUtils
-
Log the given exception in debug level if it is a
FlinkExpectedException
. - LONG - Static variable in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for both a primitive
long
andLong
. - 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
- 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 (asLongValue
)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 anAggregator
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_DURATION - Static variable in class org.apache.flink.configuration.RpcOptions
-
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.
- LZ4 - org.apache.flink.configuration.NettyShuffleEnvironmentOptions.CompressionCodec
- LZO - org.apache.flink.configuration.NettyShuffleEnvironmentOptions.CompressionCodec
M
- MAC_OS - org.apache.flink.util.OperatingSystem
- MailboxExecutor - Interface in org.apache.flink.api.common.operators
-
Executor
like interface for a build around a mailbox-based execution model. - MailboxExecutor.MailOptions - Interface in org.apache.flink.api.common.operators
-
Extra options to configure enqueued mails.
- MailOptionsImpl - Class in org.apache.flink.api.common.operators
-
Options to configure behaviour of executing mailbox mails.
- makeNewStateFuture() - Method in class org.apache.flink.core.state.StateFutureImpl
-
Make a new future based on context of this future.
- 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_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(IN) - Method in class org.apache.flink.api.common.functions.RichMapFunction
- map(Function<? super T, ? extends R>) - Method in class org.apache.flink.types.SerializableOptional
- map(Map.Entry<K, V>...) - Static method in class org.apache.flink.util.CollectionUtil
-
Returns an immutable
Map
from the provided entries. - map(T) - Method in interface org.apache.flink.api.common.functions.MapFunction
-
The mapping method.
- MAP - org.apache.flink.api.common.state.StateDescriptor.Type
- MAP(TypeInformation<K>, TypeInformation<V>) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for a Java
Map
. - 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(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
- MapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapOperatorBase
- mapPartition(Iterable<I>, Collector<O>) - Method in class org.apache.flink.api.common.functions.RichMapPartitionFunction
- 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.
- 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(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
- MapPartitionOperatorBase(UserCodeWrapper<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.
- 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.
- MapStateDescriptor<UK,UV> - Class in org.apache.flink.api.common.state
-
A
StateDescriptor
forMapState
. - 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. - 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, 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. - 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>
. - MapTypeDescriptorImpl<K,V> - Class in org.apache.flink.api.common.typeinfo.descriptor
-
Implementation of
TypeDescriptor
to createMapTypeInfo
. - MapTypeDescriptorImpl(TypeDescriptor<K>, TypeDescriptor<V>) - Constructor for class org.apache.flink.api.common.typeinfo.descriptor.MapTypeDescriptorImpl
- MapTypeInfo<K,V> - Class in org.apache.flink.api.java.typeutils
-
Special
TypeInformation
used byMapStateDescriptor
. - MapTypeInfo(Class<K>, Class<V>) - Constructor for class org.apache.flink.api.java.typeutils.MapTypeInfo
- MapTypeInfo(TypeInformation<K>, TypeInformation<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
- MATERIALIZATION_MAX_FAILURES_ALLOWED - Static variable in class org.apache.flink.configuration.StateChangelogOptions
- MathUtils - Class in org.apache.flink.util
-
Collection of simple mathematical routines.
- 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 historical execution attempts kept in history.
- MAX_CONCURRENT_CHECKPOINTS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- 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_PROFILING_DURATION - Static variable in class org.apache.flink.configuration.RestOptions
-
Maximum profiling duration for profiling function.
- MAX_PROFILING_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.RestOptions
-
Maximum history size of profiling list.
- 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_WATERMARK - Static variable in class org.apache.flink.api.common.eventtime.Watermark
-
The watermark that signifies end-of-event-time.
- MdcUtils - Class in org.apache.flink.util
-
Utility class to manage common Flink attributes in
MDC
(onlyJobID
ATM). - MdcUtils() - Constructor for class org.apache.flink.util.MdcUtils
- MdcUtils.MdcCloseable - Interface in org.apache.flink.util
-
AutoCloseable
that restores theMDC
contents on close. - Memory - org.apache.flink.configuration.JobManagerOptions.JobStoreType
- 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).
- 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(ACC, ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
- 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, 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<Integer, TreeMap<Integer, Integer>>) - Method in class org.apache.flink.api.common.accumulators.Histogram
- 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<Utils.ChecksumHashCode, Utils.ChecksumHashCode>) - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- merge(Accumulator<T, ArrayList<byte[]>>) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
- merge(Accumulator<T, ArrayList<T>>) - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
- 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(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.
- mergeListsToArray(List<String>, List<String>) - Static method in class org.apache.flink.configuration.CoreOptions
- 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.
- mergeTernaryBooleanWithConfig(TernaryBoolean, ConfigOption<Boolean>, ReadableConfig) - Static method in enum org.apache.flink.util.TernaryBoolean
-
Merges an existing value with a config, accepting the config's value only if the existing value is undefined.
- mergeWith(MultipleParameterTool) - Method in class org.apache.flink.util.MultipleParameterTool
-
Merges two
MultipleParameterTool
. - mergeWith(ParameterTool) - Method in class org.apache.flink.util.ParameterTool
-
Merges two
ParameterTool
. - metadataConsumer() - Method in interface org.apache.flink.api.connector.sink2.WriterInitContext
-
Returns a metadata consumer, the
SinkWriter
can publish metadata events of typeWriterInitContext
to the consumer. - 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.sink2.CommitterInitContext
- metricGroup() - Method in interface org.apache.flink.api.connector.sink2.WriterInitContext
- 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.
- MetricOptions.JobStatusMetrics - Enum in org.apache.flink.configuration
-
Enum describing the different kinds of job status metrics.
- MetricOptions.JobStatusMetricsSettings - Class in org.apache.flink.configuration
-
Describes which job status metrics have been enabled.
- METRICS_REPORTER_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The prefix for per-metric reporter configs.
- migrateLegacyToStandardYamlConfig(String) - Static method in class org.apache.flink.configuration.ConfigurationFileMigrationUtils
-
Migrates the legacy Flink configuration from the specified directory to a standard YAML format representation.
- MIGRATION_NOT_SUPPORTED_MSG - Static variable in exception org.apache.flink.util.StateMigrationException
- 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
- MIN_PAUSE_BETWEEN_CHECKPOINTS - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- MIN_SLOT_NUM - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
- MIN_TOTAL_CPU - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
- MIN_TOTAL_MEM - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
- MINI_CLUSTER_NUM_TASK_MANAGERS - Static variable in class org.apache.flink.configuration.TaskManagerOptions
- minSplitSize - Variable in class org.apache.flink.api.common.io.FileInputFormat
-
The minimal split size, set by the configure() method.
- 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
- mkdirs(Path) - Method in interface org.apache.flink.core.fs.IFileSystem
-
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
- MORE_AVAILABLE - org.apache.flink.core.io.InputStatus
-
Indicator that more data is available and the input can be called immediately again to produce more data.
- MultipleParameterTool - Class in org.apache.flink.util
-
This class provides simple utility methods for reading and parsing program arguments from different sources.
- multiply(int) - Method in class org.apache.flink.api.common.resources.Resource
- multiply(BigDecimal) - Method in class org.apache.flink.api.common.resources.Resource
- 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.
- MutableURLClassLoader - Class in org.apache.flink.util
-
URL class loader that exposes the `addURL` method in URLClassLoader.
- MutableURLClassLoader(URL[], ClassLoader) - Constructor for class org.apache.flink.util.MutableURLClassLoader
N
- name - Variable in class org.apache.flink.api.common.operators.Operator
- 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.api.common.resources.CPUResource
- 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 - org.apache.flink.core.execution.SavepointFormatType
-
A format specific for the chosen state backend, in its native binary format.
- 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.
- NettyShuffleEnvironmentOptions.CompressionCodec - Enum in org.apache.flink.configuration
-
Supported compression codec.
- 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.Port - Class in org.apache.flink.util
-
Port wrapper class which holds a
FileLock
until it releases. - 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 batch shuffle for shuffle data read (currently only used by sort-shuffle and hybrid shuffle).
- NETWORK_BUFFERS_REQUEST_TIMEOUT - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
-
The timeout for requesting buffers for each 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_HYBRID_SHUFFLE_EXTERNAL_REMOTE_TIER_FACTORY_CLASS_NAME - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
-
The option to configure the tiered factory creator remote class name for hybrid shuffle.
- NETWORK_HYBRID_SHUFFLE_REMOTE_STORAGE_BASE_PATH - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
-
The option to configure the base remote storage path for hybrid shuffle.
- 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_PARTITION_REQUEST_TIMEOUT - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
-
The timeout for partition request listener in result partition manager.
- NETWORK_READ_MAX_REQUIRED_BUFFERS_PER_GATE - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
-
The maximum number of network read buffers that are required by an input gate.
- 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 blocking result partition for sort-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
- NeverReturnExpired - org.apache.flink.api.common.state.StateTtlConfig.StateVisibility
-
Never return expired user value.
- 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(Duration) - Static method in class org.apache.flink.api.common.state.StateTtlConfig
- newDirectExecutorService() - Static method in class org.apache.flink.util.concurrent.Executors
-
Creates a more
ExecutorService
that runs the passed task in the calling thread. - newDirectExecutorServiceWithNoOpShutdown() - Static method in class org.apache.flink.util.concurrent.Executors
-
Creates a new
ExecutorService
that runs the passed tasks in the calling thread but doesn't implement proper shutdown behavior. - newFile(File, OutputStream) - Static method in class org.apache.flink.core.fs.RefCountedFileWithStream
- newHashMapWithExpectedSize(int) - Static method in class org.apache.flink.util.CollectionUtil
-
Creates a new
HashMap
of the expected size, i.e. a hash map that will not rehash if expectedSize many keys are inserted, considering the load factor. - newHashSetWithExpectedSize(int) - Static method in class org.apache.flink.util.CollectionUtil
-
Creates a new
HashSet
of the expected size, i.e. a hash set that will not rehash if expectedSize many unique elements are inserted, considering the load factor. - 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
- newLinkedHashMapWithExpectedSize(int) - Static method in class org.apache.flink.util.CollectionUtil
-
Creates a new
LinkedHashMap
of the expected size, i.e. a hash map that will not rehash if expectedSize many keys are inserted, considering the load factor. - newLinkedHashSetWithExpectedSize(int) - Static method in class org.apache.flink.util.CollectionUtil
-
Creates a new
LinkedHashSet
of the expected size, i.e. a hash set that will not rehash if expectedSize many unique elements are inserted, considering the load factor. - newStatus() - Method in class org.apache.flink.core.execution.DefaultJobExecutionStatusEvent
- newStatus() - Method in interface org.apache.flink.core.execution.JobExecutionStatusEvent
-
New status for job.
- 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.api.common.operators.util.TupleUnwrappingIterator
- next() - Method in class org.apache.flink.util.CloseableIterator.IteratorAdapter
- next() - Method in class org.apache.flink.util.LongValueSequenceIterator
- 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() - Method in class org.apache.flink.util.UnionIterator
- next(int) - Method in class org.apache.flink.util.XORShiftRandom
-
All other methods like nextInt()/nextDouble()... depends on this, so we just need to overwrite this.
- next(E) - Method in interface org.apache.flink.util.MutableObjectIterator
-
Gets the next element from the collection.
- next(StringValue) - Method in class org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
-
Gets the next token from the string.
- nextKey() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
-
Moves the iterator to the next key.
- 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
- nextRecord(T) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
- 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_CLAIM - org.apache.flink.core.execution.RecoveryClaimMode
- NO_EXTERNALIZED_CHECKPOINTS - org.apache.flink.configuration.ExternalizedCheckpointRetention
-
Externalized checkpoints are disabled completely.
- NO_INDEX - Static variable in class org.apache.flink.api.java.typeutils.TypeExtractor
- NO_OP - Static variable in interface org.apache.flink.core.fs.ICloseableRegistry
-
No-op implementation of
ICloseableRegistry
. - NO_OVERWRITE - org.apache.flink.core.fs.FileSystem.WriteMode
-
Creates the target file only if no file exists at that path already.
- NO_RESTART_STRATEGY - org.apache.flink.configuration.RestartStrategyOptions.RestartStrategyType
- 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. - NO_VALUE_KEY - Static variable in class org.apache.flink.util.AbstractParameterTool
- 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.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 - org.apache.flink.api.common.ExecutionConfig.ClosureCleanerLevel
- NONE - org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
-
Disable the use of a combiner.
- NONE - org.apache.flink.api.common.operators.Order
-
Indicates no order.
- NONE - org.apache.flink.configuration.NettyShuffleEnvironmentOptions.CompressionCodec
- NONE - org.apache.flink.configuration.TaskManagerOptions.TaskManagerLoadBalanceMode
- NONE - org.apache.flink.types.parser.FieldParser.ParseErrorState
-
No error occurred.
- NONE - Static variable in class org.apache.flink.configuration.ExternalResourceOptions
-
Indicate an empty external resources list.
- NONE_PARAM_VALUES - Static variable in class org.apache.flink.configuration.CleanupOptions
- 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() - Static method in interface org.apache.flink.api.connector.source.util.ratelimit.RateLimiterStrategy
-
Creates a convenience
RateLimiterStrategy
that is not limiting the records rate. - 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
- NoOpRateLimiter - Class in org.apache.flink.api.connector.source.util.ratelimit
-
A convenience implementation of
RateLimiter
that does not throttle requests. - NoOpRateLimiter() - Constructor for class org.apache.flink.api.connector.source.util.ratelimit.NoOpRateLimiter
- 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.
- NOTHING_AVAILABLE - org.apache.flink.core.io.InputStatus
-
Indicator that no data is currently available, but more data will be available in the future again.
- 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.
- notifyCheckpointComplete(long) - Method in class org.apache.flink.api.connector.source.util.ratelimit.GatedRateLimiter
- notifyCheckpointComplete(long) - Method in class org.apache.flink.api.connector.source.util.ratelimit.RateLimitedSourceReader
- notifyCheckpointComplete(long) - Method in interface org.apache.flink.api.connector.source.util.ratelimit.RateLimiter
-
Notifies this
RateLimiter
that the checkpoint with the givencheckpointId
completed and was committed. - notifyCheckpointSubsumed(long) - Method in interface org.apache.flink.api.common.state.InternalCheckpointListener
-
This method is called as a notification once a distributed checkpoint has been subsumed.
- notifyNoMoreSplits() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
- 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.
- notifyNoMoreSplits() - Method in class org.apache.flink.api.connector.source.util.ratelimit.RateLimitedSourceReader
- 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.NullableSerializerSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
-
Snapshot for serializers of nullable types, containing the snapshot of its original serializer.
- 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
- 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. was
null
. - NullKeyFieldException() - Constructor for exception org.apache.flink.types.NullKeyFieldException
-
Constructs an
NullKeyFieldException
withnull
as its error 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. - NullKeyFieldException(String) - Constructor for exception org.apache.flink.types.NullKeyFieldException
-
Constructs an
NullKeyFieldException
with the specified 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 theNullFieldException
. - 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_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.
- NumberSequenceIterator - Class in org.apache.flink.util
-
The
NumberSequenceIterator
is an iterator that returns a sequence of numbers (asLong
)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 rangefrom
toto
(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
- NUMERIC_VALUE_FORMAT_ERROR - org.apache.flink.types.parser.FieldParser.ParseErrorState
-
The field was not in a correct format for the numeric type.
- NUMERIC_VALUE_ILLEGAL_CHARACTER - org.apache.flink.types.parser.FieldParser.ParseErrorState
-
An illegal character was encountered while parsing a numeric type.
- NUMERIC_VALUE_ORPHAN_SIGN - org.apache.flink.types.parser.FieldParser.ParseErrorState
-
A stand-alone sign was encountered while parsing a numeric type.
- NUMERIC_VALUE_OVERFLOW_UNDERFLOW - org.apache.flink.types.parser.FieldParser.ParseErrorState
-
The domain of the numeric type is not large enough to hold the parsed value.
- 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
- OBJECT_STORE - org.apache.flink.core.fs.FileSystemKind
-
An Object store.
- ObjectArrayTypeInfo<T,C> - Class in org.apache.flink.api.java.typeutils
- obtainDelegationTokens() - Method in interface org.apache.flink.core.security.token.DelegationTokenProvider
-
Obtain delegation tokens for this service.
- ObtainedDelegationTokens(byte[], Optional<Long>) - Constructor for class org.apache.flink.core.security.token.DelegationTokenProvider.ObtainedDelegationTokens
- 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(int, int) - Static method in class org.apache.flink.api.common.io.FirstAttemptInitializationContext
- 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(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.
- 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(String) - Static method in enum org.apache.flink.configuration.RestartStrategyOptions.RestartStrategyType
-
Return the corresponding RestartStrategyType based on the displayed value.
- of(Optional<T>) - Static method in class org.apache.flink.util.OptionalConsumer
- of(L) - Static method in class org.apache.flink.types.Either.Left
-
Creates a left value of
Either
- of(SerializableTimestampAssigner<T>) - Static method in interface org.apache.flink.api.common.eventtime.TimestampAssignerSupplier
- 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(FileSystemFactory) - Static method in class org.apache.flink.core.fs.PluginFileSystemFactory
- of(Path, Path, long) - Static method in interface org.apache.flink.core.fs.PathsCopyingFileSystem.CopyRequest
-
A factory method for creating a simple pair of source/destination.
- of(R) - Static method in class org.apache.flink.types.Either.Right
-
Creates a right value of
Either
- of(T) - Static method in class org.apache.flink.types.SerializableOptional
- of(T) - Static method in class org.apache.flink.util.OptionalFailure
- 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.
- OffsetAwareOutputStream - Class in org.apache.flink.core.fs
-
An
OutputStream
that keeps track of its current length. - 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.
- ofNullable(T) - Static method in class org.apache.flink.types.SerializableOptional
- ofNullable(T) - Static method in class org.apache.flink.util.CollectionUtil
- oldStatus() - Method in class org.apache.flink.core.execution.DefaultJobExecutionStatusEvent
- oldStatus() - Method in interface org.apache.flink.core.execution.JobExecutionStatusEvent
-
Old status for job.
- onCanceled(JobID) - Method in interface org.apache.flink.core.execution.JobStatusHook
-
When job get canceled by users.
- OnCreateAndWrite - org.apache.flink.api.common.state.StateTtlConfig.UpdateType
-
Last access timestamp is initialised when state is created and updated on every write operation.
- onCreated(JobID) - Method in interface org.apache.flink.core.execution.JobStatusHook
-
When Job becomes
JobStatus.CREATED
status, it would only be called one time. - onEvent(E, long, WatermarkOutput) - Method in class org.apache.flink.api.common.eventtime.NoWatermarksGenerator
- onEvent(JobStatusChangedEvent) - Method in interface org.apache.flink.core.execution.JobStatusChangedListener
- onEvent(T, long, WatermarkOutput) - Method in class org.apache.flink.api.common.eventtime.BoundedOutOfOrdernessWatermarks
- 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
- onFailed(JobID, Throwable) - Method in interface org.apache.flink.core.execution.JobStatusHook
-
When job failed finally.
- onFinished(JobID) - Method in interface org.apache.flink.core.execution.JobStatusHook
-
When job finished successfully.
- 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.
- ONLY_FINISHED_PRODUCERS - org.apache.flink.configuration.JobManagerOptions.HybridPartitionDataConsumeConstraint
- onNewTokensObtained(byte[]) - Method in interface org.apache.flink.core.security.token.DelegationTokenReceiver
-
Callback function when new delegation tokens obtained.
- 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 underlyingWatermarkOutput
. - 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(WatermarkOutput) - Method in class org.apache.flink.api.common.eventtime.WatermarksWithIdleness
- onProcessingTime(long) - Method in interface org.apache.flink.api.common.operators.ProcessingTimeService.ProcessingTimeCallback
-
This method is invoked with the time which the callback register for.
- OnReadAndWrite - org.apache.flink.api.common.state.StateTtlConfig.UpdateType
-
The same as
OnCreateAndWrite
but also updated on read. - onWatermarkUpdate(long) - Method in interface org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer.WatermarkUpdateListener
-
Called when the watermark increases.
- open(int, int) - Method in class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
- open(OpenContext) - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
- open(OpenContext) - Method in interface org.apache.flink.api.common.functions.RichFunction
-
Initialization method for the function.
- open(OpenContext) - Method in class org.apache.flink.api.common.functions.WrappingFunction
- open(OpenContext) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
- 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(OutputFormat.InitializationContext) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
- open(OutputFormat.InitializationContext) - Method in class org.apache.flink.api.common.io.FileOutputFormat
- open(OutputFormat.InitializationContext) - 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(OutputFormat.InitializationContext) - Method in class org.apache.flink.api.common.io.OutputFormatBase
-
Open the format and initializes the flush system.
- open(OutputFormat.InitializationContext) - Method in class org.apache.flink.util.Utils.ChecksumHashCodeHelper
- open(OutputFormat.InitializationContext) - Method in class org.apache.flink.util.Utils.CollectHelper
- open(OutputFormat.InitializationContext) - Method in class org.apache.flink.util.Utils.CountHelper
- 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(FileInputSplit) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
- 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(Path) - Method in class org.apache.flink.core.fs.FileSystem
- open(Path) - Method in interface org.apache.flink.core.fs.IFileSystem
-
Opens an FSDataInputStream at the indicated Path.
- open(Path) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
- 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) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
- open(Path, int) - Method in class org.apache.flink.core.fs.FileSystem
- open(Path, int) - Method in interface org.apache.flink.core.fs.IFileSystem
-
Opens an FSDataInputStream at the indicated Path.
- open(Path, int) - Method in class org.apache.flink.core.fs.LimitedConnectionsFileSystem
- open(Path, int) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
- open(Path, int) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
- open(GenericInputSplit) - Method in class org.apache.flink.api.common.io.GenericInputFormat
- open(S) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
- 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.
- OpenContext - Interface in org.apache.flink.api.common.functions
-
The
OpenContext
interface provides necessary information required by theRichFunction
when it is opened. - openFunction(Function, OpenContext) - 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.
- openNew(FunctionWithException<File, RefCountedFileWithStream, IOException>) - Static method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- 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 - org.apache.flink.core.memory.ManagedMemoryUseCase
-
Currently, weights are defined as mebibyte values.
- OPERATOR - org.apache.flink.core.memory.ManagedMemoryUseCase.Scope
- OPERATOR_CHAINING - Static variable in class org.apache.flink.configuration.PipelineOptions
- OPERATOR_CHAINING_CHAIN_OPERATORS_WITH_DIFFERENT_MAX_PARALLELISM - 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.
- OPTIMIZER_CHOOSES - org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
- OPTIMIZER_CHOOSES - org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
-
Leave the choice how to do the join to the optimizer.
- OPTIMIZER_CHOOSES - org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
-
Leave the choice how to do the combine to the optimizer.
- 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. - OptionalUtils - Class in org.apache.flink.util
-
Utilities for working with
Optional
. - options() - Static method in interface org.apache.flink.api.common.operators.MailboxExecutor.MailOptions
- 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.attribute - package org.apache.flink.api.common.attribute
- 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.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.typeinfo.descriptor - package org.apache.flink.api.common.typeinfo.descriptor
- 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.dsv2 - package org.apache.flink.api.connector.dsv2
- org.apache.flink.api.connector.sink2 - package org.apache.flink.api.connector.sink2
- 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.connector.source.util.ratelimit - package org.apache.flink.api.connector.source.util.ratelimit
- 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.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.failure - package org.apache.flink.core.failure
- 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.core.security.token - package org.apache.flink.core.security.token
- org.apache.flink.core.state - package org.apache.flink.core.state
- org.apache.flink.management.jmx - package org.apache.flink.management.jmx
- org.apache.flink.streaming.api.operators - package org.apache.flink.streaming.api.operators
- 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
- org.apache.flink.util.jackson - package org.apache.flink.util.jackson
- 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, 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(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(UserCodeWrapper<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.
- OutputFormat.InitializationContext - Interface in org.apache.flink.api.common.io
-
The context exposes some runtime info for initializing output format.
- OutputFormatBase<OUT,V> - Class in org.apache.flink.api.common.io
-
OutputFormatBase is the common abstract class for output formats.
- OutputFormatBase(int, Duration) - Constructor for class org.apache.flink.api.common.io.OutputFormatBase
- 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 outputTypeInformation
. - 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
- OutputTypeConfigurable<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Stream operators can implement this interface if they need access to the output type information at
org.apache.flink.streaming.api.graph.StreamGraph
generation. - outputView - Variable in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
- OVERWRITE - org.apache.flink.core.fs.FileSystem.WriteMode
-
Creates a new target file regardless of any existing files or directories.
- owned() - Method in class org.apache.flink.util.Reference
-
Returns the value if it is owned.
- owned(V) - Static method in class org.apache.flink.util.Reference
P
- PACKAGE_SEPARATOR - Static variable in class org.apache.flink.util.FileUtils
- PARALLELISM_DEFAULT - Static variable in class org.apache.flink.api.common.ExecutionConfig
-
The flag value indicating use of the default parallelism.
- PARALLELISM_OVERRIDES - Static variable in class org.apache.flink.configuration.PipelineOptions
- PARALLELISM_UNKNOWN - Static variable in class org.apache.flink.api.common.ExecutionConfig
-
The flag value indicating an unknown or unset parallelism.
- parameters - Variable in class org.apache.flink.api.common.operators.Operator
- ParameterTool - Class in org.apache.flink.util
-
This class provides simple utility methods for reading and parsing program arguments from different sources.
- PARENT_FIRST - org.apache.flink.util.FlinkUserCodeClassLoaders.ResolveOrder
- PARENT_FIRST_LOGGING_PATTERNS - Static variable in class org.apache.flink.configuration.CoreOptions
- parentFirst(URL[], ClassLoader, Consumer<Throwable>, boolean) - Static method in class org.apache.flink.util.FlinkUserCodeClassLoaders
- PARONLY - org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
-
A directory is only created for parallel output tasks, i.e., number of output tasks > 1.
- 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(String, Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
- ParseException(Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
- 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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) - 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[], Boolean) - Method in class org.apache.flink.types.parser.BooleanParser
- parseField(byte[], int, int, byte[], Byte) - Method in class org.apache.flink.types.parser.ByteParser
- parseField(byte[], int, int, byte[], Double) - Method in class org.apache.flink.types.parser.DoubleParser
- parseField(byte[], int, int, byte[], Float) - Method in class org.apache.flink.types.parser.FloatParser
- parseField(byte[], int, int, byte[], Integer) - Method in class org.apache.flink.types.parser.IntParser
- parseField(byte[], int, int, byte[], Long) - Method in class org.apache.flink.types.parser.LongParser
- parseField(byte[], int, int, byte[], Short) - Method in class org.apache.flink.types.parser.ShortParser
- parseField(byte[], int, int, byte[], String) - Method in class org.apache.flink.types.parser.StringParser
- parseField(byte[], int, int, byte[], BigDecimal) - Method in class org.apache.flink.types.parser.BigDecParser
- parseField(byte[], int, int, byte[], BigInteger) - Method in class org.apache.flink.types.parser.BigIntParser
- parseField(byte[], int, int, byte[], Date) - Method in class org.apache.flink.types.parser.SqlDateParser
- parseField(byte[], int, int, byte[], Time) - Method in class org.apache.flink.types.parser.SqlTimeParser
- parseField(byte[], int, int, byte[], Timestamp) - Method in class org.apache.flink.types.parser.SqlTimestampParser
- parseField(byte[], int, int, byte[], BooleanValue) - Method in class org.apache.flink.types.parser.BooleanValueParser
- parseField(byte[], int, int, byte[], ByteValue) - Method in class org.apache.flink.types.parser.ByteValueParser
- parseField(byte[], int, int, byte[], DoubleValue) - Method in class org.apache.flink.types.parser.DoubleValueParser
- parseField(byte[], int, int, byte[], FloatValue) - Method in class org.apache.flink.types.parser.FloatValueParser
- parseField(byte[], int, int, byte[], IntValue) - Method in class org.apache.flink.types.parser.IntValueParser
- parseField(byte[], int, int, byte[], LongValue) - Method in class org.apache.flink.types.parser.LongValueParser
- parseField(byte[], int, int, byte[], ShortValue) - Method in class org.apache.flink.types.parser.ShortValueParser
- parseField(byte[], int, int, byte[], StringValue) - Method in class org.apache.flink.types.parser.StringValueParser
- 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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, 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).
- 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
. - parseMapToString(Map<String, String>) - Static method in class org.apache.flink.configuration.ConfigurationUtils
- parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
- parseStringFromCachedFiles(List<Tuple2<String, DistributedCache.DistributedCacheEntry>>) - Static method in class org.apache.flink.api.common.cache.DistributedCache
- parseStringToMap(String) - Static method in class org.apache.flink.configuration.ConfigurationUtils
-
Parses a string as a map of strings.
- 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(Collection<T>, int) - Static method in class org.apache.flink.util.CollectionUtil
-
Partition a collection into approximately n buckets.
- partition(K, int) - Method in interface org.apache.flink.api.common.functions.Partitioner
-
Computes the partition for the given key.
- 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(String) - Constructor for class org.apache.flink.core.fs.Path
-
Construct a path from a String.
- Path(String, String) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- 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(String, Path) - Constructor for class org.apache.flink.core.fs.Path
-
Resolve a child path against a parent path.
- Path(URI) - Constructor for class org.apache.flink.core.fs.Path
-
Constructs a path object from a given URI.
- Path(Path, String) - 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 - Static variable in class org.apache.flink.configuration.RestOptions
-
The path that should be used by clients to interact with the server.
- PathsCopyingFileSystem - Interface in org.apache.flink.core.fs
-
An interface marking that given
FileSystem
have an optimised path for copying paths instead of usingFSDataOutputStream
orFSDataInputStream
. - PathsCopyingFileSystem.CopyRequest - Interface in org.apache.flink.core.fs
-
A pair of source and destination to duplicate a file.
- pathToFile(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
-
Converts the given Path to a File for this file system.
- pauseOrResumeSplits(Collection<String>, Collection<String>) - Method in interface org.apache.flink.api.connector.source.SourceReader
-
Pauses or resumes reading of individual source splits.
- perCheckpoint(int) - Static method in interface org.apache.flink.api.connector.source.util.ratelimit.RateLimiterStrategy
-
Creates a
RateLimiterStrategy
that is limiting the number of records per checkpoint. - PERIODIC_MATERIALIZATION_ENABLED - Static variable in class org.apache.flink.configuration.StateChangelogOptions
- PERIODIC_MATERIALIZATION_INTERVAL - Static variable in class org.apache.flink.configuration.StateChangelogOptions
- perSecond(double) - Static method in interface org.apache.flink.api.connector.source.util.ratelimit.RateLimiterStrategy
-
Creates a
RateLimiterStrategy
that is limiting the number of records per second. - persist() - Method in class org.apache.flink.core.fs.CommitterFromPersistRecoverableFsDataOutputStream
- persist() - Method in class org.apache.flink.core.fs.local.LocalRecoverableFsDataOutputStream
- 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. a user job. - PipelineExecutorFactory - Interface in org.apache.flink.core.execution
-
A factory for selecting and instantiating the adequate
PipelineExecutor
based on a providedConfiguration
. - 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 givenPipeline
. - PipelineOptions - Class in org.apache.flink.configuration
-
The
configuration options
for job execution. - PipelineOptions() - Constructor for class org.apache.flink.configuration.PipelineOptions
- PipelineOptions.VertexDescriptionMode - Enum in org.apache.flink.configuration
-
The mode how we organize description of a vertex.
- 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<?>>) - 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(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<?>) - 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.
- 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.
- 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-specific option of
CoreOptions.ALWAYS_PARENT_FIRST_LOADER_PATTERNS
. - 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 allFileSystem
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 thePluginManager
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.
- 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[], SerializerConfig) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
-
Constructor to create a new
PojoSerializer
. - 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.util.ratelimit.RateLimitedSourceReader
- pollNext(ReaderOutput<O>) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
- pollNext(ReaderOutput<T>) - Method in interface org.apache.flink.api.connector.source.SourceReader
-
Poll the next available record into the
ReaderOutput
. - Port(int, FileLock) - Constructor for class org.apache.flink.util.NetUtils.Port
- 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. - PortRange - Class in org.apache.flink.util
-
Represents a port range and provides access to an iterator of the given range.
- PortRange(int) - Constructor for class org.apache.flink.util.PortRange
- PortRange(String) - Constructor for class org.apache.flink.util.PortRange
-
Creates a new port range instance.
- postClose() - Method in class org.apache.flink.api.common.io.OutputFormatBase
-
Tear down the OutputFormat.
- postComplete(boolean) - Method in class org.apache.flink.core.state.StateFutureImpl
-
Will be triggered when this future completes.
- postOpen() - Method in class org.apache.flink.api.common.io.OutputFormatBase
-
Initialize the OutputFormat.
- PostVersionedIOReadableWritable - Class in org.apache.flink.core.io
-
A
VersionedIOReadableWritable
which allows to differentiate whether the previous data was versioned with aVersionedIOReadableWritable
. - 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.
- PPC64_LE - org.apache.flink.util.ProcessorArchitecture
-
The little-endian mode of the 64 bit Power-PC architecture.
- Preconditions - Class in org.apache.flink.util
-
A collection of static utility methods to validate input.
- prepareCommit() - Method in interface org.apache.flink.api.connector.sink2.CommittingSinkWriter
-
Prepares 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
- PROCESS_WORKING_DIR_BASE - Static variable in class org.apache.flink.configuration.ClusterOptions
- 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. - 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. - processFailure(Throwable, FailureEnricher.Context) - Method in interface org.apache.flink.core.failure.FailureEnricher
-
Method to handle a failure as part of the enricher and optionally return a map of KV pairs (labels).
- ProcessingTime - org.apache.flink.api.common.state.StateTtlConfig.TtlTimeCharacteristic
-
Processing time.
- ProcessingTimeService - Interface in org.apache.flink.api.common.operators
-
A service that allows to get the current processing time and register timers that will execute the given
ProcessingTimeService.ProcessingTimeCallback
when firing. - ProcessingTimeService.ProcessingTimeCallback - Interface in org.apache.flink.api.common.operators
-
A callback that can be registered via
ProcessingTimeService.registerTimer(long, ProcessingTimeCallback)
. - 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.
- PROFILING_RESULT_DIR - Static variable in class org.apache.flink.configuration.RestOptions
-
Directory for storing the profiling results.
- PROGRAM_CONFIG_ENABLED - Static variable in class org.apache.flink.configuration.DeploymentOptions
- PROGRAM_CONFIG_WILDCARDS - Static variable in class org.apache.flink.configuration.DeploymentOptions
- 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(Collection<I>, Function<I, O>) - Static method in class org.apache.flink.util.CollectionUtil
- 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. - 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
-
Deprecated.Number of async query threads for the client proxy (0 => #slots).
- PROXY_NETWORK_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
Deprecated.Number of network (event loop) threads for the client proxy (0 => #slots).
- PROXY_PORT_RANGE - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
Deprecated.The config parameter defining the server port range of the queryable state proxy.
- 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(int, ByteBuffer, 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(String, K, V) - Method in class org.apache.flink.util.LinkedOptionalMap
- put(K, V) - Method in class org.apache.flink.types.MapValue
- 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(Boolean, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
- putNormalizedKey(Byte, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
- putNormalizedKey(Character, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
- putNormalizedKey(Double, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
- putNormalizedKey(Float, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
- putNormalizedKey(Integer, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
- putNormalizedKey(Long, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
- putNormalizedKey(Short, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
- putNormalizedKey(String, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
- 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. 2 bits determine the sign (negative, zero, positive), 33 bits determine the magnitude.
- 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. 1 bit determines the sign (negative, zero/positive), 31 bit the bit length of the record.
- putNormalizedKey(Instant, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.InstantComparator
- 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(Date, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
- putNormalizedKey(Date, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
- putNormalizedKey(BooleanValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
- putNormalizedKey(ByteValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
- putNormalizedKey(CharValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
- putNormalizedKey(DoubleValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
- putNormalizedKey(FloatValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
- putNormalizedKey(IntValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
- 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(Row, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
- putNormalizedKey(ShortValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
- 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.base.array.PrimitiveArrayComparator
- putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
- 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(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
- PYTHON - org.apache.flink.core.memory.ManagedMemoryUseCase
Q
- 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
-
Deprecated.The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.
R
- RANGE - org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
- RangeBoundaries<T> - Interface in org.apache.flink.api.common.distributions
-
RangeBoundaries is used to split the records into multiple ranges.
- RateLimitedSourceReader<E,SplitT extends SourceSplit> - Class in org.apache.flink.api.connector.source.util.ratelimit
-
Wraps the actual
SourceReader
and rate limits its data emission. - RateLimitedSourceReader(SourceReader<E, SplitT>, RateLimiter) - Constructor for class org.apache.flink.api.connector.source.util.ratelimit.RateLimitedSourceReader
-
Instantiates a new rate-limited source reader.
- RateLimiter - Interface in org.apache.flink.api.connector.source.util.ratelimit
-
The interface to rate limit execution of methods.
- RateLimiterStrategy - Interface in org.apache.flink.api.connector.source.util.ratelimit
-
A factory for
RateLimiters
which apply rate-limiting to a source sub-task. - 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
- REACTIVE - org.apache.flink.configuration.SchedulerExecutionMode
- read() - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
- read() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
- read() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
- read() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
- read() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
- read() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
- read() - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
- read(byte[]) - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
- read(byte[]) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
- read(byte[]) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
- read(byte[]) - Method in class org.apache.flink.core.memory.DataInputDeserializer
- read(byte[]) - Method in interface org.apache.flink.core.memory.DataInputView
-
Tries to fill the given byte array
b
. - read(byte[], int, int) - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
- read(byte[], int, int) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
- read(byte[], int, int) - 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.NoFetchingInput
- read(byte[], int, int) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
- read(byte[], int, int) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
- read(byte[], int, int) - 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 intob
starting at offsetoff
. - read(byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegmentInputStreamWithPos
- read(long, ByteBuffer) - Method in interface org.apache.flink.core.fs.ByteBufferReadable
-
Reads up to
byteBuffer.remaining()
bytes into byteBuffer from a given position in the file and returns the number of bytes read. - read(long, ByteBuffer) - Method in class org.apache.flink.core.fs.ByteBufferReadableClosingFSDataInputStream
- 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(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(ByteBuffer) - Method in interface org.apache.flink.core.fs.ByteBufferReadable
-
Reads up to byteBuffer.remaining() bytes into byteBuffer.
- read(ByteBuffer) - Method in class org.apache.flink.core.fs.ByteBufferReadableClosingFSDataInputStream
- read(DataInputView) - Method in class org.apache.flink.api.common.io.BlockInfo
- read(DataInputView) - Method in class org.apache.flink.configuration.Configuration
- read(DataInputView) - Method in class org.apache.flink.configuration.DelegatingConfiguration
- 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) - 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(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(DataInputView, boolean) - Method in class org.apache.flink.core.io.PostVersionedIOReadableWritable
-
Read from the provided
in
. - 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, Charset) - 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
- readLongUTF() - Method in class org.apache.flink.core.memory.DataInputDeserializer
-
Similar to
DataInputDeserializer.readUTF()
. - 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
- 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. any information beyond the nested serializers of the outer serializer.
- 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.
- readSerializerSnapshot(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSnapshotSerializationUtil
-
Reads from a data input view a
TypeSerializerSnapshot
that was previously written using {@link #writeSerializerSnapshot(DataOutputView, TypeSerializerSnapshot}. - readShort() - Method in class org.apache.flink.core.memory.DataInputDeserializer
- 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.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 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.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>, byte[]) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
-
Deserializes the version and datum from a byte array.
- readVersionAndDeSerialize(SimpleVersionedSerializer<T>, DataInputView) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
-
Deserializes the version and datum from a stream.
- readVersionAndDeserializeList(SimpleVersionedSerializer<T>, DataInputView) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
-
Deserializes the version and data from a stream.
- readVersionedSnapshot(DataInputView, ClassLoader) - Static method in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
-
Reads a snapshot from the stream, performing resolving
- 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(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(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(Row, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
- 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.base.array.PrimitiveArrayComparator
- readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
- 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(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
- REBALANCE - org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
- RECONCILING - org.apache.flink.api.common.JobStatus
-
The job is currently reconciling and waits for task execution report to recover state.
- 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(int) - Constructor for class org.apache.flink.types.Record
-
Creates a new record, containing the given number of fields.
- 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_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.
- RecoveryClaimMode - Enum in org.apache.flink.core.execution
-
Defines state files ownership when Flink restore from a given savepoint or retained checkpoint.
- RECURSIVE - org.apache.flink.api.common.ExecutionConfig.ClosureCleanerLevel
- recursivelyRegisterType(Class<?>, SerializerConfig, Set<Class<?>>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
- recursivelyRegisterType(TypeInformation<?>, SerializerConfig, Set<Class<?>>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
- recycleUnpooledMemorySegments(Collection<MemorySegment>) - Method in interface org.apache.flink.core.memory.MemorySegmentProvider
- reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichGroupReduceFunction
- reduce(Iterable<T>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.GroupReduceFunction
-
The reduce method.
- reduce(T, T) - Method in class org.apache.flink.api.common.functions.RichReduceFunction
- ReduceOperatorBase<T,FT extends org.apache.flink.api.common.functions.ReduceFunction<T>> - Class in org.apache.flink.api.common.operators.base
-
Base data flow operator for Reduce user-defined functions.
- 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(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>, 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>, String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
-
Creates a non-grouped reduce data flow operator (all-reduce).
- 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(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.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.
- REDUCING - org.apache.flink.api.common.state.StateDescriptor.Type
- ReducingStateDescriptor<T> - Class in org.apache.flink.api.common.state
-
StateDescriptor
forReducingState
. - 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.
- RefCountedBufferingFileStream - Class in org.apache.flink.core.fs
-
A
RefCountedFileWithStream
that also uses an in-memory buffer for buffering small writes. - RefCountedBufferingFileStream(RefCountedFileWithStream, int) - Constructor for class org.apache.flink.core.fs.RefCountedBufferingFileStream
- 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
- RefCountedFileWithStream - 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
. - RefCountedFSOutputStream - Class in org.apache.flink.core.fs
-
A
FSDataOutputStream
with theRefCounted
functionality. - RefCountedFSOutputStream() - Constructor for class org.apache.flink.core.fs.RefCountedFSOutputStream
- RefCountedTmpFileCreator - Class in org.apache.flink.core.fs
-
A utility class that creates local
reference counted files
that serve as temporary files. - reference - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
- Reference<T> - Class in org.apache.flink.util
-
Wrapper class that allows to express whether the value is borrowed or owned.
- 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_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.AbstractAutoCloseableRegistry
-
Registers a
AutoCloseable
with the registry. - registerCloseable(Closeable) - Method in interface org.apache.flink.core.fs.ICloseableRegistry
-
Registers a
Closeable
with the registry. - registerCloseableTemporarily(Closeable) - Method in interface org.apache.flink.core.fs.ICloseableRegistry
-
Same as
ICloseableRegistry.registerCloseable(Closeable)
but allows tounregister
the passed closeable by closing the returned closeable. - registeredReaders() - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
-
Get the currently registered readers.
- registeredReadersOfAttempts() - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
-
Get the currently registered readers of all the subtask attempts.
- registerFactory(Type, Class<? extends TypeInfoFactory<?>>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
-
Registers a type information factory globally for a certain type.
- 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 interface org.apache.flink.api.common.serialization.SerializerConfig
-
Registers the given type with the serialization stack.
- registerKryoType(Class<?>) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Registers the given type with the serialization stack.
- registerNewOutput(String, WatermarkOutputMultiplexer.WatermarkUpdateListener) - 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 interface org.apache.flink.api.common.serialization.SerializerConfig
-
Registers the given type with the serialization stack.
- registerPojoType(Class<?>) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Registers the given type with the serialization stack.
- 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.
- registerSerializers(Kryo) - Method in interface org.apache.flink.api.java.typeutils.runtime.kryo.ChillSerializerRegistrar
-
Registers all serializers with the given
Kryo
. - registerTimer(long, ProcessingTimeService.ProcessingTimeCallback) - Method in interface org.apache.flink.api.common.operators.ProcessingTimeService
-
Registers a task to be executed when (processing) time is
timestamp
. - registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer.
- registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer.
- registerTypeWithKryoSerializer(Class<?>, T) - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
Registers the given type with a Kryo Serializer.
- registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
-
Registers the given type with a Kryo Serializer.
- 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_TIMEOUT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
Defines the timeout it can take for the TaskManager registration.
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.apache.flink.util.concurrent.IgnoreShutdownRejectedExecutionHandler
- RelativeClock - Interface in org.apache.flink.util.clock
-
A clock that gives access to relative time, similar to System#nanoTime(), however the progress of the relative time doesn't have to reflect the progress of a wall clock.
- 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 interface org.apache.flink.util.clock.RelativeClock
-
Gets the current relative time, in milliseconds.
- 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 interface org.apache.flink.util.clock.RelativeClock
-
Gets the current relative time, in nanoseconds.
- 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.RefCountedBufferingFileStream
- 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. - REMOTE_FORK_JOIN_EXECUTOR_PARALLELISM_FACTOR - Static variable in class org.apache.flink.configuration.RpcOptions
- REMOTE_FORK_JOIN_EXECUTOR_PARALLELISM_MAX - Static variable in class org.apache.flink.configuration.RpcOptions
- REMOTE_FORK_JOIN_EXECUTOR_PARALLELISM_MIN - Static variable in class org.apache.flink.configuration.RpcOptions
- 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() - Method in class org.apache.flink.api.common.operators.util.TupleUnwrappingIterator
- 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
- 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
- removeAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
- removeCloseableInternal(R) - Method in class org.apache.flink.util.AbstractAutoCloseableRegistry
-
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.
- removeKey(String) - Method in class org.apache.flink.configuration.Configuration
-
Removes given key from the configuration.
- removeKey(String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
- 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
- rename(Path, Path) - Method in interface org.apache.flink.core.fs.IFileSystem
-
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, Long) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
- 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
. - REPARTITION_HASH_FIRST - org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
-
Hint that the first join input is a bit smaller than the second.
- REPARTITION_HASH_SECOND - org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
-
Hint that the second join input is a bit smaller than the first.
- REPARTITION_SORT_MERGE - org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
-
Hint that the join should repartitioning both inputs and use sorting and merging as the join strategy.
- 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
- REPORT_EVENTS_AS_SPANS - Static variable in class org.apache.flink.configuration.TraceOptions
-
Deprecated.
- REPORTER_ADDITIONAL_VARIABLES - Static variable in class org.apache.flink.configuration.MetricOptions
- REPORTER_ADDITIONAL_VARIABLES - Static variable in class org.apache.flink.configuration.TraceOptions
- REPORTER_CONFIG_PARAMETER - Static variable in class org.apache.flink.configuration.MetricOptions
- REPORTER_CONFIG_PARAMETER - Static variable in class org.apache.flink.configuration.TraceOptions
- REPORTER_EXCLUDED_VARIABLES - Static variable in class org.apache.flink.configuration.MetricOptions
- REPORTER_EXCLUDES - Static variable in class org.apache.flink.configuration.MetricOptions
- REPORTER_FACTORY_CLASS - Static variable in class org.apache.flink.configuration.MetricOptions
- REPORTER_FACTORY_CLASS - Static variable in class org.apache.flink.configuration.TraceOptions
- REPORTER_INCLUDES - Static variable in class org.apache.flink.configuration.MetricOptions
- REPORTER_INTERVAL - Static variable in class org.apache.flink.configuration.MetricOptions
- REPORTER_SCOPE_DELIMITER - 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.
- reportHeartbeat(long) - Method in interface org.apache.flink.core.execution.JobClient
-
The client reports the heartbeat to the dispatcher for aliveness.
- requestUnpooledMemorySegments(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.
- REQUIREMENTS_CHECK_DELAY - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
- 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. temporarily files created or objects uploaded to external systems. - RESCALE_ENABLE - Static variable in class org.apache.flink.configuration.WebOptions
-
Config parameter indicating whether jobs can be rescaled from the web-frontend.
- 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
- resetLocal() - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- resetParallelism() - Method in class org.apache.flink.api.common.ExecutionConfig
- 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.
- resolveFactory(ThreadLocal<T>, T) - Static method in class org.apache.flink.util.Utils
-
Resolves the given factories.
- resolveOuterSchemaCompatibility(TypeSerializerSnapshot<C[]>) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
- resolveOuterSchemaCompatibility(TypeSerializerSnapshot<Row>) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
- resolveOuterSchemaCompatibility(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
-
Checks the schema compatibility of the given old serializer snapshot based on the outer snapshot.
- resolveOuterSchemaCompatibility(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer.NullableSerializerSnapshot
- resolveOuterSchemaCompatibility(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(TypeSerializerSnapshot)
instead. - resolveProxyClass(String[]) - Method in class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
- resolveSchemaCompatibility(TypeSerializerSnapshot<C[]>) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<Either<L, R>>) - Method in class org.apache.flink.api.java.typeutils.runtime.JavaEitherSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<T>) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot
-
Checks current serializer's compatibility to read data written by the prior serializer.
- resolveSchemaCompatibility(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
- 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_PREVIOUS_WORKER_RECOVERY_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
-
Timeout for ResourceManager to recover all the previous attempts workers.
- RESOURCE_STABILIZATION_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
- RESOURCE_WAIT_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
Deprecated.
- 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 toResourceGuard.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.RestartStrategyOptions
- RESTART_STRATEGY_CONFIG_PREFIX - Static variable in class org.apache.flink.configuration.RestartStrategyOptions
- RESTART_STRATEGY_EXPONENTIAL_DELAY_ATTEMPTS - 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.RestartStrategyOptions
- 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.RestartStrategyOptions
- 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.RestartStrategyOptions
- RESTARTING - org.apache.flink.api.common.JobStatus
-
The job is currently undergoing a reset and total restart.
- RestartStrategyDescriptionUtils - Class in org.apache.flink.api.common
-
Utility class for describing restart strategies.
- RestartStrategyDescriptionUtils() - Constructor for class org.apache.flink.api.common.RestartStrategyDescriptionUtils
- RestartStrategyOptions - Class in org.apache.flink.configuration
-
Config options for restart strategies.
- RestartStrategyOptions.RestartStrategyType - Enum in org.apache.flink.configuration
-
The restart strategy type.
- RestOptions - Class in org.apache.flink.configuration
-
Configuration parameters for REST communication.
- RestOptions() - Constructor for class org.apache.flink.configuration.RestOptions
- restore(FunctionWithException<File, RefCountedFileWithStream, IOException>, File) - Static method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- RESTORE_MODE - Static variable in class org.apache.flink.configuration.StateRecoveryOptions
-
Describes the mode how Flink should restore from the given savepoint or retained checkpoint.
- restoredFile(File, OutputStream, long) - Static method in class org.apache.flink.core.fs.RefCountedFileWithStream
- 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.base.EnumSerializer.EnumSerializerSnapshot
- 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 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.kryo.KryoSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializerSnapshot
- restoreWriter(WriterInitContext, Collection<WriterStateT>) - Method in interface org.apache.flink.api.connector.sink2.SupportsWriterState
-
Create a
StatefulSinkWriter
from a recovered state. - 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.RefCountedBufferingFileStream
- retain() - Method in class org.apache.flink.core.fs.RefCountedFile
- retain() - Method in interface org.apache.flink.util.RefCounted
-
Increases the reference counter.
- RETAIN_ON_CANCELLATION - org.apache.flink.configuration.ExternalizedCheckpointRetention
-
Retain externalized checkpoints on job cancellation.
- 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) - 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, 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. - 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.RpcOptions
-
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
- retryLater() - Method in interface org.apache.flink.api.connector.sink2.Committer.CommitRequest
-
The commit failed for a retriable reason.
- RetryStrategy - Interface in org.apache.flink.util.concurrent
-
Interface that encapsulates retry logic.
- retrySuccessfulWithDelay(Supplier<CompletableFuture<T>>, Duration, 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>>, 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>>, RetryStrategy, ScheduledExecutor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
-
Retry the given operation with the given delay in between failures.
- returnExceptionIfUnexpected(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
-
Return the given exception if it is not a
FlinkExpectedException
. - returnExpiredIfNotCleanedUp() - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
- ReturnExpiredIfNotCleanedUp - org.apache.flink.api.common.state.StateTtlConfig.StateVisibility
-
Return expired user value if it is not cleaned up yet.
- 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() - Method in class org.apache.flink.types.Either
-
Retrieve the Right value of Either.
- right() - Method in class org.apache.flink.types.Either.Right
- Right(R) - Constructor for class org.apache.flink.types.Either.Right
- Right(R) - Static method in class org.apache.flink.types.Either
-
Create a Right value of Either
- RIGHT - org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
- RNG - Static variable in class org.apache.flink.util.Utils
- 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 - 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(int) - Constructor for class org.apache.flink.types.Row
-
Creates a fixed-length row in position-based field mode.
- Row(RowKind, int) - Constructor for class org.apache.flink.types.Row
-
Creates a fixed-length row in position-based field mode.
- 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_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.RowSerializerSnapshot - Class in org.apache.flink.api.java.typeutils.runtime
-
A
TypeSerializerSnapshot
for RowSerializer. - RowSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerSnapshot
- RowTypeInfo - Class in org.apache.flink.api.java.typeutils
-
TypeInformation
forRow
. - 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.
- RpcOptions - Class in org.apache.flink.configuration
-
RPC configuration options.
- RpcOptions() - Constructor for class org.apache.flink.configuration.RpcOptions
- run() - Method in class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
- 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.
- runAsync(RunnableWithException, Executor) - Static method in class org.apache.flink.util.concurrent.FutureUtils
-
Returns a future which is completed when
RunnableWithException
is finished. - 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.
- RUNNING - org.apache.flink.api.common.JobStatus
-
Some tasks are scheduled or running, some may be pending, some may be finished.
- 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
-
A set of adapters between
RuntimeContext
andDeserializationSchema.InitializationContext
orSerializationSchema.InitializationContext
. - RuntimeContextInitializationContextAdapters() - Constructor for class org.apache.flink.api.common.serialization.RuntimeContextInitializationContextAdapters
- 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(JobInfo, 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) - Constructor for class org.apache.flink.api.common.functions.util.RuntimeUDFContext
S
- SafetyNetCloseableRegistry - Class in org.apache.flink.core.fs
-
This implementation of an
AbstractAutoCloseableRegistry
registersWrappingProxyCloseable
. - SafetyNetWrapperClassLoader(FlinkUserCodeClassLoader, ClassLoader) - Constructor for class org.apache.flink.util.FlinkUserCodeClassLoaders.SafetyNetWrapperClassLoader
- SafetyNetWrapperFileSystem - Class in org.apache.flink.core.fs
-
This is a
WrappingProxy
aroundFileSystem
which (i) wraps all opened streams asClosingFSDataInputStream
orClosingFSDataOutputStream
and (ii) registers them to aSafetyNetCloseableRegistry
. - 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_IGNORE_UNCLAIMED_STATE - Static variable in class org.apache.flink.configuration.StateRecoveryOptions
-
A flag indicating if we allow Flink to skip savepoint state that cannot be restored, e.g.
- SAVEPOINT_PATH - Static variable in class org.apache.flink.configuration.StateRecoveryOptions
-
The path to a savepoint that will be used to bootstrap the pipeline's state.
- SavepointFormatType - Enum in org.apache.flink.core.execution
-
Describes the binary format in which a savepoint should be taken.
- schedule(Runnable, long, TimeUnit) - Method in interface org.apache.flink.util.concurrent.ScheduledExecutor
-
Executes the given command after the given delay.
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.util.concurrent.ScheduledExecutorServiceAdapter
- schedule(Callable<V>, long, TimeUnit) - Method in interface org.apache.flink.util.concurrent.ScheduledExecutor
-
Executes the given callable after the given delay.
- 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 aScheduledExecutor
. - 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_EXECUTING_COOLDOWN_AFTER_RESCALING - Static variable in class org.apache.flink.configuration.JobManagerOptions
- SCHEDULER_EXECUTING_RESOURCE_STABILIZATION_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
- SCHEDULER_MODE - Static variable in class org.apache.flink.configuration.JobManagerOptions
- SCHEDULER_RESCALE_TRIGGER_MAX_CHECKPOINT_FAILURES - Static variable in class org.apache.flink.configuration.JobManagerOptions
- SCHEDULER_RESCALE_TRIGGER_MAX_DELAY - Static variable in class org.apache.flink.configuration.JobManagerOptions
- SCHEDULER_SCALING_INTERVAL_MAX - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
Deprecated.
- SCHEDULER_SCALING_INTERVAL_MIN - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
Deprecated.
- SCHEDULER_SUBMISSION_RESOURCE_STABILIZATION_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
- SCHEDULER_SUBMISSION_RESOURCE_WAIT_TIMEOUT - 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.
- 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_JM_OPERATOR - Static variable in class org.apache.flink.configuration.MetricOptions
-
The scope format string that is applied to all metrics scoped to the components running on a JobManager of an operator.
- 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.
- scopeToJob(JobID, Executor) - Static method in class org.apache.flink.util.MdcUtils
- scopeToJob(JobID, ExecutorService) - Static method in class org.apache.flink.util.MdcUtils
-
Wrap the given
ExecutorService
so that the givenJobID
is added before it executes any submitted commands and removed afterward. - scopeToJob(JobID, ScheduledExecutorService) - Static method in class org.apache.flink.util.MdcUtils
-
Wrap the given
ScheduledExecutorService
so that the givenJobID
is added before it executes any submitted commands and removed afterward. - SECOND_IS_SMALL - org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
- 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
- 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(OUT) - Method in class org.apache.flink.api.common.io.OutputFormatBase
-
Send the actual record for writing.
- sendEventToSourceReader(int, int, SourceEvent) - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
-
Send a source event to a source reader.
- 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
. - SeparateThreadExecutor - Class in org.apache.flink.util.concurrent
-
An
Executor
that runs every runnable in a separate thread. - SeparateThreadExecutor(ThreadFactory) - Constructor for class org.apache.flink.util.concurrent.SeparateThreadExecutor
- 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 extends com.esotericsoftware.kryo.Serializer<?> & Serializable> - Class in org.apache.flink.api.common
-
The wrapper to make serializer serializable.
- SerializableSerializer(T) - Constructor for class org.apache.flink.api.common.SerializableSerializer
- SerializableTimestampAssigner<T> - Interface in org.apache.flink.api.common.eventtime
-
A
TimestampAssigner
that is alsoSerializable
. - SERIALIZATION_CONFIG - Static variable in class org.apache.flink.configuration.PipelineOptions
- 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(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(C[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
- serialize(E) - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
-
Serializes the given object.
- serialize(Boolean, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
- serialize(Byte, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
- serialize(Character, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
- serialize(Double, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
- serialize(Float, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
- serialize(Integer, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
- serialize(Long, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
- serialize(Short, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
- serialize(String) - Method in class org.apache.flink.api.common.serialization.SimpleStringSchema
- serialize(String[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
- serialize(String, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
- serialize(Void, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
- 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(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(Instant, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.InstantSerializer
- 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(Date, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
- serialize(List<T>, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
- serialize(Map<K, V>, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
- serialize(Tuple0, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
- serialize(DataOutputView) - Method in class org.apache.flink.types.Record
-
Writes this record to the given output view.
- serialize(BooleanValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
- serialize(ByteValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
- serialize(CharValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
- serialize(DoubleValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
- serialize(Either<L, R>, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
- serialize(FloatValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
- serialize(IntValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
- serialize(LongValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
- serialize(NullValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
- serialize(Row, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
- serialize(ShortValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
- serialize(StringValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
- serialize(T) - Method in interface org.apache.flink.api.common.serialization.SerializationSchema
-
Serializes the incoming element to a specified type.
- serialize(T) - Method in class org.apache.flink.api.common.serialization.TypeInformationSerializationSchema
- serialize(T) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerAdapter
- 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, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
- 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(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(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
- serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
- serialize(T, DataOutputView) - Method in class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
- 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(OutputStream, Object) - Static method in class org.apache.flink.util.InstantiationUtil
- serializeObject(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
- SerializerConfig - Interface in org.apache.flink.api.common.serialization
-
A config to define the behavior for serializers in Flink job, it manages the registered types and serializers.
- SerializerConfigImpl - Class in org.apache.flink.api.common.serialization
-
The default implement of
SerializerConfig
. - SerializerConfigImpl() - Constructor for class org.apache.flink.api.common.serialization.SerializerConfigImpl
- SerializerConfigImpl(Configuration) - Constructor for class org.apache.flink.api.common.serialization.SerializerConfigImpl
- SerializerFactory - Interface in org.apache.flink.api.common.functions
-
A factory for
TypeSerializer
implementations. - serializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
-
serializers to deserialize the first n fields for comparison
- 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.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
- serializeToDataOutputView(Path, DataOutputView) - Static method in class org.apache.flink.core.fs.Path
-
Serialize the path to
DataInputView
. - SERVER_ASYNC_QUERY_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
-
Deprecated.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
-
Deprecated.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
-
Deprecated.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.RpcOptions
- SERVER_SOCKET_WORKER_POOL_SIZE_MAX - Static variable in class org.apache.flink.configuration.RpcOptions
- SERVER_SOCKET_WORKER_POOL_SIZE_MIN - Static variable in class org.apache.flink.configuration.RpcOptions
- SERVER_THREAD_PRIORITY - Static variable in class org.apache.flink.configuration.RestOptions
- serviceConfigPrefix() - Method in interface org.apache.flink.core.security.token.DelegationTokenProvider
-
Config prefix of the service.
- serviceConfigPrefix() - Method in interface org.apache.flink.core.security.token.DelegationTokenReceiver
-
Config prefix of the service.
- serviceName() - Method in interface org.apache.flink.core.security.token.DelegationTokenProvider
-
Name of the service to provide delegation tokens.
- serviceName() - Method in interface org.apache.flink.core.security.token.DelegationTokenReceiver
-
Name of the service to receive delegation tokens for.
- set(boolean) - Method in class org.apache.flink.types.BooleanValue
- set(int, V) - Method in class org.apache.flink.types.ListValue
- set(Iterator<Tuple2<K, T>>) - Method in class org.apache.flink.api.common.operators.util.TupleUnwrappingIterator
- 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
. - setAccumulatedRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
-
Sets the accumulatedRecordCount to the specified value.
- setAsyncInflightRecordsLimit(int) - Method in class org.apache.flink.api.common.ExecutionConfig
- setAsyncStateBufferSize(int) - Method in class org.apache.flink.api.common.ExecutionConfig
- setAsyncStateBufferTimeout(long) - Method in class org.apache.flink.api.common.ExecutionConfig
- setAttribute(Attribute) - Method in class org.apache.flink.api.dag.Transformation
- 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
- 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[]) - Method in class org.apache.flink.core.memory.DataInputDeserializer
- setBuffer(byte[], int, int) - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
- setBuffer(byte[], int, int) - Method in class org.apache.flink.core.memory.DataInputDeserializer
- setBuffer(ByteBuffer) - 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.
- 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
- 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
- setDescription(String) - Method in class org.apache.flink.api.dag.Transformation
-
Changes the description of this
Transformation
. - setDistribution(DataDistribution) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
- 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.
- 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(int, Object) - Method in class org.apache.flink.types.Row
-
Sets the field's content at the specified position.
- setField(int, Value) - Method in class org.apache.flink.types.Record
-
Sets the field at the given position to the given value.
- setField(String, Object) - Method in class org.apache.flink.types.Row
-
Sets the field's content using the specified field name.
- setField(T, int, Object) - Method in class org.apache.flink.api.common.typeutils.CompositeSerializer
-
Modify field of existing instance.
- setFieldDelimiter(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
- setFieldsGeneric(boolean[], Class<?>[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
- setFieldsGeneric(int[], 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
- setFirstRecordStart(long) - Method in class org.apache.flink.api.common.io.BlockInfo
-
Sets the firstRecordStart to the specified value.
- setForceAvro(boolean) - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
The method will be converted to private in the next Flink major version after removing its deprecated caller methods.
- setForceAvro(boolean) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
- setForceKryo(boolean) - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
The method will be converted to private in the next Flink major version after removing its deprecated caller methods.
- setForceKryo(boolean) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
- setForceKryoAvro(boolean) - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
The method will be converted to private in the next Flink major version after removing its deprecated caller methods.
- setForceKryoAvro(boolean) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
- 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
- setGenericTypes(boolean) - Method in interface org.apache.flink.api.common.serialization.SerializerConfig
-
The method will be converted to private in the next Flink major version after removing its deprecated caller methods.
- setGenericTypes(boolean) - Method in class org.apache.flink.api.common.serialization.SerializerConfigImpl
- 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.
- 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. - setIsProcessingBacklog(boolean) - Method in interface org.apache.flink.api.connector.source.SplitEnumeratorContext
-
Reports to JM whether this source is currently processing backlog.
- setJobConfiguration(Configuration) - Method in class org.apache.flink.api.common.Plan
- 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.
- 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.
- setMaterializationMaxAllowedFailures(int) - Method in class org.apache.flink.api.common.ExecutionConfig
- 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.
- setNoOutputUntilEndOfInput(boolean) - Method in class org.apache.flink.api.common.attribute.Attribute.Builder
- setNoOutputUntilEndOfInput(boolean) - Method in class org.apache.flink.api.common.attribute.Attribute
- 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. - 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<OUT>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.OutputTypeConfigurable
-
Is called by the
org.apache.flink.streaming.api.graph.StreamGraph#addOperator(Integer, String, StreamOperator, TypeInformation, TypeInformation, String)
method when theorg.apache.flink.streaming.api.graph.StreamGraph
is generated. - 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
. - setParallelism(int, boolean) - Method in class org.apache.flink.api.dag.Transformation
- setParameter(String, String) - Method in class org.apache.flink.api.common.operators.Operator
-
Sets a stub parameters in the configuration of this contract.
- setPeriodicMaterializeIntervalMillis(Duration) - Method in class org.apache.flink.api.common.ExecutionConfig
- 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
- setQueryable(String) - Method in class org.apache.flink.api.common.state.StateDescriptor
-
Deprecated.The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.
- 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(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(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(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(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
- 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(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(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)
andTypeComparator.compareToReference(TypeComparator)
. - 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(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
- setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
- setReference(T1) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
- setReference(T1) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
-
Sets the reference for comparisons.
- 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.
- 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.functions.WrappingFunction
- 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
- 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(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
- setTimeToLive(Duration) - Method in class org.apache.flink.api.common.state.StateTtlConfig.Builder
- 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.
- setUseSnapshotCompression(boolean) - Method in class org.apache.flink.api.common.ExecutionConfig
- setValue(boolean) - 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(char) - Method in class org.apache.flink.types.CharValue
-
Sets the encapsulated char to the specified value.
- 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.
- setValue(double) - Method in class org.apache.flink.types.DoubleValue
-
Sets the value of the encapsulated primitive double.
- setValue(float) - Method in class org.apache.flink.types.FloatValue
-
Sets the value of the encapsulated primitive float.
- setValue(int) - Method in class org.apache.flink.types.IntValue
-
Sets the encapsulated int to the specified value.
- setValue(long) - Method in class org.apache.flink.types.LongValue
-
Sets the value of the encapsulated long to the specified value.
- setValue(short) - Method in class org.apache.flink.types.ShortValue
-
Sets the encapsulated short to the specified value.
- setValue(CharSequence) - Method in class org.apache.flink.types.StringValue
-
Sets the value of the StringValue to 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(L) - Method in class org.apache.flink.types.Either.Left
-
Sets the encapsulated value to another value
- setValue(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
- setValue(ByteValue) - Method in class org.apache.flink.types.ByteValue
- setValue(CharValue) - Method in class org.apache.flink.types.CharValue
- setValue(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
- setValue(FloatValue) - Method in class org.apache.flink.types.FloatValue
- setValue(IntValue) - Method in class org.apache.flink.types.IntValue
- setValue(LongValue) - Method in class org.apache.flink.types.LongValue
- setValue(ShortValue) - Method in class org.apache.flink.types.ShortValue
- 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(R) - Method in class org.apache.flink.types.Either.Right
-
Sets the encapsulated value to another value
- setValue(T) - Method in interface org.apache.flink.types.ResettableValue
-
Sets the encapsulated value to another 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
andShort
. - 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.
- shouldInterrupt() - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
-
Return if operator/function should interrupt a longer computation and return from the currently processed elemenent/watermark, for example in order to let Flink perform a checkpoint.
- 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
- SHUTDOWN_ON_APPLICATION_FINISH - Static variable in class org.apache.flink.configuration.DeploymentOptions
- ShutdownHookUtil - Class in org.apache.flink.util
-
Utils class for dealing with JVM shutdown hooks.
- signalAlreadyCommitted() - Method in interface org.apache.flink.api.connector.sink2.Committer.CommitRequest
-
Signals that a committable is skipped as it was committed already in a previous run.
- signalFailedWithKnownReason(Throwable) - Method in interface org.apache.flink.api.connector.sink2.Committer.CommitRequest
-
The commit failed for known reason and should not be retried.
- signalFailedWithUnknownReason(Throwable) - Method in interface org.apache.flink.api.connector.sink2.Committer.CommitRequest
-
The commit failed for unknown reason and should not be retried.
- signalIntermediateNoMoreSplits(int) - Method in interface org.apache.flink.api.connector.source.SupportsIntermediateNoMoreSplits
-
Signals a subtask that it will not receive split for current source, but it will receive split for next sources.
- 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 usestoString()
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.
- SimpleVersionedSerializerAdapter<T> - Class in org.apache.flink.core.io
-
Adapter for
TypeSerializer
toSimpleVersionedSerializer
. - SimpleVersionedSerializerAdapter(TypeSerializer<T>) - Constructor for class org.apache.flink.core.io.SimpleVersionedSerializerAdapter
- SimpleVersionedSerializerTypeSerializerProxy<T> - Class in org.apache.flink.core.io
-
A
TypeSerializer
that delegates to an underlyingSimpleVersionedSerializer
. - SimpleVersionedSerializerTypeSerializerProxy(SerializableSupplier<SimpleVersionedSerializer<T>>) - Constructor for class org.apache.flink.core.io.SimpleVersionedSerializerTypeSerializerProxy
- SingleInputOperator<IN,OUT,FT extends org.apache.flink.api.common.functions.Function> - Class in org.apache.flink.api.common.operators
-
Abstract superclass 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> - Interface in org.apache.flink.api.connector.sink2
-
Base interface for developing a sink.
- sinks - Variable in class org.apache.flink.api.common.Plan
-
A collection of all sinks in the plan.
- SinkUtils - Class in org.apache.flink.api.common.io
-
Utility class for sinks.
- SinkUtils() - Constructor for class org.apache.flink.api.common.io.SinkUtils
- SinkWriter<InputT> - Interface in org.apache.flink.api.connector.sink2
-
The
SinkWriter
is responsible for writing data. - SinkWriter.Context - Interface in org.apache.flink.api.connector.sink2
-
Context that
SinkWriter.write(InputT, org.apache.flink.api.connector.sink2.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() - Method in class org.apache.flink.util.LinkedOptionalMap
- SIZE - Static variable in class org.apache.flink.util.AbstractID
-
The size of the ID in byte.
- 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(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
- skip(long) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
- 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 - org.apache.flink.core.memory.ManagedMemoryUseCase.Scope
- SLOT_IDLE_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
The timeout in milliseconds for a idle slot in Slot Pool.
- SLOT_REQUEST_MAX_INTERVAL - Static variable in class org.apache.flink.configuration.JobManagerOptions
- SLOT_REQUEST_TIMEOUT - Static variable in class org.apache.flink.configuration.JobManagerOptions
-
The timeout in milliseconds for requesting a slot from Slot Pool.
- SLOT_TIMEOUT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
Timeout for identifying inactive slots.
- SLOTS - org.apache.flink.configuration.TaskManagerOptions.TaskManagerLoadBalanceMode
- SlotSharingGroup - Class in org.apache.flink.api.common.operators
-
Describe the name and 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
- SlowTaskDetectorOptions - Class in org.apache.flink.configuration
-
Configuration options to detect slow tasks.
- snapshot(TypeSerializer<?>...) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerUtils
-
Takes snapshots of the given serializers.
- SNAPSHOT_COMPRESSION - Static variable in class org.apache.flink.configuration.ExecutionOptions
-
Should be moved to
CheckpointingOptions
along withExecutionConfig#useSnapshotCompression
, which should be put intoCheckpointConfig
. - 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(long) - Method in interface org.apache.flink.api.connector.sink2.StatefulSinkWriter
- 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.IteratorSourceReaderBase
- 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.
- snapshotState(long) - Method in class org.apache.flink.api.connector.source.util.ratelimit.RateLimitedSourceReader
- 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. in particular, this method makes sure that IPv6 addresses have the proper formatting to be included in URLs.
- socketToUrl(InetSocketAddress) - Static method in class org.apache.flink.util.NetUtils
-
Converts an InetSocketAddress to a URL.
- SOLARIS - org.apache.flink.util.OperatingSystem
- SolutionSetPlaceHolder(DeltaIterationBase<ST, ?>, OperatorInformation<ST>) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
- SORT - org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
-
Use a sort-based strategy.
- SORT_INPUTS - Static variable in class org.apache.flink.configuration.ExecutionOptions
- SORT_KEYED_PARTITION_MEMORY - Static variable in class org.apache.flink.configuration.ExecutionOptions
- SORT_PARTITION_MEMORY - 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 aSourceReader
) 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 interface that exposes some context from runtime to the
SourceReader
. - SourceReaderFactory<T,SplitT extends SourceSplit> - Interface in org.apache.flink.api.connector.source
-
A factory for creating source reader instances.
- 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
- SPECULATIVE_ENABLED - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- SPECULATIVE_MAX_CONCURRENT_EXECUTIONS - Static variable in class org.apache.flink.configuration.BatchExecutionOptions
- 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
-
The interface for a split enumerator responsible for discovering the source splits, and assigning them to the
SourceReader
. - 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.BlobServerOptions
-
Flag to override ssl support for the blob service transport.
- SSL_ENABLED - Static variable in class org.apache.flink.configuration.RpcOptions
-
Override SSL support for the Pekko transport.
- 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 (pekko 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_KEYSTORE_TYPE - Static variable in class org.apache.flink.configuration.SecurityOptions
-
For internal SSL, the type of the keystore.
- 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_INTERNAL_TRUSTSTORE_TYPE - Static variable in class org.apache.flink.configuration.SecurityOptions
-
For internal SSL, the type of 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_KEYSTORE_TYPE - Static variable in class org.apache.flink.configuration.SecurityOptions
-
For external (REST) SSL, the type of the keystore.
- 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_REST_TRUSTSTORE_TYPE - Static variable in class org.apache.flink.configuration.SecurityOptions
-
For external (REST) SSL, the type of 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.IteratorSourceReaderBase
- 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() - Method in class org.apache.flink.api.connector.source.util.ratelimit.RateLimitedSourceReader
- start(SourceReaderContext) - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
- 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) - Method in class org.apache.flink.types.StringValue
-
Checks whether this StringValue starts with the given prefix string.
- 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.
- STARTUP_TIMEOUT - Static variable in class org.apache.flink.configuration.RpcOptions
-
Timeout for the startup of the actor system.
- STATE - org.apache.flink.configuration.MetricOptions.JobStatusMetrics
- STATE_BACKEND - org.apache.flink.core.memory.ManagedMemoryUseCase
- 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.StateChangelogOptions
-
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
- StateChangelogOptions - Class in org.apache.flink.configuration
-
A collection of all configuration options that relate to changelog.
- StateChangelogOptions() - Constructor for class org.apache.flink.configuration.StateChangelogOptions
- StateDescriptor<S extends org.apache.flink.api.common.state.State,T> - Class in org.apache.flink.api.common.state
-
Base class for state descriptors.
- 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(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, 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.Type - Enum in org.apache.flink.api.common.state
-
An enumeration of the types of supported states.
- StatefulSinkWriter<InputT,WriterStateT> - Interface in org.apache.flink.api.connector.sink2
-
A
SinkWriter
whose state needs to be checkpointed. - StateFutureImpl<T> - Class in org.apache.flink.core.state
-
The default implementation of
StateFuture
. - StateFutureImpl(StateFutureImpl.CallbackRunner, StateFutureImpl.AsyncFrameworkExceptionHandler) - Constructor for class org.apache.flink.core.state.StateFutureImpl
- StateFutureImpl.AsyncFrameworkExceptionHandler - Interface in org.apache.flink.core.state
-
Handle exceptions thrown by async state callback framework.
- StateFutureImpl.CallbackRunner - Interface in org.apache.flink.core.state
-
The entry for a state future to submit task to mailbox.
- StateFutureUtils - Class in org.apache.flink.core.state
-
A collection of utilities that expand the usage of
StateFuture
. - StateFutureUtils() - Constructor for class org.apache.flink.core.state.StateFutureUtils
- StateLatencyTrackOptions - Class in org.apache.flink.configuration
-
A collection of all configuration options that relate to the latency tracking for state access.
- StateLatencyTrackOptions() - Constructor for class org.apache.flink.configuration.StateLatencyTrackOptions
- 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(String, Throwable) - Constructor for exception org.apache.flink.util.StateMigrationException
- StateMigrationException(Throwable) - Constructor for exception org.apache.flink.util.StateMigrationException
- StateRecoveryOptions - Class in org.apache.flink.configuration
-
The
configuration options
used when restoring state from a savepoint or a checkpoint. - StateRecoveryOptions() - Constructor for class org.apache.flink.configuration.StateRecoveryOptions
- 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, SavepointFormatType) - 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
- stream(Optional<T>) - Static method in class org.apache.flink.util.OptionalUtils
- 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(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(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(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(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(ThrowingRunnable<? extends Exception>) - Method in interface org.apache.flink.core.state.StateFutureImpl.CallbackRunner
- 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.
- SUBMIT_FAILED_JOB_ON_APPLICATION_ERROR - Static variable in class org.apache.flink.configuration.DeploymentOptions
- 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
- subTypeCast(Collection<? super T>) - Static method in class org.apache.flink.util.CollectionUtil
-
Casts the given collection to a subtype.
- 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
- 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
. - SupportsBatchSnapshot - Interface in org.apache.flink.api.connector.source
-
A decorative interface
SplitEnumerator
. - SupportsCommitter<CommittableT> - Interface in org.apache.flink.api.connector.sink2
-
A mixin interface for a
Sink
which supports exactly-once semantics using a two-phase commit protocol. - supportsCompareAgainstReference() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
- SupportsConcurrentExecutionAttempts - Interface in org.apache.flink.api.common
-
The interface indicates that it supports multiple attempts executing at the same time.
- SupportsHandleExecutionAttemptSourceEvent - Interface in org.apache.flink.api.connector.source
-
An decorative interface of
SplitEnumerator
which allows to handleSourceEvent
sent from a specific execution attempt. - SupportsIntermediateNoMoreSplits - Interface in org.apache.flink.api.connector.source
-
A decorative interface of
SplitEnumeratorContext
which allows to handle intermediate NoMoreSplits. - 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
- SupportsWriterState<InputT,WriterStateT> - Interface in org.apache.flink.api.connector.sink2
-
A mixin interface for a
Sink
which supports a statefulStatefulSinkWriter
. - SupportsWriterState.WithCompatibleState - Interface in org.apache.flink.api.connector.sink2
-
A mix-in for
SupportsWriterState
that allows users to migrate from a sink with a compatible state to this sink. - suppressExceptions(RunnableWithException) - Static method in class org.apache.flink.util.ExceptionUtils
- SUSPENDED - org.apache.flink.api.common.JobStatus
-
The job has been suspended which means that it has been stopped but not been removed from a potential HA job store.
- 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
- sync() - Method in class org.apache.flink.core.fs.local.LocalRecoverableFsDataOutputStream
- sync() - Method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- 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 - org.apache.flink.core.failure.FailureEnricher.Context.FailureType
-
The failure has been reported by a particular task.
- TASK_CANCELLATION_INTERVAL - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
Time interval in milliseconds between two successive task cancellation attempts.
- 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 - org.apache.flink.core.failure.FailureEnricher.Context.FailureType
-
The TaskManager has non-gracefully disconnected from the JobMaster or we have not received heartbeats for the
configured timeout
. - TASK_MANAGER_LOAD_BALANCE_MODE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
- TASK_MANAGER_LOG_PATH - Static variable in class org.apache.flink.configuration.TaskManagerOptions
- TASK_MANAGER_NODE_ID - Static variable in class org.apache.flink.configuration.TaskManagerOptionsInternal
-
The ID of the node where the TaskManager is located on.
- TASK_MANAGER_PROCESS_WORKING_DIR_BASE - Static variable in class org.apache.flink.configuration.ClusterOptions
- 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_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_SYSTEM_OUT_LOG_CACHE_SIZE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
- TASK_MANAGER_SYSTEM_OUT_LOG_THREAD_NAME - Static variable in class org.apache.flink.configuration.TaskManagerOptions
- TASK_MANAGER_SYSTEM_OUT_MODE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
This configures how to redirect the
System.out
andSystem.err
. - TASK_MANAGER_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
-
The timeout for an idle task manager to be released.
- TASK_OFF_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
-
Task Off-Heap Memory size for TaskExecutors.
- TaskInfo - Interface in org.apache.flink.api.common
-
The
TaskInfo
represents the meta information of current task. - TaskInfoImpl - Class in org.apache.flink.api.common
-
The default implementation of
TaskInfo
. - TaskInfoImpl(String, int, int, int, int) - Constructor for class org.apache.flink.api.common.TaskInfoImpl
- TaskInfoImpl(String, int, int, int, int, String) - Constructor for class org.apache.flink.api.common.TaskInfoImpl
- 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.
- TaskManagerOptions.SystemOutMode - Enum in org.apache.flink.configuration
-
Type of redirection of
System.out
andSystem.err
. - TaskManagerOptions.TaskManagerLoadBalanceMode - Enum in org.apache.flink.configuration
- 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_CONNECTION_REUSE_ACROSS_JOBS_ENABLED - Static variable in class org.apache.flink.configuration.NettyShuffleEnvironmentOptions
-
Whether to reuse tcp connections across multi jobs.
- TCP_TIMEOUT - Static variable in class org.apache.flink.configuration.RpcOptions
-
The Pekko 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) - Method in class org.apache.flink.configuration.description.Description.DescriptionBuilder
-
Creates a simple block of text.
- text(String) - Static method in class org.apache.flink.configuration.description.TextElement
-
Creates a simple block of text.
- 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, 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
. - 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. code, bold etc. - thenAccept(ThrowingConsumer<? super T, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenAccept(ThrowingConsumer<? super T, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- 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. - thenApply(FunctionWithException<? super T, ? extends U, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenApply(FunctionWithException<? super T, ? extends U, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- 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. - thenCombine(StateFuture<? extends U>, BiFunctionWithException<? super T, ? super U, ? extends V, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenCombine(StateFuture<? extends U>, BiFunctionWithException<? super T, ? super U, ? extends V, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- thenCompose(FunctionWithException<? super T, ? extends StateFuture<U>, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenCompose(FunctionWithException<? super T, ? extends StateFuture<U>, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- 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. - thenConditionallyAccept(FunctionWithException<? super T, Boolean, ? extends Exception>, ThrowingConsumer<? super T, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenConditionallyAccept(FunctionWithException<? super T, Boolean, ? extends Exception>, ThrowingConsumer<? super T, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- thenConditionallyAccept(FunctionWithException<? super T, Boolean, ? extends Exception>, ThrowingConsumer<? super T, ? extends Exception>, ThrowingConsumer<? super T, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenConditionallyAccept(FunctionWithException<? super T, Boolean, ? extends Exception>, ThrowingConsumer<? super T, ? extends Exception>, ThrowingConsumer<? super T, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- thenConditionallyApply(FunctionWithException<? super T, Boolean, ? extends Exception>, FunctionWithException<? super T, ? extends U, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenConditionallyApply(FunctionWithException<? super T, Boolean, ? extends Exception>, FunctionWithException<? super T, ? extends U, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- thenConditionallyApply(FunctionWithException<? super T, Boolean, ? extends Exception>, FunctionWithException<? super T, ? extends U, ? extends Exception>, FunctionWithException<? super T, ? extends V, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenConditionallyApply(FunctionWithException<? super T, Boolean, ? extends Exception>, FunctionWithException<? super T, ? extends U, ? extends Exception>, FunctionWithException<? super T, ? extends V, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- thenConditionallyCompose(FunctionWithException<? super T, Boolean, ? extends Exception>, FunctionWithException<? super T, ? extends StateFuture<U>, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenConditionallyCompose(FunctionWithException<? super T, Boolean, ? extends Exception>, FunctionWithException<? super T, ? extends StateFuture<U>, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- thenConditionallyCompose(FunctionWithException<? super T, Boolean, ? extends Exception>, FunctionWithException<? super T, ? extends StateFuture<U>, ? extends Exception>, FunctionWithException<? super T, ? extends StateFuture<V>, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenConditionallyCompose(FunctionWithException<? super T, Boolean, ? extends Exception>, FunctionWithException<? super T, ? extends StateFuture<U>, ? extends Exception>, FunctionWithException<? super T, ? extends StateFuture<V>, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- thenSyncAccept(ThrowingConsumer<? super T, ? extends Exception>) - Method in class org.apache.flink.core.state.CompletedStateFuture
- thenSyncAccept(ThrowingConsumer<? super T, ? extends Exception>) - Method in interface org.apache.flink.core.state.InternalStateFuture
-
Accept the action in the same thread with the one of complete (or current thread if it has been completed).
- thenSyncAccept(ThrowingConsumer<? super T, ? extends Exception>) - Method in class org.apache.flink.core.state.StateFutureImpl
- THREAD_DUMP_STACKTRACE_MAX_DEPTH - Static variable in class org.apache.flink.configuration.ClusterOptions
- ThreadUtils - Class in org.apache.flink.util.concurrent
-
ThreadUtils
collects helper methods in the context of threading. - ThreadUtils() - Constructor for class org.apache.flink.util.concurrent.ThreadUtils
- THROW - org.apache.flink.configuration.ClusterOptions.UserSystemExitMode
- 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.
- 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() - Method in interface org.apache.flink.api.connector.sink2.SinkWriter.Context
-
Returns the timestamp of the current input record or
null
if the element does not have an assigned timestamp. - TIMESTAMP - Static variable in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
- 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
-
Additional information available to
TimestampAssignerSupplier.createTimestampAssigner(Context)
. - 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
. - toConfiguration() - Method in class org.apache.flink.api.common.ExecutionConfig
- 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.
- toFileWritableMap() - Method in class org.apache.flink.configuration.Configuration
-
Convert Config into a
Map<String, String>
representation. - toFileWritableMap() - Method in class org.apache.flink.configuration.DelegatingConfiguration
- 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
- TOLERABLE_FAILURE_NUMBER - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- 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
- toMap() - Method in interface org.apache.flink.configuration.ReadableConfig
-
Converts the configuration items into a map of string key-value pairs.
- toMap() - Method in class org.apache.flink.util.AbstractParameterTool
- toMap() - Method in class org.apache.flink.util.MultipleParameterTool
- toMap() - Method in class org.apache.flink.util.ParameterTool
- toMultiMap() - Method in class org.apache.flink.util.MultipleParameterTool
-
Return MultiMap of all the parameters processed by
MultipleParameterTool
. - toOptional() - Method in class org.apache.flink.types.SerializableOptional
- TOP_LEVEL - org.apache.flink.api.common.ExecutionConfig.ClosureCleanerLevel
- 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
- 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.serialization.SerializerConfigImpl
- 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.typeinfo.BasicArrayTypeInfo
- toString() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
- toString() - Method in class org.apache.flink.api.common.typeinfo.descriptor.BasicTypeDescriptorImpl
- toString() - Method in class org.apache.flink.api.common.typeinfo.descriptor.ListTypeDescriptorImpl
- toString() - Method in class org.apache.flink.api.common.typeinfo.descriptor.MapTypeDescriptorImpl
- toString() - Method in class org.apache.flink.api.common.typeinfo.descriptor.ValueTypeDescriptorImpl
- 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.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.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.FileSystem.FSKey
- 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.fs.RefCountedBufferingFileStream
- 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.PortRange
- toString() - Method in class org.apache.flink.util.Reference
- 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
- toString() - Method in class org.apache.flink.util.Utils.ChecksumHashCode
- 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.
- TOTAL_TIME - org.apache.flink.configuration.MetricOptions.JobStatusMetrics
- 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
- toYAMLString(Object) - Static method in class org.apache.flink.configuration.YamlParserUtils
-
Converts the given value to a string representation in the YAML syntax.
- TRACE_REPORTERS_LIST - Static variable in class org.apache.flink.configuration.TraceOptions
-
An optional list of reporter names.
- TraceOptions - Class in org.apache.flink.configuration
-
Configuration options for traces and trace reporters.
- TRACES_REPORTER_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
-
The prefix for per-trace reporter configs.
- 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. - Transformation(String, TypeInformation<T>, int, boolean) - 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
- 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.
- TREE - org.apache.flink.configuration.PipelineOptions.VertexDescriptionMode
-
Organizes the description in a multi line tree mode.
- triggerSavepoint(String, SavepointFormatType) - Method in interface org.apache.flink.core.execution.JobClient
-
Triggers a savepoint for the associated job.
- TRUE - org.apache.flink.util.TernaryBoolean
-
The value for 'true'.
- TRUE - Static variable in class org.apache.flink.types.BooleanValue
- tryAcquire(int, int, Duration, Semaphore) - Static method in class org.apache.flink.api.common.io.SinkUtils
-
Acquire permits on the given semaphore within a given allowed timeout and deal with errors.
- 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.
- tryGetAvroUtils() - Static method in class org.apache.flink.api.java.typeutils.AvroUtils
-
Returns either
Optional#EMPTY
which throw an exception in cases where Avro would be needed or loads the specific utils for Avro from flink-avro. - tryLock() - Method in class org.apache.flink.util.FileLock
-
Try to acquire a lock on the locking file.
- tryMoveToNextSplit() - Method in class org.apache.flink.api.connector.source.lib.util.IteratorSourceReaderBase
- tryReadFully(InputStream, byte[]) - Static method in class org.apache.flink.util.IOUtils
-
Similar to
IOUtils.readFully(InputStream, byte[], int, int)
. - 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 method attempts to run the command at the head of the mailbox.
- 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(TypeInformation<?>...) - Static method in class org.apache.flink.api.common.typeinfo.Types
-
Returns type information for subclasses of Flink's
Tuple
(namelyTuple0
tillTuple25
) with fields of the given types. - 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
- tupleClass - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
- TupleComparator<T extends org.apache.flink.api.java.tuple.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 org.apache.flink.api.java.tuple.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
- TupleSerializerSnapshot<T extends org.apache.flink.api.java.tuple.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 org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.api.java.typeutils
-
A
TypeInformation
for the tuple types of the Java API. - TupleTypeInfo(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
- TupleTypeInfo(TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
- TupleTypeInfoBase<T> - Class in org.apache.flink.api.java.typeutils
- TupleTypeInfoBase(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
- TupleUnwrappingIterator<T,K> - Class in org.apache.flink.api.common.operators.util
-
An iterator that reads 2-tuples (key value pairs) and returns only the values (second field).
- TupleUnwrappingIterator() - Constructor for class org.apache.flink.api.common.operators.util.TupleUnwrappingIterator
- 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 produceTypeInformation
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 - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
- 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
- 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
- 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 aTypeSerializer
can be safely used to read data written by a previous type serializer. - 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 aTypeSerializer
'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 theTypeSerializerSnapshot
. - 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
- UNALIGNED_MAX_SUBTASKS_PER_CHANNEL_STATE_FILE - Static variable in class org.apache.flink.configuration.CheckpointingOptions
- 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
- uncheckedConsumer(ThrowingConsumer<A, ?>) - Static method in class org.apache.flink.util.function.FunctionUtils
-
Converts a
ThrowingConsumer
into aConsumer
which throws checked exceptions as unchecked. - uncheckedFunction(FunctionWithException<A, B, ?>) - Static method in class org.apache.flink.util.function.FunctionUtils
-
Convert at
FunctionWithException
into aFunction
. - uncheckedSupplier(SupplierWithException<T, ?>) - Static method in class org.apache.flink.util.function.FunctionUtils
-
Converts a
SupplierWithException
into aSupplier
which throws all checked exceptions as unchecked. - UNDEFINED - org.apache.flink.util.TernaryBoolean
-
The value for 'undefined'.
- UNFINISHED_PRODUCERS - org.apache.flink.configuration.JobManagerOptions.HybridPartitionDataConsumeConstraint
- 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 - org.apache.flink.api.common.state.StateDescriptor.Type
-
Deprecated.Enum for migrating from old checkpoints/savepoint versions.
- UNKNOWN - org.apache.flink.util.OperatingSystem
- UNKNOWN - org.apache.flink.util.ProcessorArchitecture
-
Unknown architecture, could not be determined.
- 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
orInvalidClassException
. - 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
- unlock() - Method in class org.apache.flink.util.FileLock
-
Release the file lock.
- unlockAndDestroy() - Method in class org.apache.flink.util.FileLock
-
Release the file lock, close the fileChannel and FileOutputStream then try deleting the locking file if other file lock does not need it, which means the lock will not be used anymore.
- 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
- UNQUOTED_CHARS_AFTER_QUOTED_STRING - org.apache.flink.types.parser.FieldParser.ParseErrorState
-
The parser found characters between the end of the quoted string and the delimiter.
- unregisterAndCloseAll(Closeable...) - Method in class org.apache.flink.core.fs.CloseableRegistry
-
Unregisters all given
Closeable
objects from this registry and closes all objects that are were actually registered. - unregisterCloseable(C) - Method in class org.apache.flink.util.AbstractAutoCloseableRegistry
-
Removes a
Closeable
from the registry. - unregisterCloseable(Closeable) - Method in interface org.apache.flink.core.fs.ICloseableRegistry
-
Removes a
Closeable
from the registry. - unregisterOutput(String) - Method in class org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
- unrequestedParameters - Variable in class org.apache.flink.util.AbstractParameterTool
- unresolvedHostAndPortToNormalizedString(String, int) - Static method in class org.apache.flink.util.NetUtils
-
Returns a valid address for Pekko.
- unresolvedHostToNormalizedString(String) - Static method in class org.apache.flink.util.NetUtils
-
Returns an address in a normalized format for Pekko.
- UNSAFE - Static variable in class org.apache.flink.core.memory.MemoryUtils
-
The "unsafe", which can be used to perform native memory accesses.
- UNSPECIFIED - org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
- 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
. - UNTERMINATED_QUOTED_STRING - org.apache.flink.types.parser.FieldParser.ParseErrorState
-
A quoted string was not terminated until the line end.
- 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_AFTER - org.apache.flink.types.RowKind
-
Update operation with new content of the updated row.
- UPDATE_BEFORE - org.apache.flink.types.RowKind
-
Update operation with the previous content of the updated row.
- updateAndRetryLater(CommT) - Method in interface org.apache.flink.api.connector.sink2.Committer.CommitRequest
-
Updates the underlying committable and retries later (see
Committer.CommitRequest.retryLater()
for a description). - 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.
- URL_PREFIX - Static variable in class org.apache.flink.configuration.RestOptions
-
The url prefix that should be used by clients to construct the full target url.
- USE_BATCH_STATE_BACKEND - Static variable in class org.apache.flink.configuration.ExecutionOptions
- 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
- Utils - Class in org.apache.flink.util
-
Utility class that contains helper methods to work with Java APIs.
- Utils.ChecksumHashCode - Class in org.apache.flink.util
-
Accumulator of
Utils.ChecksumHashCode
. - Utils.ChecksumHashCodeHelper<T> - Class in org.apache.flink.util
- Utils.CollectHelper<T> - Class in org.apache.flink.util
-
Utility sink function that collects elements into an accumulator, from which it they can be retrieved by the client.
- Utils.CountHelper<T> - Class in org.apache.flink.util
-
Utility sink function that counts elements and writes the count into an accumulator, from which it can be retrieved by the client.
V
- validate() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
- validateClassLoadable(ClassNotFoundException, ClassLoader) - Static method in class org.apache.flink.util.ClassLoaderUtil
-
Checks, whether the class that was not found in the given exception, can be resolved through the given class loader.
- 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, boolean) - 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, 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 annotation type org.apache.flink.api.common.typeinfo.TypeInfo
- Value - Interface in org.apache.flink.types
-
Basic value interface for types that act as serializable values.
- VALUE - org.apache.flink.api.common.state.StateDescriptor.Type
- 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
). - 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.ExecutionConfig.ClosureCleanerLevel
-
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.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.ExternalizedCheckpointRetention
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.configuration.JobManagerOptions.HybridPartitionDataConsumeConstraint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.configuration.JobManagerOptions.JobStoreType
-
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.MetricOptions.JobStatusMetrics
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.configuration.NettyShuffleEnvironmentOptions.CompressionCodec
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.configuration.PipelineOptions.VertexDescriptionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.configuration.RestartStrategyOptions.RestartStrategyType
-
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.configuration.TaskManagerOptions.SystemOutMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.configuration.TaskManagerOptions.TaskManagerLoadBalanceMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.core.execution.CheckpointingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.core.execution.CheckpointType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.core.execution.RecoveryClaimMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.core.execution.SavepointFormatType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.core.failure.FailureEnricher.Context.FailureType
-
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.FlinkUserCodeClassLoaders.ResolveOrder
-
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.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.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.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.ExternalizedCheckpointRetention
-
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.HybridPartitionDataConsumeConstraint
-
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.JobStoreType
-
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.MetricOptions.JobStatusMetrics
-
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.NettyShuffleEnvironmentOptions.CompressionCodec
-
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.PipelineOptions.VertexDescriptionMode
-
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.RestartStrategyOptions.RestartStrategyType
-
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.configuration.TaskManagerOptions.SystemOutMode
-
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.TaskManagerOptions.TaskManagerLoadBalanceMode
-
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.execution.CheckpointingMode
-
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.execution.CheckpointType
-
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.execution.RecoveryClaimMode
-
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.execution.SavepointFormatType
-
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.failure.FailureEnricher.Context.FailureType
-
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.FlinkUserCodeClassLoaders.ResolveOrder
-
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.ValueSerializerSnapshot<T extends Value> - Class in org.apache.flink.api.java.typeutils.runtime
-
ValueSerializer
snapshot class. - ValueSerializerSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerSnapshot
- ValueStateDescriptor<T> - Class in org.apache.flink.api.common.state
-
StateDescriptor
forValueState
. - 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, 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 isnull
. - 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, 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 isnull
. - 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. - 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 isnull
. - ValueTypeDescriptorImpl<T extends Value> - Class in org.apache.flink.api.common.typeinfo.descriptor
-
Implementation of
TypeDescriptor
to createValueTypeInfo
. - ValueTypeDescriptorImpl(TypeDescriptor<T>) - Constructor for class org.apache.flink.api.common.typeinfo.descriptor.ValueTypeDescriptorImpl
- 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
- VERTEX_DESCRIPTION_MODE - Static variable in class org.apache.flink.configuration.PipelineOptions
- VERTEX_NAME_INCLUDE_INDEX_PREFIX - Static variable in class org.apache.flink.configuration.PipelineOptions
- 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
- 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.
- WATERMARK_ALIGNMENT_DISABLED - Static variable in class org.apache.flink.api.common.eventtime.WatermarkAlignmentParams
- WatermarkAlignmentParams - Class in org.apache.flink.api.common.eventtime
-
Configuration parameters for watermark alignment.
- WatermarkAlignmentParams(long, String, long) - Constructor for class org.apache.flink.api.common.eventtime.WatermarkAlignmentParams
- 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
-
Additional information available to
WatermarkGeneratorSupplier.createWatermarkGenerator(Context)
. - 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 underlyingWatermarkOutput
. - WatermarkOutputMultiplexer(WatermarkOutput) - Constructor for class org.apache.flink.api.common.eventtime.WatermarkOutputMultiplexer
-
Creates a new
WatermarkOutputMultiplexer
that emits combined updates to the givenWatermarkOutput
. - WatermarkOutputMultiplexer.WatermarkUpdateListener - Interface in org.apache.flink.api.common.eventtime
-
A callback for propagating changes to split based watermarks.
- WatermarkStrategy<T> - Interface in org.apache.flink.api.common.eventtime
-
The WatermarkStrategy defines how to generate
Watermark
s 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, RelativeClock) - 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.
- WINDOWS - org.apache.flink.util.OperatingSystem
- WithConfigurationOpenContext - Class in org.apache.flink.api.common.functions
-
A special
OpenContext
for passing configuration to udf. - WithConfigurationOpenContext(Configuration) - Constructor for class org.apache.flink.api.common.functions.WithConfigurationOpenContext
- withContext(Map<String, String>) - Static method in class org.apache.flink.util.MdcUtils
-
Replace MDC contents with the provided one and return a closeable object that can be used to restore the original MDC.
- 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
. - 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
. - 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 createdWatermarkGenerator
. - withNames() - Static method in class org.apache.flink.types.Row
-
Creates a variable-length row in name-based field mode.
- withNames(RowKind) - Static method in class org.apache.flink.types.Row
-
Creates a variable-length row in name-based field mode.
- withPositions(int) - Static method in class org.apache.flink.types.Row
-
Creates a fixed-length row in position-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.
- 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 givenSerializableTimestampAssigner
. - 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 givenTimestampAssigner
(via aTimestampAssignerSupplier
). - withWatermarkAlignment(String, Duration) - Method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
-
Creates a new
WatermarkStrategy
that configures the maximum watermark drift from other sources/tasks/partitions in the same watermark group. - withWatermarkAlignment(String, Duration, Duration) - Method in interface org.apache.flink.api.common.eventtime.WatermarkStrategy
-
Creates a new
WatermarkStrategy
that configures the maximum watermark drift from other sources/tasks/partitions in the same watermark group. - WorksetPlaceHolder(DeltaIterationBase<?, WT>, OperatorInformation<WT>) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
- wrap(byte[]) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
-
Creates a new memory segment that targets the given heap memory region.
- 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(TypeSerializer<T>, boolean) - Static method in class org.apache.flink.api.java.typeutils.runtime.NullableSerializer
-
This method wraps the
originalSerializer
with theNullableSerializer
if not already wrapped. - wrap(InlineElement...) - Static method in class org.apache.flink.configuration.description.TextElement
-
Wraps a list of
InlineElement
s into a singleTextElement
. - wrapAsByteBuffer() - Method in class org.apache.flink.core.memory.DataOutputSerializer
- wrapCallable(Map<String, String>, Callable<T>) - Static method in class org.apache.flink.util.MdcUtils
-
Wrap the given
Callable
so that the given data is added toMDC
before its execution and removed afterward. - 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 theoriginalSerializer
and wraps it in case ofNullPointerException
, otherwise it returns theoriginalSerializer
. - 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.
- wrappedFunction - Variable in class org.apache.flink.api.common.functions.WrappingFunction
- WrappedSink<T> - Class in org.apache.flink.api.connector.dsv2
-
A simple
Sink
implementation that wrap a sink-v2 based sink. - WrappedSink(Sink<T>) - Constructor for class org.apache.flink.api.connector.dsv2.WrappedSink
- WrappedSource<T> - Class in org.apache.flink.api.connector.dsv2
-
A simple
Source
implementation that wrap a FLIP-27 source. - WrappedSource(Source<T, ?, ?>) - Constructor for class org.apache.flink.api.connector.dsv2.WrappedSource
- WrappingFunction<T extends org.apache.flink.api.common.functions.Function> - Class in org.apache.flink.api.common.functions
-
Wrapper around
Function
. - WrappingFunction(T) - Constructor for class org.apache.flink.api.common.functions.WrappingFunction
- 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
forCloseable
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(String, Throwable) - Constructor for exception org.apache.flink.util.WrappingRuntimeException
- WrappingRuntimeException(Throwable) - Constructor for exception org.apache.flink.util.WrappingRuntimeException
- wrapRunnable(Map<String, String>, Runnable) - Static method in class org.apache.flink.util.MdcUtils
-
Wrap the given
Runnable
so that the given data is added toMDC
before its execution and removed afterward. - 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
- wrapSink(Sink<T>) - Static method in class org.apache.flink.api.connector.dsv2.DataStreamV2SinkUtils
-
Wrap a sink-v2 based sink to a DataStream V2 supported sink.
- wrapSource(Source<T, ?, ?>) - Static method in class org.apache.flink.api.connector.dsv2.DataStreamV2SourceUtils
-
Wrap a FLIP-27 based source to a DataStream V2 supported source.
- WritableConfig - Interface in org.apache.flink.configuration
-
Write access to a configuration object.
- write(byte[]) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
- write(byte[]) - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
- write(byte[]) - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
- write(byte[]) - Method in class org.apache.flink.core.memory.DataOutputSerializer
- write(byte[]) - Method in class org.apache.flink.util.CloseShieldOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
- write(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
- write(byte[], int, int) - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
- write(byte[], int, int) - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.core.fs.local.LocalRecoverableFsDataOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.core.fs.OffsetAwareOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- write(byte[], int, int) - Method in class org.apache.flink.core.fs.RefCountedFileWithStream
- write(byte[], int, int) - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
- write(byte[], int, int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
- write(byte[], int, int) - Method in class org.apache.flink.util.CloseShieldOutputStream
- write(int) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
- write(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
- write(int) - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
- write(int) - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
- write(int) - Method in class org.apache.flink.core.fs.local.LocalRecoverableFsDataOutputStream
- write(int) - Method in class org.apache.flink.core.fs.RefCountedBufferingFileStream
- write(int) - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
- write(int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
- write(int) - Method in class org.apache.flink.util.CloseShieldOutputStream
- write(Kryo, Output, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.DummyAvroKryoSerializerClass
- write(Kryo, Output, T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
- write(IN) - Method in class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
- write(InputT, SinkWriter.Context) - Method in interface org.apache.flink.api.connector.sink2.SinkWriter
-
Adds an element to the writer.
- write(IN, SinkWriter.Context) - Method in class org.apache.flink.api.common.functions.util.PrintSinkOutputWriter
- 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(DataOutputView) - Method in class org.apache.flink.api.common.io.BlockInfo
- write(DataOutputView) - Method in class org.apache.flink.configuration.Configuration
- write(DataOutputView) - Method in class org.apache.flink.configuration.DelegatingConfiguration
- 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(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
- write(MemorySegment, int, int) - Method in class org.apache.flink.core.memory.DataOutputSerializer
- write(MemorySegment, int, int) - Method in interface org.apache.flink.core.memory.MemorySegmentWritable
-
Writes
len
bytes from memory segmentsegment
starting at offsetoff
, in order, to the output. - WRITE_BUFFER_SIZE - Static variable in class org.apache.flink.configuration.JobEventStoreOptions
- 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, Charset) - 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
- writeLongUTF(String) - Method in class org.apache.flink.core.memory.DataOutputSerializer
-
Similar to
DataOutputSerializer.writeUTF(String)
. - writeMask(boolean[], int, DataOutputView) - Static method in class org.apache.flink.api.java.typeutils.runtime.MaskUtils
- writeMask(boolean[], 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. any information beyond the nested serializers of the outer serializer.
- 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.RowSerializer.RowSerializerSnapshot
- 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(IT) - Method in interface org.apache.flink.api.common.io.OutputFormat
-
Adds a record to the output.
- writeRecord(OUT) - Method in class org.apache.flink.api.common.io.OutputFormatBase
-
Asynchronously write a record and deal with
OutputFormatBase.maxConcurrentRequests
. - writeRecord(T) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
- writeRecord(T) - Method in class org.apache.flink.util.Utils.ChecksumHashCodeHelper
- writeRecord(T) - Method in class org.apache.flink.util.Utils.CollectHelper
- writeRecord(T) - Method in class org.apache.flink.util.Utils.CountHelper
- WriterInitContext - Interface in org.apache.flink.api.connector.sink2
-
The interface exposes some runtime info for creating a
SinkWriter
. - writeSerializerSnapshot(DataOutputView, TypeSerializerSnapshot<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.base.EnumSerializer.EnumSerializerSnapshot
- 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 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.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) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
-
Serializes the version and datum into a byte array.
- writeVersionAndSerialize(SimpleVersionedSerializer<T>, T, DataOutputView) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
-
Serializes the version and datum into a stream.
- writeVersionAndSerializeList(SimpleVersionedSerializer<T>, List<T>, DataOutputView) - Static method in class org.apache.flink.core.io.SimpleVersionedSerialization
-
Serializes the version and data into a stream.
- 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.sink2.SinkWriter
-
Adds a watermark to the writer.
- 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(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(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(Row, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
- 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.base.array.PrimitiveArrayComparator
- writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
- 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(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
- X86 - org.apache.flink.util.ProcessorArchitecture
-
The Intel x86 processor architecture.
- 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
- YamlParserUtils - Class in org.apache.flink.configuration
-
This class contains utility methods to load standard yaml file and convert object to standard yaml syntax.
- YamlParserUtils() - Constructor for class org.apache.flink.configuration.YamlParserUtils
- yield() - Method in interface org.apache.flink.api.common.operators.MailboxExecutor
-
This method 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.
- ZOOKEEPER_CLIENT_ACL - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
- ZOOKEEPER_CLIENT_AUTHORIZATION - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
- ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
- ZOOKEEPER_ENSEMBLE_TRACKING - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
- ZOOKEEPER_MAX_CLOSE_WAIT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
- ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
- ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
- 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.SecurityOptions
- ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
- ZOOKEEPER_SIMULATED_SESSION_EXP_PERCENT - 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
- ZSTD - org.apache.flink.configuration.NettyShuffleEnvironmentOptions.CompressionCodec
_
- _32_BIT - org.apache.flink.util.ProcessorArchitecture.MemoryAddressSize
-
32 bit memory address size.
- _64_BIT - org.apache.flink.util.ProcessorArchitecture.MemoryAddressSize
-
64 bit memory address size.
All Classes All Packages